You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by am...@apache.org on 2019/04/30 10:15:16 UTC

[ignite] branch gg-18539 created (now 6175879)

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

amashenkov pushed a change to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git.


      at 6175879  GG-18539: Remove useless code.

This branch includes the following new commits:

     new d074c3f  GG-17388 Fixed flaky test IgnitePdsStartWIthEmptyArchive
     new 5e317d4  GG-17389 Fixed flaky test IgnitePdsWithTtlTest
     new d2c944f  IGNITE-11762 Mute testClientStartCloseServersRestart test with known issue
     new f4f20f7  GG-17405 Web Console: Fixed missing e-mail templates in "Direct install" packages.
     new c35f196  GG-17331 Clean up GridDhtPartitionsFullMessage when not needed, do not hold decompressed partsSizes in field.
     new 85643a8  GG-17344 Idle Verify --cache-filter ALL should include system caches.
     new b2c6983  GG-17375 Web Console: Implemented support for Mongo 4.x and latest Ubuntu. Co-authored-by: Vasiliy Sisko <vs...@gridgain.com> Co-authored-by: Andrey Novikov <an...@gridgain.com> Co-authored-by: Ilya Murchenko <im...@gridgain.com>
     new c247d5b  GG-17405 Fix of wrong commit.
     new e66ff5d  GG-17424 Disable by default bash pipefail/errexit/nounset options from Ignite startup scripts
     new a813e04  GG-17434 Fix memory leak on unstable topology caused by partition reservation
     new 1326c5e  GG-17466 Web Console: Fixed e2e tests. Fixes #15.
     new b1a355a  GG-17480 Implement WAL page snapshot records compression - Fixes #6116.
     new ac5baab  GG-17440 DMS feature id changed for the sake of rolling upgrade support.
     new 41536c7  GG-14890: Integrate H2 codebase to GG as separate module.
     new 77c839d  GG-17480 Implement WAL page snapshot records compression  * fixed groupId causing compilation errors
     new 1aeed47  GG-18539: Remove useless dependencies.
     new 6175879  GG-18539: Remove useless code.

The 17 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.



[ignite] 10/17: GG-17434 Fix memory leak on unstable topology caused by partition reservation

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit a813e047f8b091ceaba6820501e6bde9e79274a6
Author: tledkov <tl...@gridgain.com>
AuthorDate: Fri Apr 26 19:54:09 2019 +0300

    GG-17434 Fix memory leak on unstable topology caused by partition reservation
---
 .../query/h2/twostep/PartitionReservationKey.java  |  13 ++
 .../h2/twostep/PartitionReservationManager.java    |  73 +++++--
 .../query/MemLeakOnSqlWithClientReconnectTest.java | 218 +++++++++++++++++++++
 .../testsuites/IgniteCacheQuerySelfTestSuite6.java |   4 +-
 4 files changed, 290 insertions(+), 18 deletions(-)

diff --git a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/PartitionReservationKey.java b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/PartitionReservationKey.java
index 73984bc..d02b6b8 100644
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/PartitionReservationKey.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/PartitionReservationKey.java
@@ -18,6 +18,7 @@ package org.apache.ignite.internal.processors.query.h2.twostep;
 
 import org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion;
 import org.apache.ignite.internal.util.typedef.F;
+import org.apache.ignite.internal.util.typedef.internal.S;
 
 /**
  * Partition reservation key.
@@ -47,6 +48,13 @@ public class PartitionReservationKey {
         return cacheName;
     }
 
+    /**
+     * @return Topology version of reservation.
+     */
+    public AffinityTopologyVersion topologyVersion() {
+        return topVer;
+    }
+
     /** {@inheritDoc} */
     @Override public boolean equals(Object o) {
         if (this == o)
@@ -69,4 +77,9 @@ public class PartitionReservationKey {
 
         return res;
     }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(PartitionReservationKey.class, this);
+    }
 }
diff --git a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/PartitionReservationManager.java b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/PartitionReservationManager.java
index e91d7d5..89d7a01 100644
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/PartitionReservationManager.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/PartitionReservationManager.java
@@ -16,13 +16,24 @@
 
 package org.apache.ignite.internal.processors.query.h2.twostep;
 
+import java.util.ArrayList;
+import java.util.Collection;
+import java.util.Collections;
+import java.util.List;
+import java.util.UUID;
+import java.util.concurrent.ConcurrentHashMap;
+import java.util.concurrent.ConcurrentMap;
 import org.apache.ignite.IgniteCheckedException;
+import org.apache.ignite.IgniteLogger;
 import org.apache.ignite.cache.PartitionLossPolicy;
 import org.apache.ignite.internal.GridKernalContext;
+import org.apache.ignite.internal.managers.communication.GridIoPolicy;
 import org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion;
 import org.apache.ignite.internal.processors.cache.CacheInvalidStateException;
 import org.apache.ignite.internal.processors.cache.GridCacheContext;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridReservable;
+import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture;
+import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.PartitionsExchangeAware;
 import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtLocalPartition;
 import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtPartitionState;
 import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtPartitionsReservation;
@@ -30,14 +41,6 @@ import org.apache.ignite.internal.util.typedef.CI1;
 import org.apache.ignite.internal.util.typedef.F;
 import org.jetbrains.annotations.Nullable;
 
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.Collections;
-import java.util.List;
-import java.util.UUID;
-import java.util.concurrent.ConcurrentHashMap;
-import java.util.concurrent.ConcurrentMap;
-
 import static org.apache.ignite.cache.PartitionLossPolicy.READ_ONLY_SAFE;
 import static org.apache.ignite.cache.PartitionLossPolicy.READ_WRITE_SAFE;
 import static org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion.NONE;
@@ -45,19 +48,24 @@ import static org.apache.ignite.internal.processors.cache.distributed.dht.topolo
 import static org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtPartitionState.OWNING;
 
 /**
- * Class responsible for partition reservation for queries executed on local node.
- * Prevents partitions from being eveicted from node during query execution.
+ * Class responsible for partition reservation for queries executed on local node. Prevents partitions from being
+ * evicted from node during query execution.
  */
-public class PartitionReservationManager {
+public class PartitionReservationManager implements PartitionsExchangeAware {
     /** Special instance of reservable object for REPLICATED caches. */
     private static final ReplicatedReservable REPLICATED_RESERVABLE = new ReplicatedReservable();
 
     /** Kernal context. */
     private final GridKernalContext ctx;
 
-    /** Reservations. */
+    /** Group reservations cache. When affinity version is not changed and all primary partitions must be reserved
+     * we get group reservation from this map instead of create new reservation group.
+     */
     private final ConcurrentMap<PartitionReservationKey, GridReservable> reservations = new ConcurrentHashMap<>();
 
+    /** Logger. */
+    private final IgniteLogger log;
+
     /**
      * Constructor.
      *
@@ -65,11 +73,15 @@ public class PartitionReservationManager {
      */
     public PartitionReservationManager(GridKernalContext ctx) {
         this.ctx = ctx;
+
+        log = ctx.log(PartitionReservationManager.class);
+
+        ctx.cache().context().exchange().registerExchangeAwareComponent(this);
     }
 
     /**
      * @param cacheIds Cache IDs.
-     * @param topVer Topology version.
+     * @param reqTopVer Topology version from request.
      * @param explicitParts Explicit partitions list.
      * @param nodeId Node ID.
      * @param reqId Request ID.
@@ -78,18 +90,18 @@ public class PartitionReservationManager {
      */
     public PartitionReservation reservePartitions(
         @Nullable List<Integer> cacheIds,
-        AffinityTopologyVersion topVer,
+        AffinityTopologyVersion reqTopVer,
         final int[] explicitParts,
         UUID nodeId,
         long reqId
     ) throws IgniteCheckedException {
-        assert topVer != null;
+        assert reqTopVer != null;
+
+        AffinityTopologyVersion topVer = ctx.cache().context().exchange().lastAffinityChangedTopologyVersion(reqTopVer);
 
         if (F.isEmpty(cacheIds))
             return new PartitionReservation(Collections.emptyList());
 
-        List<GridReservable> reserved = new ArrayList<>();
-
         Collection<Integer> partIds;
 
         if (explicitParts == null)
@@ -103,6 +115,8 @@ public class PartitionReservationManager {
                 partIds.add(explicitPart);
         }
 
+        List<GridReservable> reserved = new ArrayList<>();
+
         for (int i = 0; i < cacheIds.size(); i++) {
             GridCacheContext<?, ?> cctx = ctx.cache().context().cacheContext(cacheIds.get(i));
 
@@ -308,6 +322,31 @@ public class PartitionReservationManager {
     }
 
     /**
+     * Cleanup group reservations cache on change affinity version.
+     */
+    @Override public void onDoneAfterTopologyUnlock(final GridDhtPartitionsExchangeFuture fut) {
+        try {
+            // Must not do anything at the exchange thread. Dispatch to the management thread pool.
+            ctx.closure().runLocal(() -> {
+                    AffinityTopologyVersion topVer = ctx.cache().context().exchange()
+                        .lastAffinityChangedTopologyVersion(fut.topologyVersion());
+
+                    reservations.forEach((key, r) -> {
+                        if (r != REPLICATED_RESERVABLE && !F.eq(key.topologyVersion(), topVer)) {
+                            assert r instanceof GridDhtPartitionsReservation;
+
+                            ((GridDhtPartitionsReservation)r).invalidate();
+                        }
+                    });
+                },
+                GridIoPolicy.MANAGEMENT_POOL);
+        }
+        catch (Throwable e) {
+            log.error("Unexpected exception on start reservations cleanup", e);
+        }
+    }
+
+    /**
      * Mapper fake reservation object for replicated caches.
      */
     private static class ReplicatedReservable implements GridReservable {
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/MemLeakOnSqlWithClientReconnectTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/MemLeakOnSqlWithClientReconnectTest.java
new file mode 100644
index 0000000..ad56e11
--- /dev/null
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/MemLeakOnSqlWithClientReconnectTest.java
@@ -0,0 +1,218 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ *
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal.processors.query;
+
+import java.util.Collections;
+import java.util.List;
+import java.util.Map;
+import java.util.concurrent.atomic.AtomicBoolean;
+import java.util.concurrent.atomic.AtomicInteger;
+import org.apache.ignite.IgniteCache;
+import org.apache.ignite.cache.CacheMode;
+import org.apache.ignite.cache.QueryEntity;
+import org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction;
+import org.apache.ignite.cache.query.FieldsQueryCursor;
+import org.apache.ignite.cache.query.SqlFieldsQuery;
+import org.apache.ignite.configuration.CacheConfiguration;
+import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.internal.IgniteEx;
+import org.apache.ignite.internal.IgniteInternalFuture;
+import org.apache.ignite.internal.processors.cache.index.AbstractIndexingCommonTest;
+import org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing;
+import org.apache.ignite.internal.util.typedef.internal.U;
+import org.apache.ignite.logger.NullLogger;
+import org.apache.ignite.testframework.GridTestUtils;
+import org.junit.Test;
+
+/**
+ * Tests for group reservation leaks at the PartitionReservationManager on unstable topology.
+ */
+public class MemLeakOnSqlWithClientReconnectTest extends AbstractIndexingCommonTest {
+    /** Keys count. */
+    private static final int KEY_CNT = 10;
+
+    /** Keys count. */
+    private static final int ITERS = 2000;
+
+    /** Replicated cache schema name. */
+    private static final String REPL_SCHEMA = "REPL";
+
+    /** Partitioned cache schema name. */
+    private static final String PART_SCHEMA = "PART";
+
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration getConfiguration(String igniteInstanceName) throws Exception {
+        IgniteConfiguration cfg = super.getConfiguration(igniteInstanceName);
+
+        if (igniteInstanceName.startsWith("cli"))
+            cfg.setClientMode(true).setGridLogger(new NullLogger());
+
+        return cfg;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected void beforeTest() throws Exception {
+        super.beforeTest();
+
+        startGrid();
+
+        IgniteCache<Long, Long> partCache = grid().createCache(new CacheConfiguration<Long, Long>()
+            .setName("part")
+            .setSqlSchema("PART")
+            .setQueryEntities(Collections.singleton(new QueryEntity(Long.class, Long.class)
+                .setTableName("test")
+                .addQueryField("id", Long.class.getName(), null)
+                .addQueryField("val", Long.class.getName(), null)
+                .setKeyFieldName("id")
+                .setValueFieldName("val")
+            ))
+            .setAffinity(new RendezvousAffinityFunction(false, 10)));
+
+        IgniteCache<Long, Long> replCache = grid().createCache(new CacheConfiguration<Long, Long>()
+            .setName("repl")
+            .setSqlSchema("REPL")
+            .setQueryEntities(Collections.singleton(new QueryEntity(Long.class, Long.class)
+                .setTableName("test")
+                .addQueryField("id", Long.class.getName(), null)
+                .addQueryField("val", Long.class.getName(), null)
+                .setKeyFieldName("id")
+                .setValueFieldName("val")))
+            .setCacheMode(CacheMode.REPLICATED));
+
+        for (long i = 0; i < KEY_CNT; ++i) {
+            partCache.put(i, i);
+            replCache.put(i, i);
+        }
+    }
+
+    /** {@inheritDoc} */
+    @Override protected void afterTest() throws Exception {
+        stopAllGrids();
+
+        super.afterTest();
+    }
+
+    /**
+     * Test partition group reservation leaks on partitioned cache.
+     *
+     * @throws Exception On error.
+     */
+    @Test
+    public void testPartitioned() throws Exception {
+        checkReservationLeak(false);
+    }
+
+    /**
+     * Test partition group reservation leaks on replicated cache.
+     *
+     * @throws Exception On error.
+     */
+    @Test
+    public void testReplicated() throws Exception {
+        checkReservationLeak(true);
+    }
+
+    /**
+     * Check partition group reservation leaks.
+     *
+     * @param replicated Flag to run query on partitioned or replicated cache.
+     * @throws Exception On error.
+     */
+    private void checkReservationLeak(boolean replicated) throws Exception {
+        final AtomicInteger cliNum = new AtomicInteger();
+        final AtomicBoolean end = new AtomicBoolean();
+
+        IgniteInternalFuture<Long> fut = GridTestUtils.runMultiThreadedAsync(() -> {
+                String name = "cli_" + cliNum.getAndIncrement();
+
+                while (!end.get()) {
+                    try {
+                        startGrid(name);
+
+                        U.sleep(10);
+
+                        stopGrid(name);
+                    }
+                    catch (Exception e) {
+                        fail("Unexpected exception on start test client node");
+                    }
+                }
+            },
+            10, "cli-restart");
+
+        try {
+
+            String mainCliName = "cli-main";
+
+            IgniteEx cli = startGrid(mainCliName);
+
+            // Warm up.
+            runQuery(cli, ITERS, replicated);
+
+            int baseReservations = reservationCount(grid());
+
+            // Run multiple queries on unstable topology.
+            runQuery(cli, ITERS * 10, replicated);
+
+            int curReservations = reservationCount(grid());
+
+            assertTrue("Reservations leaks: [base=" + baseReservations + ", cur=" + curReservations + ']',
+                curReservations < baseReservations * 2);
+
+            log.info("Reservations OK: [base=" + baseReservations + ", cur=" + curReservations + ']');
+        }
+        finally {
+            end.set(true);
+        }
+
+        fut.get();
+    }
+
+    /**
+     * @param ign Ignite.
+     * @param iters Run query 'iters' times
+     * @param repl Run on replicated or partitioned cache.
+     */
+    private void runQuery(IgniteEx ign, int iters, boolean repl) {
+        for (int i = 0; i < iters; ++i)
+            sql(ign, repl ? REPL_SCHEMA : PART_SCHEMA,"SELECT * FROM test").getAll();
+    }
+
+    /**
+     * @param ign Ignite instance.
+     * @param sql SQL query.
+     * @param args Query parameters.
+     * @return Results cursor.
+     */
+    private FieldsQueryCursor<List<?>> sql(IgniteEx ign, String schema, String sql, Object... args) {
+        return ign.context().query().querySqlFields(new SqlFieldsQuery(sql)
+            .setSchema(schema)
+            .setArgs(args), false);
+    }
+
+    /**
+     * @param ign Ignite instance.
+     * @return Count of reservations.
+     */
+    private static int reservationCount(IgniteEx ign) {
+        IgniteH2Indexing idx = (IgniteH2Indexing)ign.context().query().getIndexing();
+
+        Map reservations = GridTestUtils.getFieldValue(idx.partitionReservationManager(), "reservations");
+
+        return reservations.size();
+    }
+}
diff --git a/modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteCacheQuerySelfTestSuite6.java b/modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteCacheQuerySelfTestSuite6.java
index a3223df..00a7dea 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteCacheQuerySelfTestSuite6.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteCacheQuerySelfTestSuite6.java
@@ -36,6 +36,7 @@ import org.apache.ignite.internal.processors.cache.query.continuous.GridCacheCon
 import org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryReplicatedAtomicOneNodeTest;
 import org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryReplicatedAtomicSelfTest;
 import org.apache.ignite.internal.processors.cache.query.continuous.IgniteCacheContinuousQueryClientTest;
+import org.apache.ignite.internal.processors.query.MemLeakOnSqlWithClientReconnectTest;
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
 
@@ -63,7 +64,8 @@ import org.junit.runners.Suite;
     CacheContinuousWithTransformerRandomOperationsTest.class,
     CacheContinuousQueryRandomOperationsTest.class,
     StaticCacheDdlTest.class,
-    StaticCacheDdlKeepStaticConfigurationTest.class
+    StaticCacheDdlKeepStaticConfigurationTest.class,
+    MemLeakOnSqlWithClientReconnectTest.class,
 })
 public class IgniteCacheQuerySelfTestSuite6 {
 }


[ignite] 02/17: GG-17389 Fixed flaky test IgnitePdsWithTtlTest

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 5e317d4460b489c0334b807c46284d0e5c0a793a
Author: Slava Koptilin <sl...@gmail.com>
AuthorDate: Fri Apr 26 13:09:36 2019 +0300

    GG-17389 Fixed flaky test IgnitePdsWithTtlTest
---
 .../processors/cache/persistence/db/IgnitePdsWithTtlTest.java        | 5 ++++-
 1 file changed, 4 insertions(+), 1 deletion(-)

diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsWithTtlTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsWithTtlTest.java
index 90d8ad3..174119e 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsWithTtlTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsWithTtlTest.java
@@ -24,6 +24,7 @@ import javax.cache.expiry.Duration;
 import javax.cache.expiry.ExpiryPolicy;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteCheckedException;
+import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cache.CachePeekMode;
 import org.apache.ignite.cache.CacheRebalanceMode;
 import org.apache.ignite.cache.CacheWriteSynchronizationMode;
@@ -45,6 +46,7 @@ import org.apache.ignite.internal.util.typedef.PA;
 import org.apache.ignite.internal.util.typedef.internal.CU;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.MvccFeatureChecker;
+import org.apache.ignite.testframework.junits.WithSystemProperty;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.junit.Test;
 
@@ -53,6 +55,7 @@ import static org.apache.ignite.IgniteSystemProperties.IGNITE_BASELINE_AUTO_ADJU
 /**
  * Test TTL worker with persistence enabled
  */
+@WithSystemProperty(key = IgniteSystemProperties.IGNITE_UNWIND_THROTTLING_TIMEOUT, value = "5")
 public class IgnitePdsWithTtlTest extends GridCommonAbstractTest {
     /** */
     public static final String CACHE_NAME = "expirableCache";
@@ -189,7 +192,7 @@ public class IgnitePdsWithTtlTest extends GridCommonAbstractTest {
         fillCache(srv.cache(CACHE_NAME));
 
         if (restartGrid) {
-            srv.context().cache().context().database().wakeupForCheckpoint("test-checkpoint");
+            srv.context().cache().context().database().waitForCheckpoint("test-checkpoint");
 
             stopGrid(0);
             srv = startGrid(0);


[ignite] 07/17: GG-17375 Web Console: Implemented support for Mongo 4.x and latest Ubuntu. Co-authored-by: Vasiliy Sisko Co-authored-by: Andrey Novikov Co-authored-by: Ilya Murchenko

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit b2c6983f5ced57195f5b9581ee308b1dce9a3d75
Author: Vasiliy Sisko <vs...@gridgain.com>
AuthorDate: Fri Apr 26 20:00:18 2019 +0700

    GG-17375 Web Console: Implemented support for Mongo 4.x and latest Ubuntu.
    Co-authored-by: Vasiliy Sisko <vs...@gridgain.com>
    Co-authored-by: Andrey Novikov <an...@gridgain.com>
    Co-authored-by: Ilya Murchenko <im...@gridgain.com>
---
 docker/web-console/standalone/Dockerfile           |    8 +-
 modules/web-console/DEVNOTES.txt                   |    2 +-
 modules/web-console/backend/.eslintrc              |  169 +
 modules/web-console/backend/.gitignore             |    1 +
 modules/web-console/backend/app/configure.js       |    4 +-
 modules/web-console/backend/app/mongo.js           |   40 +-
 modules/web-console/backend/app/schemas.js         |    5 +-
 modules/web-console/backend/index.js               |    6 +-
 modules/web-console/backend/launch-tools.js        |   28 +-
 .../migrations/1502249492000-invalidate_rename.js  |    4 +-
 .../1508395969410-init-registered-date.js          |    4 +-
 .../migrations/1516948939797-migrate-configs.js    |   44 +-
 .../1547440382485-account-make-email-unique.js     |   18 +-
 .../backend/migrations/migration-utils.js          |    2 +-
 modules/web-console/backend/package-lock.json      | 8115 ++++++++++++++++++++
 modules/web-console/backend/package.json           |   54 +-
 modules/web-console/backend/services/auth.js       |    8 +-
 modules/web-console/backend/services/caches.js     |   44 +-
 modules/web-console/backend/services/clusters.js   |   32 +-
 modules/web-console/backend/services/domains.js    |   28 +-
 modules/web-console/backend/services/igfss.js      |   28 +-
 modules/web-console/backend/services/mails.js      |    4 +-
 modules/web-console/backend/services/notebooks.js  |    4 +-
 modules/web-console/backend/services/spaces.js     |    8 +-
 modules/web-console/backend/services/users.js      |   12 +-
 modules/web-console/backend/test/app/db.js         |    7 +-
 .../backend/{app/mongoose.js => test/app/mail.js}  |   12 +-
 .../backend/test/app/{mockgoose.js => settings.js} |   18 +-
 .../web-console/backend/test/config/settings.json  |    3 -
 modules/web-console/backend/test/injector.js       |    5 +-
 .../backend/test/unit/ActivitiesService.test.js    |   15 +-
 .../backend/test/unit/AuthService.test.js          |    4 +-
 .../web-console/docker/compose/docker-compose.yml  |    2 +-
 modules/web-console/e2e/docker-compose.yml         |    4 +-
 34 files changed, 8517 insertions(+), 225 deletions(-)

diff --git a/docker/web-console/standalone/Dockerfile b/docker/web-console/standalone/Dockerfile
index 0005f9e..6a85290 100644
--- a/docker/web-console/standalone/Dockerfile
+++ b/docker/web-console/standalone/Dockerfile
@@ -17,7 +17,7 @@
 #~~~~~~~~~~~~~~~~~~#
 #  Frontend build  #
 #~~~~~~~~~~~~~~~~~~#
-FROM node:8-slim as frontend-build
+FROM node:10-stretch as frontend-build
 
 ENV NPM_CONFIG_LOGLEVEL error
 
@@ -33,7 +33,7 @@ RUN cd frontend && \
 #~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~#
 #  Web Console Standalone assemble  #
 #~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~#
-FROM node:8-slim
+FROM node:10-stretch
 
 ENV NPM_CONFIG_LOGLEVEL error
 
@@ -41,8 +41,8 @@ ENV NPM_CONFIG_LOGLEVEL error
 RUN npm install -g pm2
 
 # Update software sources and install missing applications
-RUN apt-key adv --keyserver hkp://keyserver.ubuntu.com:80 --recv 0C49F3730359A14518585931BC711F9BA15703C6 && \
-    echo "deb http://repo.mongodb.org/apt/debian jessie/mongodb-org/3.4 main" > /etc/apt/sources.list.d/mongodb-org-3.4.list && \
+RUN apt-key adv --keyserver hkp://keyserver.ubuntu.com:80 --recv 9DA31620334BD75D9DCB49F368818C72E52529D4 \
+    && echo "deb http://repo.mongodb.org/apt/debian stretch/mongodb-org/4.0 main" | tee /etc/apt/sources.list.d/mongodb-org-4.0.list
     apt update && \
     apt install -y --no-install-recommends \
         nginx-light \
diff --git a/modules/web-console/DEVNOTES.txt b/modules/web-console/DEVNOTES.txt
index 6119d64..417829e 100644
--- a/modules/web-console/DEVNOTES.txt
+++ b/modules/web-console/DEVNOTES.txt
@@ -1,6 +1,6 @@
 Ignite Web Console Build Instructions
 =====================================
-1. Install MongoDB (version >=3.2.0 <=3.4.15) using instructions from http://docs.mongodb.org/manual/installation.
+1. Install MongoDB (version >=3.0) using instructions from http://docs.mongodb.org/manual/installation.
 2. Install Node.js (version >=8.0.0) using installer from https://nodejs.org/en/download/current for your OS.
 3. Change directory to 'modules/web-console/backend' and
  run "npm install --no-optional" for download backend dependencies.
diff --git a/modules/web-console/backend/.eslintrc b/modules/web-console/backend/.eslintrc
new file mode 100644
index 0000000..b288d07
--- /dev/null
+++ b/modules/web-console/backend/.eslintrc
@@ -0,0 +1,169 @@
+env:
+    es6: true
+    browser: false
+    mocha: true
+parserOptions:
+    sourceType: module
+    ecmaVersion: 2018
+
+rules:
+    arrow-parens: [1, "always"]
+    arrow-spacing: [1, { "before": true, "after": true }]
+    accessor-pairs: 2
+    block-scoped-var: 2
+    brace-style: [0, "1tbs"]
+    comma-dangle: [2, "never"]
+    comma-spacing: [2, {"before": false, "after": true}]
+    comma-style: [2, "last"]
+    complexity: [1, 40]
+    computed-property-spacing: [2, "never"]
+    consistent-return: 0
+    consistent-this: [0, "that"]
+    constructor-super: 2
+    curly: [2, "multi-or-nest"]
+    default-case: 2
+    dot-location: 0
+    dot-notation: [2, { "allowKeywords": true }]
+    eol-last: 2
+    eqeqeq: 2
+    func-names: 0
+    func-style: [0, "declaration"]
+    generator-star-spacing: 0
+    guard-for-in: 1
+    handle-callback-err: 0
+    id-length: [2, {"min": 1, "max": 60}]
+    indent: [2, 4, {"SwitchCase": 1, "MemberExpression": "off", "CallExpression": {"arguments": "off"}}]
+    key-spacing: [2, { "beforeColon": false, "afterColon": true }]
+    lines-around-comment: 0
+    linebreak-style: [0, "unix"]
+    max-depth: [0, 4]
+    max-len: [0, 120, 4]
+    max-nested-callbacks: [1, 4]
+    max-params: [0, 3]
+    max-statements: [0, 10]
+    new-cap: 2
+    new-parens: 2
+    no-alert: 2
+    no-array-constructor: 2
+    no-bitwise: 0
+    no-caller: 2
+    no-catch-shadow: 2
+    no-cond-assign: 2
+    no-console: 0
+    no-constant-condition: 2
+    no-continue: 0
+    no-class-assign: 2
+    no-const-assign: 2
+    no-control-regex: 2
+    no-debugger: 2
+    no-delete-var: 2
+    no-div-regex: 0
+    no-dupe-keys: 2
+    no-dupe-args: 2
+    no-duplicate-case: 2
+    no-else-return: 2
+    no-empty: 2
+    no-empty-character-class: 2
+    no-eq-null: 2
+    no-eval: 2
+    no-ex-assign: 2
+    no-extend-native: 2
+    no-extra-bind: 2
+    no-extra-boolean-cast: 2
+    no-extra-parens: 0
+    no-extra-semi: 2
+    no-fallthrough: 2
+    no-floating-decimal: 1
+    no-func-assign: 2
+    no-implied-eval: 2
+    no-inline-comments: 0
+    no-inner-declarations: [2, "functions"]
+    no-invalid-regexp: 2
+    no-irregular-whitespace: 2
+    no-iterator: 2
+    no-label-var: 2
+    no-labels: 2
+    no-lone-blocks: 2
+    no-lonely-if: 2
+    no-implicit-coercion: [2, {"boolean": false, "number": true, "string": true}]
+    no-loop-func: 2
+    no-mixed-requires: [0, false]
+    no-mixed-spaces-and-tabs: [2, true]
+    no-multi-spaces: ["error", {"exceptions": { "VariableDeclarator": true }}]
+    no-multi-str: 2
+    no-multiple-empty-lines: [0, {"max": 2}]
+    no-native-reassign: 2
+    no-negated-in-lhs: 2
+    no-nested-ternary: 0
+    no-new: 2
+    no-new-func: 2
+    no-new-object: 2
+    no-new-require: 0
+    no-new-wrappers: 2
+    no-obj-calls: 2
+    no-octal: 2
+    no-octal-escape: 2
+    no-param-reassign: 0
+    no-path-concat: 0
+    no-plusplus: 0
+    no-process-env: 0
+    no-process-exit: 0
+    no-proto: 2
+    no-redeclare: 2
+    no-regex-spaces: 1
+    no-restricted-modules: 0
+    no-script-url: 0
+    no-self-compare: 2
+    no-sequences: 2
+    no-shadow: 0
+    no-shadow-restricted-names: 2
+    no-spaced-func: 2
+    no-sparse-arrays: 1
+    no-sync: 0
+    no-ternary: 0
+    no-trailing-spaces: ["error", {"ignoreComments": true}]
+    no-throw-literal: 0
+    no-this-before-super: 2
+    no-unexpected-multiline: 2
+    // The rule produces undesired results with TS
+    // no-undef: 2
+    no-undef-init: 2
+    no-undefined: 2
+    no-unneeded-ternary: 2
+    no-unreachable: 2
+    no-unused-expressions: [2, { allowShortCircuit: true }]
+    no-unused-vars: [0, {"vars": "all", "args": "after-used"}]
+    typescript/no-unused-vars: [0]
+    no-useless-call: 2
+    no-void: 0
+    no-var: 2
+    no-warning-comments: 0
+    no-with: 2
+    newline-after-var: 0
+    object-shorthand: [2, "always"]
+    one-var: [2, "never"]
+    operator-assignment: [2, "always"]
+    operator-linebreak: 0
+    padded-blocks: 0
+    prefer-const: 1
+    prefer-spread: 2
+    quote-props: [2, "as-needed"]
+    quotes: [2, "single", {"allowTemplateLiterals": true}]
+    radix: 1
+    semi: [2, "always"]
+    semi-spacing: [2, {"before": false, "after": true}]
+    sort-vars: 0
+    keyword-spacing: 2
+    space-before-blocks: [2, "always"]
+    space-before-function-paren: [2, "never"]
+    space-in-parens: 0
+    space-infix-ops: 2
+    space-unary-ops: [2, { "words": true, "nonwords": false }]
+    spaced-comment: [1, "always", {"markers": ["/"]}]
+    use-isnan: 2
+    valid-jsdoc: 0
+    valid-typeof: 2
+    vars-on-top: 2
+    wrap-iife: 0
+    wrap-regex: 0
+    yoda: [2, "never"]
diff --git a/modules/web-console/backend/.gitignore b/modules/web-console/backend/.gitignore
index e5b9047..73bd1a1 100644
--- a/modules/web-console/backend/.gitignore
+++ b/modules/web-console/backend/.gitignore
@@ -1,2 +1,3 @@
 agent_dists/*.zip
 config/*.json
+!package-lock.json
diff --git a/modules/web-console/backend/app/configure.js b/modules/web-console/backend/app/configure.js
index 0c29070..29fbbaf 100644
--- a/modules/web-console/backend/app/configure.js
+++ b/modules/web-console/backend/app/configure.js
@@ -21,7 +21,7 @@ const logger = require('morgan');
 const cookieParser = require('cookie-parser');
 const bodyParser = require('body-parser');
 const session = require('express-session');
-const connectMongo = require('connect-mongo');
+const MongoDBStore = require('connect-mongodb-session');
 const passport = require('passport');
 const passportSocketIo = require('passport.socketio');
 const mongoSanitize = require('express-mongo-sanitize');
@@ -37,7 +37,7 @@ module.exports = {
 };
 
 module.exports.factory = function(settings, mongo, apis) {
-    const _sessionStore = new (connectMongo(session))({mongooseConnection: mongo.connection});
+    const _sessionStore = new (MongoDBStore(session))({uri: settings.mongoUrl});
 
     return {
         express: (app) => {
diff --git a/modules/web-console/backend/app/mongo.js b/modules/web-console/backend/app/mongo.js
index cacb61b..ec75a88 100644
--- a/modules/web-console/backend/app/mongo.js
+++ b/modules/web-console/backend/app/mongo.js
@@ -16,9 +16,9 @@
 
 'use strict';
 
+const fs = require('fs');
 const _ = require('lodash');
-const {MongodHelper} = require('mongodb-prebuilt');
-const {MongoDBDownload} = require('mongodb-download');
+const mongoose = require('mongoose');
 
 // Fire me up!
 
@@ -27,10 +27,10 @@ const {MongoDBDownload} = require('mongodb-download');
  */
 module.exports = {
     implements: 'mongo',
-    inject: ['settings', 'mongoose', 'schemas']
+    inject: ['settings', 'schemas']
 };
 
-const defineSchema = (mongoose, schemas) => {
+const defineSchema = (schemas) => {
     const result = { connection: mongoose.connection };
 
     result.ObjectId = mongoose.Types.ObjectId;
@@ -66,26 +66,36 @@ const upgradeAccounts = (mongo, activation) => {
             });
     }
 
-    return mongo.Account.update({activated: false}, {$unset: {activationSentAt: "", activationToken: ""}}, {multi: true}).exec();
+    return mongo.Account.updateMany({activated: false}, {$unset: {activationSentAt: '', activationToken: ''}}).exec();
 };
 
-module.exports.factory = function(settings, mongoose, schemas) {
+module.exports.factory = function(settings, schemas) {
     // Use native promises
     mongoose.Promise = global.Promise;
 
-    console.log('Trying to connect to local MongoDB...');
+    console.log(settings.mongoUrl, 'Trying to connect to local MongoDB...');
+
+
 
     // Connect to mongoDB database.
-    return mongoose.connect(settings.mongoUrl, {server: {poolSize: 4}})
-        .then(() => defineSchema(mongoose, schemas))
-        .catch((err) => {
-            console.log('Failed to connect to local MongoDB, will try to download and start embedded MongoDB', err);
+    return mongoose.connect(settings.mongoUrl, {useNewUrlParser: true, useCreateIndex: true})
+        .then(() => defineSchema(schemas))
+        .catch(() => {
+            console.log(`Failed to connect to MongoDB with connection string: "${settings.mongoUrl}", will try to download and start embedded MongoDB`);
+
+            const dbDir = `${process.cwd()}/user_data`;
+
+            if (!fs.existsSync(dbDir))
+                fs.mkdirSync(dbDir);
+
+            const {MongodHelper} = require('mongodb-prebuilt');
+            const {MongoDBDownload} = require('mongodb-download');
 
-            const helper = new MongodHelper(['--port', '27017', '--dbpath', `${process.cwd()}/user_data`]);
+            const helper = new MongodHelper(['--port', '27017', '--dbpath', dbDir]);
 
             helper.mongoBin.mongoDBPrebuilt.mongoDBDownload = new MongoDBDownload({
                 downloadDir: `${process.cwd()}/libs/mongodb`,
-                version: '3.4.7'
+                version: '4.0.9'
             });
 
             let mongodRun;
@@ -117,14 +127,14 @@ module.exports.factory = function(settings, mongoose, schemas) {
                 .then(() => {
                     console.log('Embedded MongoDB successfully started');
 
-                    return mongoose.connect(settings.mongoUrl, {server: {poolSize: 4}})
+                    return mongoose.connect(settings.mongoUrl, {useNewUrlParser: true, useCreateIndex: true})
                         .catch((err) => {
                             console.log('Failed to connect to embedded MongoDB', err);
 
                             return Promise.reject(err);
                         });
                 })
-                .then(() => defineSchema(mongoose, schemas))
+                .then(() => defineSchema(schemas))
                 .then((mongo) => {
                     if (settings.packaged) {
                         return mongo.Account.count()
diff --git a/modules/web-console/backend/app/schemas.js b/modules/web-console/backend/app/schemas.js
index b292e07..55e7245 100644
--- a/modules/web-console/backend/app/schemas.js
+++ b/modules/web-console/backend/app/schemas.js
@@ -16,6 +16,7 @@
 
 'use strict';
 
+const mongoose = require('mongoose');
 const passportMongo = require('passport-local-mongoose');
 
 // Fire me up!
@@ -25,10 +26,10 @@ const passportMongo = require('passport-local-mongoose');
  */
 module.exports = {
     implements: 'schemas',
-    inject: ['mongoose']
+    inject: []
 };
 
-module.exports.factory = function(mongoose) {
+module.exports.factory = function() {
     const Schema = mongoose.Schema;
     const ObjectId = mongoose.Schema.Types.ObjectId;
 
diff --git a/modules/web-console/backend/index.js b/modules/web-console/backend/index.js
index a756e1a..8024e81 100755
--- a/modules/web-console/backend/index.js
+++ b/modules/web-console/backend/index.js
@@ -22,7 +22,7 @@ const appPath = require('app-module-path');
 appPath.addPath(__dirname);
 appPath.addPath(path.join(__dirname, 'node_modules'));
 
-const { checkMongo, migrate, init } = require('./launch-tools');
+const { migrate, init } = require('./launch-tools');
 
 const injector = require('./injector');
 
@@ -30,9 +30,7 @@ injector.log.info = () => {};
 injector.log.debug = () => {};
 
 injector('mongo')
-    .then(() => checkMongo())
-    .then(() => injector('settings'))
-    .then(({mongoUrl}) => migrate(mongoUrl, 'Ignite', path.join(__dirname, 'migrations')))
+    .then((mongo) => migrate(mongo.connection, 'Ignite', path.join(__dirname, 'migrations')))
     .then(() => Promise.all([injector('settings'), injector('api-server'), injector('agents-handler'), injector('browsers-handler')]))
     .then(init)
     .catch((err) => {
diff --git a/modules/web-console/backend/launch-tools.js b/modules/web-console/backend/launch-tools.js
index d854f1d..a36b42b 100644
--- a/modules/web-console/backend/launch-tools.js
+++ b/modules/web-console/backend/launch-tools.js
@@ -19,8 +19,7 @@
 const _ = require('lodash');
 const http = require('http');
 const https = require('https');
-const MigrateMongoose = require('migrate-mongoose');
-const mongoose = require('mongoose');
+const MigrateMongoose = require('migrate-mongoose-typescript');
 
 /**
  * Event listener for HTTP server "error" event.
@@ -80,15 +79,15 @@ const init = ([settings, apiSrv, agentsHnd, browsersHnd]) => {
 /**
  * Run mongo model migration.
  *
- * @param dbConnectionUri Mongo connection url.
+ * @param connection Mongo connection.
  * @param group Migrations group.
  * @param migrationsPath Migrations path.
  * @param collectionName Name of collection where migrations write info about applied scripts.
  */
-const migrate = (dbConnectionUri, group, migrationsPath, collectionName) => {
+const migrate = (connection, group, migrationsPath, collectionName) => {
     const migrator = new MigrateMongoose({
         migrationsPath,
-        dbConnectionUri,
+        connection,
         collectionName,
         autosync: true
     });
@@ -110,21 +109,4 @@ const migrate = (dbConnectionUri, group, migrationsPath, collectionName) => {
         });
 };
 
-/**
- * Check version of used MongoDB.
- */
-const checkMongo = () => {
-    const versionValid = (mijor, minor) => mijor === 3 && minor >= 2 && minor <= 4;
-
-    const admin = new mongoose.mongo.Admin(mongoose.connection.db, null, global.Promise);
-
-    return admin.buildInfo()
-        .then((info) => {
-            const versions = info.version.split('.');
-
-            if (!versionValid(parseInt(versions[0]), parseInt(versions[1])))
-                throw Error(`Unsupported version of MongoDB ${info.version}. Supported versions: 3.2.x-3.4.x`);
-        });
-};
-
-module.exports = { checkMongo, migrate, init };
+module.exports = { migrate, init };
diff --git a/modules/web-console/backend/migrations/1502249492000-invalidate_rename.js b/modules/web-console/backend/migrations/1502249492000-invalidate_rename.js
index dc6bf52..ac07866 100644
--- a/modules/web-console/backend/migrations/1502249492000-invalidate_rename.js
+++ b/modules/web-console/backend/migrations/1502249492000-invalidate_rename.js
@@ -15,13 +15,13 @@
  */
 
 exports.up = function up(done) {
-    this('Cache').update({}, { $rename: {invalidate: 'isInvalidate'}}, {multi: true})
+    this('Cache').updateMany({}, { $rename: {invalidate: 'isInvalidate'}})
         .then(() => done())
         .catch(done);
 };
 
 exports.down = function down(done) {
-    this('Cache').update({}, { $rename: {isInvalidate: 'invalidate'}}, {multi: true})
+    this('Cache').updateMany({}, { $rename: {isInvalidate: 'invalidate'}})
         .then(() => done())
         .catch(done);
 };
diff --git a/modules/web-console/backend/migrations/1508395969410-init-registered-date.js b/modules/web-console/backend/migrations/1508395969410-init-registered-date.js
index 3348439..0918411 100644
--- a/modules/web-console/backend/migrations/1508395969410-init-registered-date.js
+++ b/modules/web-console/backend/migrations/1508395969410-init-registered-date.js
@@ -21,13 +21,13 @@ exports.up = function up(done) {
 
     accountsModel.find({}).lean().exec()
         .then((accounts) => _.reduce(accounts, (start, account) => start
-            .then(() => accountsModel.update({_id: account._id}, {$set: {registered: account.lastLogin}}).exec()), Promise.resolve()))
+            .then(() => accountsModel.updateOne({_id: account._id}, {$set: {registered: account.lastLogin}}).exec()), Promise.resolve()))
         .then(() => done())
         .catch(done);
 };
 
 exports.down = function down(done) {
-    this('Account').update({}, {$unset: {registered: 1}}, {multi: true}).exec()
+    this('Account').updateMany({}, {$unset: {registered: 1}}).exec()
         .then(() => done())
         .catch(done);
 };
diff --git a/modules/web-console/backend/migrations/1516948939797-migrate-configs.js b/modules/web-console/backend/migrations/1516948939797-migrate-configs.js
index 091a6f9..85042eb 100644
--- a/modules/web-console/backend/migrations/1516948939797-migrate-configs.js
+++ b/modules/web-console/backend/migrations/1516948939797-migrate-configs.js
@@ -32,15 +32,15 @@ function makeDup(name) {
 }
 
 function linkCacheToCluster(clustersModel, cluster, cachesModel, cache, domainsModel) {
-    return clustersModel.update({_id: cluster._id}, {$addToSet: {caches: cache._id}}).exec()
-        .then(() => cachesModel.update({_id: cache._id}, {clusters: [cluster._id]}).exec())
+    return clustersModel.updateOne({_id: cluster._id}, {$addToSet: {caches: cache._id}}).exec()
+        .then(() => cachesModel.updateOne({_id: cache._id}, {clusters: [cluster._id]}).exec())
         .then(() => {
             if (_.isEmpty(cache.domains))
                 return Promise.resolve();
 
             return _.reduce(cache.domains, (start, domain) => start.then(() => {
-                return domainsModel.update({_id: domain}, {clusters: [cluster._id]}).exec()
-                    .then(() => clustersModel.update({_id: cluster._id}, {$addToSet: {models: domain}}).exec());
+                return domainsModel.updateOne({_id: domain}, {clusters: [cluster._id]}).exec()
+                    .then(() => clustersModel.updateOne({_id: cluster._id}, {$addToSet: {models: domain}}).exec());
             }), Promise.resolve());
         })
         .catch((err) => error(`Failed link cache to cluster [cache=${cache.name}, cluster=${cluster.name}]`, err));
@@ -65,7 +65,7 @@ function cloneCache(clustersModel, cachesModel, domainsModel, cache) {
             newCache.clusters = [cluster];
             newCache.domains = [];
 
-            return clustersModel.update({_id: {$in: newCache.clusters}}, {$pull: {caches: cacheId}}, {multi: true}).exec()
+            return clustersModel.updateMany({_id: {$in: newCache.clusters}}, {$pull: {caches: cacheId}}).exec()
                 .then(() => cachesModel.create(newCache))
                 .catch((err) => {
                     if (err.code === DUPLICATE_KEY_ERROR) {
@@ -80,7 +80,7 @@ function cloneCache(clustersModel, cachesModel, domainsModel, cache) {
 
                     return Promise.reject(err);
                 })
-                .then((clone) => clustersModel.update({_id: {$in: newCache.clusters}}, {$addToSet: {caches: clone._id}}, {multi: true}).exec()
+                .then((clone) => clustersModel.updateMany({_id: {$in: newCache.clusters}}, {$addToSet: {caches: clone._id}}).exec()
                     .then(() => clone))
                 .then((clone) => {
                     if (_.isEmpty(domainIds))
@@ -109,8 +109,8 @@ function cloneCache(clustersModel, cachesModel, domainsModel, cache) {
                                         }
                                     })
                                     .then((createdDomain) => {
-                                        return clustersModel.update({_id: cluster}, {$addToSet: {models: createdDomain._id}}).exec()
-                                            .then(() => cachesModel.update({_id: clone.id}, {$addToSet: {domains: createdDomain._id}}));
+                                        return clustersModel.updateOne({_id: cluster}, {$addToSet: {models: createdDomain._id}}).exec()
+                                            .then(() => cachesModel.updateOne({_id: clone.id}, {$addToSet: {domains: createdDomain._id}}));
                                     })
                                     .catch((err) => error('Failed to clone domain during cache clone', err));
                             })
@@ -120,8 +120,8 @@ function cloneCache(clustersModel, cachesModel, domainsModel, cache) {
                 .catch((err) => error(`Failed to clone cache[id=${cacheId}, name=${cache.name}]`, err));
         }
 
-        return cachesModel.update({_id: cacheId}, {clusters: [cluster]}).exec()
-            .then(() => clustersModel.update({_id: cluster}, {$addToSet: {models: {$each: cache.domains}}}).exec());
+        return cachesModel.updateOne({_id: cacheId}, {clusters: [cluster]}).exec()
+            .then(() => clustersModel.updateOne({_id: cluster}, {$addToSet: {models: {$each: cache.domains}}}).exec());
     }), Promise.resolve());
 }
 
@@ -166,8 +166,8 @@ function migrateCaches(clustersModel, cachesModel, domainsModel) {
 }
 
 function linkIgfsToCluster(clustersModel, cluster, igfsModel, igfs) {
-    return clustersModel.update({_id: cluster._id}, {$addToSet: {igfss: igfs._id}}).exec()
-        .then(() => igfsModel.update({_id: igfs._id}, {clusters: [cluster._id]}).exec())
+    return clustersModel.updateOne({_id: cluster._id}, {$addToSet: {igfss: igfs._id}}).exec()
+        .then(() => igfsModel.updateOne({_id: igfs._id}, {clusters: [cluster._id]}).exec())
         .catch((err) => error(`Failed link IGFS to cluster [IGFS=${igfs.name}, cluster=${cluster.name}]`, err));
 }
 
@@ -184,13 +184,13 @@ function cloneIgfs(clustersModel, igfsModel, igfs) {
         newIgfs.clusters = [cluster];
 
         if (idx > 0) {
-            return clustersModel.update({_id: {$in: newIgfs.clusters}}, {$pull: {igfss: igfsId}}, {multi: true}).exec()
+            return clustersModel.updateMany({_id: {$in: newIgfs.clusters}}, {$pull: {igfss: igfsId}}).exec()
                 .then(() => igfsModel.create(newIgfs))
-                .then((clone) => clustersModel.update({_id: {$in: newIgfs.clusters}}, {$addToSet: {igfss: clone._id}}, {multi: true}).exec())
+                .then((clone) => clustersModel.updateMany({_id: {$in: newIgfs.clusters}}, {$addToSet: {igfss: clone._id}}).exec())
                 .catch((err) => error(`Failed to clone IGFS: id=${igfsId}, name=${igfs.name}]`, err));
         }
 
-        return igfsModel.update({_id: igfsId}, {clusters: [cluster]}).exec();
+        return igfsModel.updateOne({_id: igfsId}, {clusters: [cluster]}).exec();
     }), Promise.resolve());
 }
 
@@ -234,14 +234,14 @@ function migrateIgfss(clustersModel, igfsModel) {
 }
 
 function linkDomainToCluster(clustersModel, cluster, domainsModel, domain) {
-    return clustersModel.update({_id: cluster._id}, {$addToSet: {models: domain._id}}).exec()
-        .then(() => domainsModel.update({_id: domain._id}, {clusters: [cluster._id]}).exec())
+    return clustersModel.updateOne({_id: cluster._id}, {$addToSet: {models: domain._id}}).exec()
+        .then(() => domainsModel.updateOne({_id: domain._id}, {clusters: [cluster._id]}).exec())
         .catch((err) => error(`Failed link domain model to cluster [domain=${domain._id}, cluster=${cluster.name}]`, err));
 }
 
 function linkDomainToCache(cachesModel, cache, domainsModel, domain) {
-    return cachesModel.update({_id: cache._id}, {$addToSet: {domains: domain._id}}).exec()
-        .then(() => domainsModel.update({_id: domain._id}, {caches: [cache._id]}).exec())
+    return cachesModel.updateOne({_id: cache._id}, {$addToSet: {domains: domain._id}}).exec()
+        .then(() => domainsModel.updateOne({_id: domain._id}, {caches: [cache._id]}).exec())
         .catch((err) => error(`Failed link domain model to cache [cache=${cache.name}, domain=${domain._id}]`, err));
 }
 
@@ -290,16 +290,16 @@ function migrateDomain(clustersModel, cachesModel, domainsModel, domain) {
 
                             return domainsModel.create(domain)
                                 .then((clonedDomain) => {
-                                    return cachesModel.update({_id: {$in: clusterCaches}}, {$addToSet: {domains: clonedDomain._id}}).exec()
+                                    return cachesModel.updateOne({_id: {$in: clusterCaches}}, {$addToSet: {domains: clonedDomain._id}}).exec()
                                         .then(() => clonedDomain);
                                 })
                                 .then((clonedDomain) => linkDomainToCluster(clustersModel, {_id: cluster, name: `stub${idx}`}, domainsModel, clonedDomain))
                                 .then(() => {
-                                    return cachesModel.update({_id: {$in: clusterCaches}}, {$pull: {domains: domainId}}, {multi: true}).exec();
+                                    return cachesModel.updateMany({_id: {$in: clusterCaches}}, {$pull: {domains: domainId}}).exec();
                                 });
                         }
 
-                        return domainsModel.update(domainsModel.update({_id: domainId}, {caches: clusterCaches}).exec())
+                        return domainsModel.updateOne({_id: domainId}, {caches: clusterCaches}).exec()
                             .then(() => linkDomainToCluster(clustersModel, {_id: cluster, name: `stub${idx}`}, domainsModel, domain));
                     }), Promise.resolve());
                 }
diff --git a/modules/web-console/backend/migrations/1547440382485-account-make-email-unique.js b/modules/web-console/backend/migrations/1547440382485-account-make-email-unique.js
index 9e7eb51..5897040 100644
--- a/modules/web-console/backend/migrations/1547440382485-account-make-email-unique.js
+++ b/modules/web-console/backend/migrations/1547440382485-account-make-email-unique.js
@@ -51,15 +51,15 @@ function deduplicateAccounts(model) {
                 .then((spaces) => _.map(spaces, '_id'))
                 .then((spaceIds) =>
                     Promise.all([
-                        model('Cluster').remove({space: {$in: spaceIds}}).exec(),
-                        model('Cache').remove({space: {$in: spaceIds}}).exec(),
-                        model('DomainModel').remove({space: {$in: spaceIds}}).exec(),
-                        model('Igfs').remove({space: {$in: spaceIds}}).exec(),
-                        model('Notebook').remove({space: {$in: spaceIds}}).exec(),
-                        model('Activities').remove({owner: accountIds}).exec(),
-                        model('Notifications').remove({owner: accountIds}).exec(),
-                        spaceModel.remove({owner: accountIds}).exec(),
-                        accountsModel.remove({_id: accountIds}).exec()
+                        model('Cluster').deleteMany({space: {$in: spaceIds}}).exec(),
+                        model('Cache').deleteMany({space: {$in: spaceIds}}).exec(),
+                        model('DomainModel').deleteMany({space: {$in: spaceIds}}).exec(),
+                        model('Igfs').deleteMany({space: {$in: spaceIds}}).exec(),
+                        model('Notebook').deleteMany({space: {$in: spaceIds}}).exec(),
+                        model('Activities').deleteMany({owner: accountIds}).exec(),
+                        model('Notifications').deleteMany({owner: accountIds}).exec(),
+                        spaceModel.deleteMany({owner: accountIds}).exec(),
+                        accountsModel.deleteMany({_id: accountIds}).exec()
                     ])
                 )
                 .then(() => {
diff --git a/modules/web-console/backend/migrations/migration-utils.js b/modules/web-console/backend/migrations/migration-utils.js
index 5219f81..8eab185 100644
--- a/modules/web-console/backend/migrations/migration-utils.js
+++ b/modules/web-console/backend/migrations/migration-utils.js
@@ -107,7 +107,7 @@ function getCacheForMigration(clustersModel, cachesModel, space) {
                     });
                 })
                 .then((cache) => {
-                    return clustersModel.update({_id: cache.clusters[0]}, {$addToSet: {caches: cache._id}}).exec()
+                    return clustersModel.updateOne({_id: cache.clusters[0]}, {$addToSet: {caches: cache._id}}).exec()
                         .then(() => cache);
                 });
         });
diff --git a/modules/web-console/backend/package-lock.json b/modules/web-console/backend/package-lock.json
new file mode 100644
index 0000000..28051fa
--- /dev/null
+++ b/modules/web-console/backend/package-lock.json
@@ -0,0 +1,8115 @@
+{
+  "name": "ignite-web-console",
+  "version": "8.7.0",
+  "lockfileVersion": 1,
+  "requires": true,
+  "dependencies": {
+    "@babel/code-frame": {
+      "version": "7.0.0",
+      "resolved": "https://registry.npmjs.org/@babel/code-frame/-/code-frame-7.0.0.tgz",
+      "integrity": "sha512-OfC2uemaknXr87bdLUkWog7nYuliM9Ij5HUcajsVcMCpQrcLmtxRbVFTIqmcSkSeYRBFBRxs2FiUqFJDLdiebA==",
+      "dev": true,
+      "requires": {
+        "@babel/highlight": "^7.0.0"
+      }
+    },
+    "@babel/highlight": {
+      "version": "7.0.0",
+      "resolved": "https://registry.npmjs.org/@babel/highlight/-/highlight-7.0.0.tgz",
+      "integrity": "sha512-UFMC4ZeFC48Tpvj7C8UgLvtkaUuovQX+5xNWrsIoMG8o2z+XFKjKaN9iVmS84dPwVN00W4wPmqvYoZF3EGAsfw==",
+      "dev": true,
+      "requires": {
+        "chalk": "^2.0.0",
+        "esutils": "^2.0.2",
+        "js-tokens": "^4.0.0"
+      },
+      "dependencies": {
+        "ansi-styles": {
+          "version": "3.2.1",
+          "resolved": "https://registry.npmjs.org/ansi-styles/-/ansi-styles-3.2.1.tgz",
+          "integrity": "sha512-VT0ZI6kZRdTh8YyJw3SMbYm/u+NqfsAxEpWO0Pf9sq8/e94WxxOpPKx9FR1FlyCtOVDNOQ+8ntlqFxiRc+r5qA==",
+          "dev": true,
+          "requires": {
+            "color-convert": "^1.9.0"
+          }
+        },
+        "chalk": {
+          "version": "2.4.2",
+          "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.4.2.tgz",
+          "integrity": "sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==",
+          "dev": true,
+          "requires": {
+            "ansi-styles": "^3.2.1",
+            "escape-string-regexp": "^1.0.5",
+            "supports-color": "^5.3.0"
+          }
+        },
+        "js-tokens": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/js-tokens/-/js-tokens-4.0.0.tgz",
+          "integrity": "sha512-RdJUflcE3cUzKiMqQgsCu06FPu9UdIJO0beYbPhHN4k6apgJtifcoCtT9bcxOpYBtpD2kCM6Sbzg4CausW/PKQ==",
+          "dev": true
+        },
+        "supports-color": {
+          "version": "5.5.0",
+          "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-5.5.0.tgz",
+          "integrity": "sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==",
+          "dev": true,
+          "requires": {
+            "has-flag": "^3.0.0"
+          }
+        }
+      }
+    },
+    "@babel/parser": {
+      "version": "7.2.3",
+      "resolved": "https://registry.npmjs.org/@babel/parser/-/parser-7.2.3.tgz",
+      "integrity": "sha512-0LyEcVlfCoFmci8mXx8A5oIkpkOgyo8dRHtxBnK9RRBwxO2+JZPNsqtVEZQ7mJFPxnXF9lfmU24mHOPI0qnlkA=="
+    },
+    "@mrmlnc/readdir-enhanced": {
+      "version": "2.2.1",
+      "resolved": "https://registry.npmjs.org/@mrmlnc/readdir-enhanced/-/readdir-enhanced-2.2.1.tgz",
+      "integrity": "sha512-bPHp6Ji8b41szTOcaP63VlnbbO5Ny6dwAATtY6JTjh5N2OLrb5Qk/Th5cRkRQhkWCt+EJsYrNB0MiL+Gpn6e3g==",
+      "requires": {
+        "call-me-maybe": "^1.0.1",
+        "glob-to-regexp": "^0.3.0"
+      }
+    },
+    "@nodelib/fs.stat": {
+      "version": "1.1.3",
+      "resolved": "https://registry.npmjs.org/@nodelib/fs.stat/-/fs.stat-1.1.3.tgz",
+      "integrity": "sha512-shAmDyaQC4H92APFoIaVDHCx5bStIocgvbwQyxPRrbUY20V1EYTbSDchWbuwlMG3V17cprZhA6+78JfB+3DTPw=="
+    },
+    "accepts": {
+      "version": "1.3.5",
+      "resolved": "https://registry.npmjs.org/accepts/-/accepts-1.3.5.tgz",
+      "integrity": "sha1-63d99gEXI6OxTopywIBcjoZ0a9I=",
+      "requires": {
+        "mime-types": "~2.1.18",
+        "negotiator": "0.6.1"
+      }
+    },
+    "acorn": {
+      "version": "6.1.1",
+      "resolved": "https://registry.npmjs.org/acorn/-/acorn-6.1.1.tgz",
+      "integrity": "sha512-jPTiwtOxaHNaAPg/dmrJ/beuzLRnXtB0kQPQ8JpotKJgTB6rX6c8mlf315941pyjBSaPg8NHXS9fhP4u17DpGA==",
+      "dev": true
+    },
+    "acorn-jsx": {
+      "version": "5.0.1",
+      "resolved": "https://registry.npmjs.org/acorn-jsx/-/acorn-jsx-5.0.1.tgz",
+      "integrity": "sha512-HJ7CfNHrfJLlNTzIEUTj43LNWGkqpRLxm3YjAlcD0ACydk9XynzYsCBHxut+iqt+1aBXkx9UP/w/ZqMr13XIzg==",
+      "dev": true
+    },
+    "after": {
+      "version": "0.8.2",
+      "resolved": "https://registry.npmjs.org/after/-/after-0.8.2.tgz",
+      "integrity": "sha1-/ts5T58OAqqXaOcCvaI7UF+ufh8="
+    },
+    "agent-base": {
+      "version": "4.2.1",
+      "resolved": "https://registry.npmjs.org/agent-base/-/agent-base-4.2.1.tgz",
+      "integrity": "sha512-JVwXMr9nHYTUXsBFKUqhJwvlcYU/blreOEUkhNR2eXZIvwd+c+o5V4MgDPKWnMS/56awN3TRzIP+KoPn+roQtg==",
+      "dev": true,
+      "requires": {
+        "es6-promisify": "^5.0.0"
+      }
+    },
+    "ajv": {
+      "version": "6.10.0",
+      "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.10.0.tgz",
+      "integrity": "sha512-nffhOpkymDECQyR0mnsUtoCE8RlX38G0rYP+wgLWFyZuUyuuojSSvi/+euOiQBIn63whYwYVIIH1TvE3tu4OEg==",
+      "requires": {
+        "fast-deep-equal": "^2.0.1",
+        "fast-json-stable-stringify": "^2.0.0",
+        "json-schema-traverse": "^0.4.1",
+        "uri-js": "^4.2.2"
+      }
+    },
+    "ansi-colors": {
+      "version": "3.2.3",
+      "resolved": "https://registry.npmjs.org/ansi-colors/-/ansi-colors-3.2.3.tgz",
+      "integrity": "sha512-LEHHyuhlPY3TmuUYMh2oz89lTShfvgbmzaBcxve9t/9Wuy7Dwf4yoAKcND7KFT1HAQfqZ12qtc+DUrBMeKF9nw==",
+      "dev": true
+    },
+    "ansi-escapes": {
+      "version": "1.4.0",
+      "resolved": "https://registry.npmjs.org/ansi-escapes/-/ansi-escapes-1.4.0.tgz",
+      "integrity": "sha1-06ioOzGapneTZisT52HHkRQiMG4="
+    },
+    "ansi-regex": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-2.1.1.tgz",
+      "integrity": "sha1-w7M6te42DYbg5ijwRorn7yfWVN8="
+    },
+    "ansi-styles": {
+      "version": "2.2.1",
+      "resolved": "https://registry.npmjs.org/ansi-styles/-/ansi-styles-2.2.1.tgz",
+      "integrity": "sha1-tDLdM1i2NM914eRmQ2gkBTPB3b4="
+    },
+    "anymatch": {
+      "version": "1.3.2",
+      "resolved": "https://registry.npmjs.org/anymatch/-/anymatch-1.3.2.tgz",
+      "integrity": "sha512-0XNayC8lTHQ2OI8aljNCN3sSx6hsr/1+rlcDAotXJR7C1oZZHCNsfpbKwMjRA3Uqb5tF1Rae2oloTr4xpq+WjA==",
+      "optional": true,
+      "requires": {
+        "micromatch": "^2.1.5",
+        "normalize-path": "^2.0.0"
+      }
+    },
+    "app-module-path": {
+      "version": "2.2.0",
+      "resolved": "https://registry.npmjs.org/app-module-path/-/app-module-path-2.2.0.tgz",
+      "integrity": "sha1-ZBqlXft9am8KgUHEucCqULbCTdU="
+    },
+    "archetype": {
+      "version": "0.8.8",
+      "resolved": "https://registry.npmjs.org/archetype/-/archetype-0.8.8.tgz",
+      "integrity": "sha512-isdIbFfT3zXVan34hmxIwI8A5/8lo9MaYmwXF1iYWCnJS1GvKKnZ4GrXoOUgKdUMCiB/wdguRXeStCUQhFjexg==",
+      "requires": {
+        "lodash.clonedeep": "4.x",
+        "lodash.set": "4.x",
+        "lodash.unset": "4.x",
+        "mpath": "0.5.1",
+        "standard-error": "1.1.0"
+      }
+    },
+    "argparse": {
+      "version": "1.0.10",
+      "resolved": "https://registry.npmjs.org/argparse/-/argparse-1.0.10.tgz",
+      "integrity": "sha512-o5Roy6tNG4SL/FOkCAN6RzjiakZS25RLYFrcMttJqbdd8BWrnA+fGz57iN5Pb06pvBGvl5gQ0B48dJlslXvoTg==",
+      "dev": true,
+      "requires": {
+        "sprintf-js": "~1.0.2"
+      }
+    },
+    "arr-diff": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/arr-diff/-/arr-diff-2.0.0.tgz",
+      "integrity": "sha1-jzuCf5Vai9ZpaX5KQlasPOrjVs8=",
+      "optional": true,
+      "requires": {
+        "arr-flatten": "^1.0.1"
+      }
+    },
+    "arr-flatten": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/arr-flatten/-/arr-flatten-1.1.0.tgz",
+      "integrity": "sha512-L3hKV5R/p5o81R7O02IGnwpDmkp6E982XhtbuwSe3O4qOtMMMtodicASA1Cny2U+aCXcNpml+m4dPsvsJ3jatg=="
+    },
+    "arr-union": {
+      "version": "3.1.0",
+      "resolved": "https://registry.npmjs.org/arr-union/-/arr-union-3.1.0.tgz",
+      "integrity": "sha1-45sJrqne+Gao8gbiiK9jkZuuOcQ="
+    },
+    "array-flatten": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/array-flatten/-/array-flatten-1.1.1.tgz",
+      "integrity": "sha1-ml9pkFGx5wczKPKgCJaLZOopVdI="
+    },
+    "array-union": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/array-union/-/array-union-1.0.2.tgz",
+      "integrity": "sha1-mjRBDk9OPaI96jdb5b5w8kd47Dk=",
+      "requires": {
+        "array-uniq": "^1.0.1"
+      }
+    },
+    "array-uniq": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/array-uniq/-/array-uniq-1.0.3.tgz",
+      "integrity": "sha1-r2rId6Jcx/dOBYiUdThY39sk/bY="
+    },
+    "array-unique": {
+      "version": "0.2.1",
+      "resolved": "https://registry.npmjs.org/array-unique/-/array-unique-0.2.1.tgz",
+      "integrity": "sha1-odl8yvy8JiXMcPrc6zalDFiwGlM=",
+      "optional": true
+    },
+    "arraybuffer.slice": {
+      "version": "0.0.7",
+      "resolved": "https://registry.npmjs.org/arraybuffer.slice/-/arraybuffer.slice-0.0.7.tgz",
+      "integrity": "sha512-wGUIVQXuehL5TCqQun8OW81jGzAWycqzFF8lFp+GOM5BXLYj3bKNsYC4daB7n6XjCqxQA/qgTJ+8ANR3acjrog=="
+    },
+    "arrify": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/arrify/-/arrify-1.0.1.tgz",
+      "integrity": "sha1-iYUI2iIm84DfkEcoRWhJwVAaSw0="
+    },
+    "asn1": {
+      "version": "0.2.4",
+      "resolved": "https://registry.npmjs.org/asn1/-/asn1-0.2.4.tgz",
+      "integrity": "sha512-jxwzQpLQjSmWXgwaCZE9Nz+glAG01yF1QnWgbhGwHI5A6FRIEY6IVqtHhIepHqI7/kyEyQEagBC5mBEFlIYvdg==",
+      "requires": {
+        "safer-buffer": "~2.1.0"
+      }
+    },
+    "assert-plus": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/assert-plus/-/assert-plus-1.0.0.tgz",
+      "integrity": "sha1-8S4PPF13sLHN2RRpQuTpbB5N1SU="
+    },
+    "assertion-error": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/assertion-error/-/assertion-error-1.1.0.tgz",
+      "integrity": "sha512-jgsaNduz+ndvGyFt3uSuWqvy4lCnIJiovtouQN5JZHOKCS2QuhEdbcQHFhVksz2N2U9hXJo8odG7ETyWlEeuDw==",
+      "dev": true
+    },
+    "assign-symbols": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/assign-symbols/-/assign-symbols-1.0.0.tgz",
+      "integrity": "sha1-WWZ/QfrdTyDMvCu5a41Pf3jsA2c="
+    },
+    "astral-regex": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/astral-regex/-/astral-regex-1.0.0.tgz",
+      "integrity": "sha512-+Ryf6g3BKoRc7jfp7ad8tM4TtMiaWvbF/1/sQcZPkkS7ag3D5nMBCe2UfOTONtAkaG0tO0ij3C5Lwmf1EiyjHg==",
+      "dev": true
+    },
+    "async": {
+      "version": "2.6.1",
+      "resolved": "https://registry.npmjs.org/async/-/async-2.6.1.tgz",
+      "integrity": "sha512-fNEiL2+AZt6AlAw/29Cr0UDe4sRAHCpEHh54WMz+Bb7QfNcFw4h3loofyJpLeQs4Yx7yuqu/2dLgM5hKOs6HlQ==",
+      "requires": {
+        "lodash": "^4.17.10"
+      }
+    },
+    "async-each": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/async-each/-/async-each-1.0.3.tgz",
+      "integrity": "sha512-z/WhQ5FPySLdvREByI2vZiTWwCnF0moMJ1hK9YQwDTHKh6I7/uSckMetoRGb5UBZPC1z0jlw+n/XCgjeH7y1AQ==",
+      "optional": true
+    },
+    "async-limiter": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/async-limiter/-/async-limiter-1.0.0.tgz",
+      "integrity": "sha512-jp/uFnooOiO+L211eZOoSyzpOITMXx1rBITauYykG3BRYPu8h0UcxsPNB04RR5vo4Tyz3+ay17tR6JVf9qzYWg=="
+    },
+    "asynckit": {
+      "version": "0.4.0",
+      "resolved": "https://registry.npmjs.org/asynckit/-/asynckit-0.4.0.tgz",
+      "integrity": "sha1-x57Zf380y48robyXkLzDZkdLS3k="
+    },
+    "atob": {
+      "version": "2.1.2",
+      "resolved": "https://registry.npmjs.org/atob/-/atob-2.1.2.tgz",
+      "integrity": "sha512-Wm6ukoaOGJi/73p/cl2GvLjTI5JM1k/O14isD73YML8StrH/7/lRFgmg8nICZgD3bZZvjwCGxtMOD3wWNAu8cg=="
+    },
+    "aws-sign2": {
+      "version": "0.7.0",
+      "resolved": "https://registry.npmjs.org/aws-sign2/-/aws-sign2-0.7.0.tgz",
+      "integrity": "sha1-tG6JCTSpWR8tL2+G1+ap8bP+dqg="
+    },
+    "aws4": {
+      "version": "1.8.0",
+      "resolved": "https://registry.npmjs.org/aws4/-/aws4-1.8.0.tgz",
+      "integrity": "sha512-ReZxvNHIOv88FlT7rxcXIIC0fPt4KZqZbOlivyWtXLt8ESx84zd3kMC6iK5jVeS2qt+g7ftS7ye4fi06X5rtRQ=="
+    },
+    "babel-cli": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-cli/-/babel-cli-6.26.0.tgz",
+      "integrity": "sha1-UCq1SHTX24itALiHoGODzgPQAvE=",
+      "requires": {
+        "babel-core": "^6.26.0",
+        "babel-polyfill": "^6.26.0",
+        "babel-register": "^6.26.0",
+        "babel-runtime": "^6.26.0",
+        "chokidar": "^1.6.1",
+        "commander": "^2.11.0",
+        "convert-source-map": "^1.5.0",
+        "fs-readdir-recursive": "^1.0.0",
+        "glob": "^7.1.2",
+        "lodash": "^4.17.4",
+        "output-file-sync": "^1.1.2",
+        "path-is-absolute": "^1.0.1",
+        "slash": "^1.0.0",
+        "source-map": "^0.5.6",
+        "v8flags": "^2.1.1"
+      }
+    },
+    "babel-code-frame": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-code-frame/-/babel-code-frame-6.26.0.tgz",
+      "integrity": "sha1-Y/1D99weO7fONZR9uP42mj9Yx0s=",
+      "requires": {
+        "chalk": "^1.1.3",
+        "esutils": "^2.0.2",
+        "js-tokens": "^3.0.2"
+      }
+    },
+    "babel-core": {
+      "version": "6.26.3",
+      "resolved": "https://registry.npmjs.org/babel-core/-/babel-core-6.26.3.tgz",
+      "integrity": "sha512-6jyFLuDmeidKmUEb3NM+/yawG0M2bDZ9Z1qbZP59cyHLz8kYGKYwpJP0UwUKKUiTRNvxfLesJnTedqczP7cTDA==",
+      "requires": {
+        "babel-code-frame": "^6.26.0",
+        "babel-generator": "^6.26.0",
+        "babel-helpers": "^6.24.1",
+        "babel-messages": "^6.23.0",
+        "babel-register": "^6.26.0",
+        "babel-runtime": "^6.26.0",
+        "babel-template": "^6.26.0",
+        "babel-traverse": "^6.26.0",
+        "babel-types": "^6.26.0",
+        "babylon": "^6.18.0",
+        "convert-source-map": "^1.5.1",
+        "debug": "^2.6.9",
+        "json5": "^0.5.1",
+        "lodash": "^4.17.4",
+        "minimatch": "^3.0.4",
+        "path-is-absolute": "^1.0.1",
+        "private": "^0.1.8",
+        "slash": "^1.0.0",
+        "source-map": "^0.5.7"
+      },
+      "dependencies": {
+        "minimatch": {
+          "version": "3.0.4",
+          "resolved": "https://registry.npmjs.org/minimatch/-/minimatch-3.0.4.tgz",
+          "integrity": "sha512-yJHVQEhyqPLUTgt9B83PXu6W3rx4MvvHvSUvToogpwoGDOUQ+yDrR0HRot+yOCdCO7u4hX3pWft6kWBBcqh0UA==",
+          "requires": {
+            "brace-expansion": "^1.1.7"
+          }
+        }
+      }
+    },
+    "babel-generator": {
+      "version": "6.26.1",
+      "resolved": "https://registry.npmjs.org/babel-generator/-/babel-generator-6.26.1.tgz",
+      "integrity": "sha512-HyfwY6ApZj7BYTcJURpM5tznulaBvyio7/0d4zFOeMPUmfxkCjHocCuoLa2SAGzBI8AREcH3eP3758F672DppA==",
+      "requires": {
+        "babel-messages": "^6.23.0",
+        "babel-runtime": "^6.26.0",
+        "babel-types": "^6.26.0",
+        "detect-indent": "^4.0.0",
+        "jsesc": "^1.3.0",
+        "lodash": "^4.17.4",
+        "source-map": "^0.5.7",
+        "trim-right": "^1.0.1"
+      }
+    },
+    "babel-helper-builder-binary-assignment-operator-visitor": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-helper-builder-binary-assignment-operator-visitor/-/babel-helper-builder-binary-assignment-operator-visitor-6.24.1.tgz",
+      "integrity": "sha1-zORReto1b0IgvK6KAsKzRvmlZmQ=",
+      "requires": {
+        "babel-helper-explode-assignable-expression": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-helper-call-delegate": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-helper-call-delegate/-/babel-helper-call-delegate-6.24.1.tgz",
+      "integrity": "sha1-7Oaqzdx25Bw0YfiL/Fdb0Nqi340=",
+      "requires": {
+        "babel-helper-hoist-variables": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "babel-traverse": "^6.24.1",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-helper-define-map": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-helper-define-map/-/babel-helper-define-map-6.26.0.tgz",
+      "integrity": "sha1-pfVtq0GiX5fstJjH66ypgZ+Vvl8=",
+      "requires": {
+        "babel-helper-function-name": "^6.24.1",
+        "babel-runtime": "^6.26.0",
+        "babel-types": "^6.26.0",
+        "lodash": "^4.17.4"
+      }
+    },
+    "babel-helper-explode-assignable-expression": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-helper-explode-assignable-expression/-/babel-helper-explode-assignable-expression-6.24.1.tgz",
+      "integrity": "sha1-8luCz33BBDPFX3BZLVdGQArCLKo=",
+      "requires": {
+        "babel-runtime": "^6.22.0",
+        "babel-traverse": "^6.24.1",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-helper-function-name": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-helper-function-name/-/babel-helper-function-name-6.24.1.tgz",
+      "integrity": "sha1-00dbjAPtmCQqJbSDUasYOZ01gKk=",
+      "requires": {
+        "babel-helper-get-function-arity": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "babel-template": "^6.24.1",
+        "babel-traverse": "^6.24.1",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-helper-get-function-arity": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-helper-get-function-arity/-/babel-helper-get-function-arity-6.24.1.tgz",
+      "integrity": "sha1-j3eCqpNAfEHTqlCQj4mwMbG2hT0=",
+      "requires": {
+        "babel-runtime": "^6.22.0",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-helper-hoist-variables": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-helper-hoist-variables/-/babel-helper-hoist-variables-6.24.1.tgz",
+      "integrity": "sha1-HssnaJydJVE+rbyZFKc/VAi+enY=",
+      "requires": {
+        "babel-runtime": "^6.22.0",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-helper-optimise-call-expression": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-helper-optimise-call-expression/-/babel-helper-optimise-call-expression-6.24.1.tgz",
+      "integrity": "sha1-96E0J7qfc/j0+pk8VKl4gtEkQlc=",
+      "requires": {
+        "babel-runtime": "^6.22.0",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-helper-regex": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-helper-regex/-/babel-helper-regex-6.26.0.tgz",
+      "integrity": "sha1-MlxZ+QL4LyS3T6zu0DY5VPZJXnI=",
+      "requires": {
+        "babel-runtime": "^6.26.0",
+        "babel-types": "^6.26.0",
+        "lodash": "^4.17.4"
+      }
+    },
+    "babel-helper-remap-async-to-generator": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-helper-remap-async-to-generator/-/babel-helper-remap-async-to-generator-6.24.1.tgz",
+      "integrity": "sha1-XsWBgnrXI/7N04HxySg5BnbkVRs=",
+      "requires": {
+        "babel-helper-function-name": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "babel-template": "^6.24.1",
+        "babel-traverse": "^6.24.1",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-helper-replace-supers": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-helper-replace-supers/-/babel-helper-replace-supers-6.24.1.tgz",
+      "integrity": "sha1-v22/5Dk40XNpohPKiov3S2qQqxo=",
+      "requires": {
+        "babel-helper-optimise-call-expression": "^6.24.1",
+        "babel-messages": "^6.23.0",
+        "babel-runtime": "^6.22.0",
+        "babel-template": "^6.24.1",
+        "babel-traverse": "^6.24.1",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-helpers": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-helpers/-/babel-helpers-6.24.1.tgz",
+      "integrity": "sha1-NHHenK7DiOXIUOWX5Yom3fN2ArI=",
+      "requires": {
+        "babel-runtime": "^6.22.0",
+        "babel-template": "^6.24.1"
+      }
+    },
+    "babel-messages": {
+      "version": "6.23.0",
+      "resolved": "https://registry.npmjs.org/babel-messages/-/babel-messages-6.23.0.tgz",
+      "integrity": "sha1-8830cDhYA1sqKVHG7F7fbGLyYw4=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-check-es2015-constants": {
+      "version": "6.22.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-check-es2015-constants/-/babel-plugin-check-es2015-constants-6.22.0.tgz",
+      "integrity": "sha1-NRV7EBQm/S/9PaP3XH0ekYNbv4o=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-syntax-async-functions": {
+      "version": "6.13.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-syntax-async-functions/-/babel-plugin-syntax-async-functions-6.13.0.tgz",
+      "integrity": "sha1-ytnK0RkbWtY0vzCuCHI5HgZHvpU="
+    },
+    "babel-plugin-syntax-exponentiation-operator": {
+      "version": "6.13.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-syntax-exponentiation-operator/-/babel-plugin-syntax-exponentiation-operator-6.13.0.tgz",
+      "integrity": "sha1-nufoM3KQ2pUoggGmpX9BcDF4MN4="
+    },
+    "babel-plugin-syntax-trailing-function-commas": {
+      "version": "6.22.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-syntax-trailing-function-commas/-/babel-plugin-syntax-trailing-function-commas-6.22.0.tgz",
+      "integrity": "sha1-ugNgk3+NBuQBgKQ/4NVhb/9TLPM="
+    },
+    "babel-plugin-transform-async-to-generator": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-async-to-generator/-/babel-plugin-transform-async-to-generator-6.24.1.tgz",
+      "integrity": "sha1-ZTbjeK/2yx1VF6wOQOs+n8jQh2E=",
+      "requires": {
+        "babel-helper-remap-async-to-generator": "^6.24.1",
+        "babel-plugin-syntax-async-functions": "^6.8.0",
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-es2015-arrow-functions": {
+      "version": "6.22.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-arrow-functions/-/babel-plugin-transform-es2015-arrow-functions-6.22.0.tgz",
+      "integrity": "sha1-RSaSy3EdX3ncf4XkQM5BufJE0iE=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-es2015-block-scoped-functions": {
+      "version": "6.22.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-block-scoped-functions/-/babel-plugin-transform-es2015-block-scoped-functions-6.22.0.tgz",
+      "integrity": "sha1-u8UbSflk1wy42OC5ToICRs46YUE=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-es2015-block-scoping": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-block-scoping/-/babel-plugin-transform-es2015-block-scoping-6.26.0.tgz",
+      "integrity": "sha1-1w9SmcEwjQXBL0Y4E7CgnnOxiV8=",
+      "requires": {
+        "babel-runtime": "^6.26.0",
+        "babel-template": "^6.26.0",
+        "babel-traverse": "^6.26.0",
+        "babel-types": "^6.26.0",
+        "lodash": "^4.17.4"
+      }
+    },
+    "babel-plugin-transform-es2015-classes": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-classes/-/babel-plugin-transform-es2015-classes-6.24.1.tgz",
+      "integrity": "sha1-WkxYpQyclGHlZLSyo7+ryXolhNs=",
+      "requires": {
+        "babel-helper-define-map": "^6.24.1",
+        "babel-helper-function-name": "^6.24.1",
+        "babel-helper-optimise-call-expression": "^6.24.1",
+        "babel-helper-replace-supers": "^6.24.1",
+        "babel-messages": "^6.23.0",
+        "babel-runtime": "^6.22.0",
+        "babel-template": "^6.24.1",
+        "babel-traverse": "^6.24.1",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-plugin-transform-es2015-computed-properties": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-computed-properties/-/babel-plugin-transform-es2015-computed-properties-6.24.1.tgz",
+      "integrity": "sha1-b+Ko0WiV1WNPTNmZttNICjCBWbM=",
+      "requires": {
+        "babel-runtime": "^6.22.0",
+        "babel-template": "^6.24.1"
+      }
+    },
+    "babel-plugin-transform-es2015-destructuring": {
+      "version": "6.23.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-destructuring/-/babel-plugin-transform-es2015-destructuring-6.23.0.tgz",
+      "integrity": "sha1-mXux8auWf2gtKwh2/jWNYOdlxW0=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-es2015-duplicate-keys": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-duplicate-keys/-/babel-plugin-transform-es2015-duplicate-keys-6.24.1.tgz",
+      "integrity": "sha1-c+s9MQypaePvnskcU3QabxV2Qj4=",
+      "requires": {
+        "babel-runtime": "^6.22.0",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-plugin-transform-es2015-for-of": {
+      "version": "6.23.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-for-of/-/babel-plugin-transform-es2015-for-of-6.23.0.tgz",
+      "integrity": "sha1-9HyVsrYT3x0+zC/bdXNiPHUkhpE=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-es2015-function-name": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-function-name/-/babel-plugin-transform-es2015-function-name-6.24.1.tgz",
+      "integrity": "sha1-g0yJhTvDaxrw86TF26qU/Y6sqos=",
+      "requires": {
+        "babel-helper-function-name": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-plugin-transform-es2015-literals": {
+      "version": "6.22.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-literals/-/babel-plugin-transform-es2015-literals-6.22.0.tgz",
+      "integrity": "sha1-T1SgLWzWbPkVKAAZox0xklN3yi4=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-es2015-modules-amd": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-modules-amd/-/babel-plugin-transform-es2015-modules-amd-6.24.1.tgz",
+      "integrity": "sha1-Oz5UAXI5hC1tGcMBHEvS8AoA0VQ=",
+      "requires": {
+        "babel-plugin-transform-es2015-modules-commonjs": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "babel-template": "^6.24.1"
+      }
+    },
+    "babel-plugin-transform-es2015-modules-commonjs": {
+      "version": "6.26.2",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-modules-commonjs/-/babel-plugin-transform-es2015-modules-commonjs-6.26.2.tgz",
+      "integrity": "sha512-CV9ROOHEdrjcwhIaJNBGMBCodN+1cfkwtM1SbUHmvyy35KGT7fohbpOxkE2uLz1o6odKK2Ck/tz47z+VqQfi9Q==",
+      "requires": {
+        "babel-plugin-transform-strict-mode": "^6.24.1",
+        "babel-runtime": "^6.26.0",
+        "babel-template": "^6.26.0",
+        "babel-types": "^6.26.0"
+      }
+    },
+    "babel-plugin-transform-es2015-modules-systemjs": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-modules-systemjs/-/babel-plugin-transform-es2015-modules-systemjs-6.24.1.tgz",
+      "integrity": "sha1-/4mhQrkRmpBhlfXxBuzzBdlAfSM=",
+      "requires": {
+        "babel-helper-hoist-variables": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "babel-template": "^6.24.1"
+      }
+    },
+    "babel-plugin-transform-es2015-modules-umd": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-modules-umd/-/babel-plugin-transform-es2015-modules-umd-6.24.1.tgz",
+      "integrity": "sha1-rJl+YoXNGO1hdq22B9YCNErThGg=",
+      "requires": {
+        "babel-plugin-transform-es2015-modules-amd": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "babel-template": "^6.24.1"
+      }
+    },
+    "babel-plugin-transform-es2015-object-super": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-object-super/-/babel-plugin-transform-es2015-object-super-6.24.1.tgz",
+      "integrity": "sha1-JM72muIcuDp/hgPa0CH1cusnj40=",
+      "requires": {
+        "babel-helper-replace-supers": "^6.24.1",
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-es2015-parameters": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-parameters/-/babel-plugin-transform-es2015-parameters-6.24.1.tgz",
+      "integrity": "sha1-V6w1GrScrxSpfNE7CfZv3wpiXys=",
+      "requires": {
+        "babel-helper-call-delegate": "^6.24.1",
+        "babel-helper-get-function-arity": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "babel-template": "^6.24.1",
+        "babel-traverse": "^6.24.1",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-plugin-transform-es2015-shorthand-properties": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-shorthand-properties/-/babel-plugin-transform-es2015-shorthand-properties-6.24.1.tgz",
+      "integrity": "sha1-JPh11nIch2YbvZmkYi5R8U3jiqA=",
+      "requires": {
+        "babel-runtime": "^6.22.0",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-plugin-transform-es2015-spread": {
+      "version": "6.22.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-spread/-/babel-plugin-transform-es2015-spread-6.22.0.tgz",
+      "integrity": "sha1-1taKmfia7cRTbIGlQujdnxdG+NE=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-es2015-sticky-regex": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-sticky-regex/-/babel-plugin-transform-es2015-sticky-regex-6.24.1.tgz",
+      "integrity": "sha1-AMHNsaynERLN8M9hJsLta0V8zbw=",
+      "requires": {
+        "babel-helper-regex": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-plugin-transform-es2015-template-literals": {
+      "version": "6.22.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-template-literals/-/babel-plugin-transform-es2015-template-literals-6.22.0.tgz",
+      "integrity": "sha1-qEs0UPfp+PH2g51taH2oS7EjbY0=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-es2015-typeof-symbol": {
+      "version": "6.23.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-typeof-symbol/-/babel-plugin-transform-es2015-typeof-symbol-6.23.0.tgz",
+      "integrity": "sha1-3sCfHN3/lLUqxz1QXITfWdzOs3I=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-es2015-unicode-regex": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-es2015-unicode-regex/-/babel-plugin-transform-es2015-unicode-regex-6.24.1.tgz",
+      "integrity": "sha1-04sS9C6nMj9yk4fxinxa4frrNek=",
+      "requires": {
+        "babel-helper-regex": "^6.24.1",
+        "babel-runtime": "^6.22.0",
+        "regexpu-core": "^2.0.0"
+      }
+    },
+    "babel-plugin-transform-exponentiation-operator": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-exponentiation-operator/-/babel-plugin-transform-exponentiation-operator-6.24.1.tgz",
+      "integrity": "sha1-KrDJx/MJj6SJB3cruBP+QejeOg4=",
+      "requires": {
+        "babel-helper-builder-binary-assignment-operator-visitor": "^6.24.1",
+        "babel-plugin-syntax-exponentiation-operator": "^6.8.0",
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-regenerator": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-regenerator/-/babel-plugin-transform-regenerator-6.26.0.tgz",
+      "integrity": "sha1-4HA2lvveJ/Cj78rPi03KL3s6jy8=",
+      "requires": {
+        "regenerator-transform": "^0.10.0"
+      }
+    },
+    "babel-plugin-transform-runtime": {
+      "version": "6.23.0",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-runtime/-/babel-plugin-transform-runtime-6.23.0.tgz",
+      "integrity": "sha1-iEkNRGUC6puOfvsP4J7E2ZR5se4=",
+      "requires": {
+        "babel-runtime": "^6.22.0"
+      }
+    },
+    "babel-plugin-transform-strict-mode": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-plugin-transform-strict-mode/-/babel-plugin-transform-strict-mode-6.24.1.tgz",
+      "integrity": "sha1-1fr3qleKZbvlkc9e2uBKDGcCB1g=",
+      "requires": {
+        "babel-runtime": "^6.22.0",
+        "babel-types": "^6.24.1"
+      }
+    },
+    "babel-polyfill": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-polyfill/-/babel-polyfill-6.26.0.tgz",
+      "integrity": "sha1-N5k3q8Z9eJWXCtxiHyhM2WbPIVM=",
+      "requires": {
+        "babel-runtime": "^6.26.0",
+        "core-js": "^2.5.0",
+        "regenerator-runtime": "^0.10.5"
+      },
+      "dependencies": {
+        "regenerator-runtime": {
+          "version": "0.10.5",
+          "resolved": "https://registry.npmjs.org/regenerator-runtime/-/regenerator-runtime-0.10.5.tgz",
+          "integrity": "sha1-M2w+/BIgrc7dosn6tntaeVWjNlg="
+        }
+      }
+    },
+    "babel-preset-es2015": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-preset-es2015/-/babel-preset-es2015-6.24.1.tgz",
+      "integrity": "sha1-1EBQ1rwsn+6nAqrzjXJ6AhBTiTk=",
+      "requires": {
+        "babel-plugin-check-es2015-constants": "^6.22.0",
+        "babel-plugin-transform-es2015-arrow-functions": "^6.22.0",
+        "babel-plugin-transform-es2015-block-scoped-functions": "^6.22.0",
+        "babel-plugin-transform-es2015-block-scoping": "^6.24.1",
+        "babel-plugin-transform-es2015-classes": "^6.24.1",
+        "babel-plugin-transform-es2015-computed-properties": "^6.24.1",
+        "babel-plugin-transform-es2015-destructuring": "^6.22.0",
+        "babel-plugin-transform-es2015-duplicate-keys": "^6.24.1",
+        "babel-plugin-transform-es2015-for-of": "^6.22.0",
+        "babel-plugin-transform-es2015-function-name": "^6.24.1",
+        "babel-plugin-transform-es2015-literals": "^6.22.0",
+        "babel-plugin-transform-es2015-modules-amd": "^6.24.1",
+        "babel-plugin-transform-es2015-modules-commonjs": "^6.24.1",
+        "babel-plugin-transform-es2015-modules-systemjs": "^6.24.1",
+        "babel-plugin-transform-es2015-modules-umd": "^6.24.1",
+        "babel-plugin-transform-es2015-object-super": "^6.24.1",
+        "babel-plugin-transform-es2015-parameters": "^6.24.1",
+        "babel-plugin-transform-es2015-shorthand-properties": "^6.24.1",
+        "babel-plugin-transform-es2015-spread": "^6.22.0",
+        "babel-plugin-transform-es2015-sticky-regex": "^6.24.1",
+        "babel-plugin-transform-es2015-template-literals": "^6.22.0",
+        "babel-plugin-transform-es2015-typeof-symbol": "^6.22.0",
+        "babel-plugin-transform-es2015-unicode-regex": "^6.24.1",
+        "babel-plugin-transform-regenerator": "^6.24.1"
+      }
+    },
+    "babel-preset-es2016": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-preset-es2016/-/babel-preset-es2016-6.24.1.tgz",
+      "integrity": "sha1-+QC/k+LrwNJ235uKtZck6/2Vn4s=",
+      "requires": {
+        "babel-plugin-transform-exponentiation-operator": "^6.24.1"
+      }
+    },
+    "babel-preset-es2017": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-preset-es2017/-/babel-preset-es2017-6.24.1.tgz",
+      "integrity": "sha1-WXvq37n38gi8/YoS6bKym4svFNE=",
+      "requires": {
+        "babel-plugin-syntax-trailing-function-commas": "^6.22.0",
+        "babel-plugin-transform-async-to-generator": "^6.24.1"
+      }
+    },
+    "babel-preset-latest": {
+      "version": "6.24.1",
+      "resolved": "https://registry.npmjs.org/babel-preset-latest/-/babel-preset-latest-6.24.1.tgz",
+      "integrity": "sha1-Z33gaRVKdIXC0lxXfAL2JLhbheg=",
+      "requires": {
+        "babel-preset-es2015": "^6.24.1",
+        "babel-preset-es2016": "^6.24.1",
+        "babel-preset-es2017": "^6.24.1"
+      }
+    },
+    "babel-register": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-register/-/babel-register-6.26.0.tgz",
+      "integrity": "sha1-btAhFz4vy0htestFxgCahW9kcHE=",
+      "requires": {
+        "babel-core": "^6.26.0",
+        "babel-runtime": "^6.26.0",
+        "core-js": "^2.5.0",
+        "home-or-tmp": "^2.0.0",
+        "lodash": "^4.17.4",
+        "mkdirp": "^0.5.1",
+        "source-map-support": "^0.4.15"
+      }
+    },
+    "babel-runtime": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-runtime/-/babel-runtime-6.26.0.tgz",
+      "integrity": "sha1-llxwWGaOgrVde/4E/yM3vItWR/4=",
+      "requires": {
+        "core-js": "^2.4.0",
+        "regenerator-runtime": "^0.11.0"
+      }
+    },
+    "babel-template": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-template/-/babel-template-6.26.0.tgz",
+      "integrity": "sha1-3gPi0WOWsGn0bdn/+FIfsaDjXgI=",
+      "requires": {
+        "babel-runtime": "^6.26.0",
+        "babel-traverse": "^6.26.0",
+        "babel-types": "^6.26.0",
+        "babylon": "^6.18.0",
+        "lodash": "^4.17.4"
+      }
+    },
+    "babel-traverse": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-traverse/-/babel-traverse-6.26.0.tgz",
+      "integrity": "sha1-RqnL1+3MYsjlwGTi0tjQ9ANXZu4=",
+      "requires": {
+        "babel-code-frame": "^6.26.0",
+        "babel-messages": "^6.23.0",
+        "babel-runtime": "^6.26.0",
+        "babel-types": "^6.26.0",
+        "babylon": "^6.18.0",
+        "debug": "^2.6.8",
+        "globals": "^9.18.0",
+        "invariant": "^2.2.2",
+        "lodash": "^4.17.4"
+      }
+    },
+    "babel-types": {
+      "version": "6.26.0",
+      "resolved": "https://registry.npmjs.org/babel-types/-/babel-types-6.26.0.tgz",
+      "integrity": "sha1-o7Bz+Uq0nrb6Vc1lInozQ4BjJJc=",
+      "requires": {
+        "babel-runtime": "^6.26.0",
+        "esutils": "^2.0.2",
+        "lodash": "^4.17.4",
+        "to-fast-properties": "^1.0.3"
+      }
+    },
+    "babylon": {
+      "version": "6.18.0",
+      "resolved": "https://registry.npmjs.org/babylon/-/babylon-6.18.0.tgz",
+      "integrity": "sha512-q/UEjfGJ2Cm3oKV71DJz9d25TPnq5rhBVL2Q4fA5wcC3jcrdn7+SssEybFIxwAvvP+YCsCYNKughoF33GxgycQ=="
+    },
+    "backo2": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/backo2/-/backo2-1.0.2.tgz",
+      "integrity": "sha1-MasayLEpNjRj41s+u2n038+6eUc="
+    },
+    "balanced-match": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/balanced-match/-/balanced-match-1.0.0.tgz",
+      "integrity": "sha1-ibTRmasr7kneFk6gK4nORi1xt2c="
+    },
+    "base": {
+      "version": "0.11.2",
+      "resolved": "https://registry.npmjs.org/base/-/base-0.11.2.tgz",
+      "integrity": "sha512-5T6P4xPgpp0YDFvSWwEZ4NoE3aM4QBQXDzmVbraCkFj8zHM+mba8SyqB5DbZWyR7mYHo6Y7BdQo3MoA4m0TeQg==",
+      "requires": {
+        "cache-base": "^1.0.1",
+        "class-utils": "^0.3.5",
+        "component-emitter": "^1.2.1",
+        "define-property": "^1.0.0",
+        "isobject": "^3.0.1",
+        "mixin-deep": "^1.2.0",
+        "pascalcase": "^0.1.1"
+      },
+      "dependencies": {
+        "define-property": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/define-property/-/define-property-1.0.0.tgz",
+          "integrity": "sha1-dp66rz9KY6rTr56NMEybvnm/sOY=",
+          "requires": {
+            "is-descriptor": "^1.0.0"
+          }
+        },
+        "is-accessor-descriptor": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-accessor-descriptor/-/is-accessor-descriptor-1.0.0.tgz",
+          "integrity": "sha512-m5hnHTkcVsPfqx3AKlyttIPb7J+XykHvJP2B9bZDjlhLIoEq4XoK64Vg7boZlVWYK6LUY94dYPEE7Lh0ZkZKcQ==",
+          "requires": {
+            "kind-of": "^6.0.0"
+          }
+        },
+        "is-data-descriptor": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-data-descriptor/-/is-data-descriptor-1.0.0.tgz",
+          "integrity": "sha512-jbRXy1FmtAoCjQkVmIVYwuuqDFUbaOeDjmed1tOGPrsMhtJA4rD9tkgA0F1qJ3gRFRXcHYVkdeaP50Q5rE/jLQ==",
+          "requires": {
+            "kind-of": "^6.0.0"
+          }
+        },
+        "is-descriptor": {
+          "version": "1.0.2",
+          "resolved": "https://registry.npmjs.org/is-descriptor/-/is-descriptor-1.0.2.tgz",
+          "integrity": "sha512-2eis5WqQGV7peooDyLmNEPUrps9+SXX5c9pL3xEB+4e9HnGuDa7mB7kHxHw4CbqS9k1T2hOH3miL8n8WtiYVtg==",
+          "requires": {
+            "is-accessor-descriptor": "^1.0.0",
+            "is-data-descriptor": "^1.0.0",
+            "kind-of": "^6.0.2"
+          }
+        },
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        },
+        "kind-of": {
+          "version": "6.0.2",
+          "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-6.0.2.tgz",
+          "integrity": "sha512-s5kLOcnH0XqDO+FvuaLX8DDjZ18CGFk7VygH40QoKPUQhW4e2rvM0rwUq0t8IQDOwYSeLK01U90OjzBTme2QqA=="
+        }
+      }
+    },
+    "base64-arraybuffer": {
+      "version": "0.1.5",
+      "resolved": "https://registry.npmjs.org/base64-arraybuffer/-/base64-arraybuffer-0.1.5.tgz",
+      "integrity": "sha1-c5JncZI7Whl0etZmqlzUv5xunOg="
+    },
+    "base64-js": {
+      "version": "1.3.0",
+      "resolved": "https://registry.npmjs.org/base64-js/-/base64-js-1.3.0.tgz",
+      "integrity": "sha512-ccav/yGvoa80BQDljCxsmmQ3Xvx60/UpBIij5QN21W3wBi/hhIC9OoO+KLpu9IJTS9j4DRVJ3aDDF9cMSoa2lw=="
+    },
+    "base64id": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/base64id/-/base64id-1.0.0.tgz",
+      "integrity": "sha1-R2iMuZu2gE8OBtPnY7HDLlfY5rY="
+    },
+    "basic-auth": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/basic-auth/-/basic-auth-2.0.1.tgz",
+      "integrity": "sha512-NF+epuEdnUYVlGuhaxbbq+dvJttwLnGY+YixlXlME5KpQ5W3CnXA5cVTneY3SPbPDRkcjMbifrwmFYcClgOZeg==",
+      "requires": {
+        "safe-buffer": "5.1.2"
+      }
+    },
+    "bcrypt-pbkdf": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/bcrypt-pbkdf/-/bcrypt-pbkdf-1.0.2.tgz",
+      "integrity": "sha1-pDAdOJtqQ/m2f/PKEaP2Y342Dp4=",
+      "requires": {
+        "tweetnacl": "^0.14.3"
+      }
+    },
+    "better-assert": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/better-assert/-/better-assert-1.0.2.tgz",
+      "integrity": "sha1-QIZrnhueC1W0gYlDEeaPr/rrxSI=",
+      "requires": {
+        "callsite": "1.0.0"
+      }
+    },
+    "binary-extensions": {
+      "version": "1.13.1",
+      "resolved": "https://registry.npmjs.org/binary-extensions/-/binary-extensions-1.13.1.tgz",
+      "integrity": "sha512-Un7MIEDdUC5gNpcGDV97op1Ywk748MpHcFTHoYs6qnj1Z3j7I53VG3nwZhKzoBZmbdRNnb6WRdFlwl7tSDuZGw==",
+      "optional": true
+    },
+    "bl": {
+      "version": "1.2.2",
+      "resolved": "https://registry.npmjs.org/bl/-/bl-1.2.2.tgz",
+      "integrity": "sha512-e8tQYnZodmebYDWGH7KMRvtzKXaJHx3BbilrgZCfvyLUYdKpK1t5PSPmpkny/SgiTSCnjfLW7v5rlONXVFkQEA==",
+      "requires": {
+        "readable-stream": "^2.3.5",
+        "safe-buffer": "^5.1.1"
+      }
+    },
+    "blob": {
+      "version": "0.0.5",
+      "resolved": "https://registry.npmjs.org/blob/-/blob-0.0.5.tgz",
+      "integrity": "sha512-gaqbzQPqOoamawKg0LGVd7SzLgXS+JH61oWprSLH+P+abTczqJbhTR8CmJ2u9/bUYNmHTGJx/UEmn6doAvvuig=="
+    },
+    "bluebird": {
+      "version": "3.5.4",
+      "resolved": "https://registry.npmjs.org/bluebird/-/bluebird-3.5.4.tgz",
+      "integrity": "sha512-FG+nFEZChJrbQ9tIccIfZJBz3J7mLrAhxakAbnrJWn8d7aKOC+LWifa0G+p4ZqKp4y13T7juYvdhq9NzKdsrjw=="
+    },
+    "body-parser": {
+      "version": "1.19.0",
+      "resolved": "https://registry.npmjs.org/body-parser/-/body-parser-1.19.0.tgz",
+      "integrity": "sha512-dhEPs72UPbDnAQJ9ZKMNTP6ptJaionhP5cBb541nXPlW60Jepo9RV/a4fX4XWW9CuFNK22krhrj1+rgzifNCsw==",
+      "requires": {
+        "bytes": "3.1.0",
+        "content-type": "~1.0.4",
+        "debug": "2.6.9",
+        "depd": "~1.1.2",
+        "http-errors": "1.7.2",
+        "iconv-lite": "0.4.24",
+        "on-finished": "~2.3.0",
+        "qs": "6.7.0",
+        "raw-body": "2.4.0",
+        "type-is": "~1.6.17"
+      }
+    },
+    "brace-expansion": {
+      "version": "1.1.11",
+      "resolved": "https://registry.npmjs.org/brace-expansion/-/brace-expansion-1.1.11.tgz",
+      "integrity": "sha512-iCuPHDFgrHX7H2vEI/5xpz07zSHB00TpugqhmYtVmMO6518mCuRMoOYFldEBl0g187ufozdaHgWKcYFb61qGiA==",
+      "requires": {
+        "balanced-match": "^1.0.0",
+        "concat-map": "0.0.1"
+      }
+    },
+    "braces": {
+      "version": "1.8.5",
+      "resolved": "https://registry.npmjs.org/braces/-/braces-1.8.5.tgz",
+      "integrity": "sha1-uneWLhLf+WnWt2cR6RS3N4V79qc=",
+      "optional": true,
+      "requires": {
+        "expand-range": "^1.8.1",
+        "preserve": "^0.2.0",
+        "repeat-element": "^1.1.2"
+      }
+    },
+    "browser-stdout": {
+      "version": "1.3.1",
+      "resolved": "https://registry.npmjs.org/browser-stdout/-/browser-stdout-1.3.1.tgz",
+      "integrity": "sha512-qhAVI1+Av2X7qelOfAIYwXONood6XlZE/fXaBSmW/T5SzLAmCgzi+eiWE7fUvbHaeNBQH13UftjpXxsfLkMpgw==",
+      "dev": true
+    },
+    "bson": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/bson/-/bson-1.1.1.tgz",
+      "integrity": "sha512-jCGVYLoYMHDkOsbwJZBCqwMHyH4c+wzgI9hG7Z6SZJRXWr+x58pdIbm2i9a/jFGCkRJqRUr8eoI7lDWa0hTkxg=="
+    },
+    "buffer": {
+      "version": "5.2.1",
+      "resolved": "https://registry.npmjs.org/buffer/-/buffer-5.2.1.tgz",
+      "integrity": "sha512-c+Ko0loDaFfuPWiL02ls9Xd3GO3cPVmUobQ6t3rXNUk304u6hGq+8N/kFi+QEIKhzK3uwolVhLzszmfLmMLnqg==",
+      "requires": {
+        "base64-js": "^1.0.2",
+        "ieee754": "^1.1.4"
+      }
+    },
+    "buffer-alloc": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/buffer-alloc/-/buffer-alloc-1.2.0.tgz",
+      "integrity": "sha512-CFsHQgjtW1UChdXgbyJGtnm+O/uLQeZdtbDo8mfUgYXCHSM1wgrVxXm6bSyrUuErEb+4sYVGCzASBRot7zyrow==",
+      "requires": {
+        "buffer-alloc-unsafe": "^1.1.0",
+        "buffer-fill": "^1.0.0"
+      }
+    },
+    "buffer-alloc-unsafe": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/buffer-alloc-unsafe/-/buffer-alloc-unsafe-1.1.0.tgz",
+      "integrity": "sha512-TEM2iMIEQdJ2yjPJoSIsldnleVaAk1oW3DBVUykyOLsEsFmEc9kn+SFFPz+gl54KQNxlDnAwCXosOS9Okx2xAg=="
+    },
+    "buffer-crc32": {
+      "version": "0.2.13",
+      "resolved": "https://registry.npmjs.org/buffer-crc32/-/buffer-crc32-0.2.13.tgz",
+      "integrity": "sha1-DTM+PwDqxQqhRUq9MO+MKl2ackI="
+    },
+    "buffer-fill": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/buffer-fill/-/buffer-fill-1.0.0.tgz",
+      "integrity": "sha1-+PeLdniYiO858gXNY39o5wISKyw="
+    },
+    "buffer-from": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/buffer-from/-/buffer-from-1.1.1.tgz",
+      "integrity": "sha512-MQcXEUbCKtEo7bhqEs6560Hyd4XaovZlO/k9V3hjVUF/zwW7KBVdSK4gIt/bzwS9MbR5qob+F5jusZsb0YQK2A=="
+    },
+    "byline": {
+      "version": "5.0.0",
+      "resolved": "https://registry.npmjs.org/byline/-/byline-5.0.0.tgz",
+      "integrity": "sha1-dBxSFkaOrcRXsDQQEYrXfejB3bE="
+    },
+    "bytes": {
+      "version": "3.1.0",
+      "resolved": "https://registry.npmjs.org/bytes/-/bytes-3.1.0.tgz",
+      "integrity": "sha512-zauLjrfCG+xvoyaqLoV8bLVXXNGC4JqlxFCutSDWA6fJrTo2ZuvLYTqZ7aHBLZSMOopbzwv8f+wZcVzfVTI2Dg=="
+    },
+    "cache-base": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/cache-base/-/cache-base-1.0.1.tgz",
+      "integrity": "sha512-AKcdTnFSWATd5/GCPRxr2ChwIJ85CeyrEyjRHlKxQ56d4XJMGym0uAiKn0xbLOGOl3+yRpOTi484dVCEc5AUzQ==",
+      "requires": {
+        "collection-visit": "^1.0.0",
+        "component-emitter": "^1.2.1",
+        "get-value": "^2.0.6",
+        "has-value": "^1.0.0",
+        "isobject": "^3.0.1",
+        "set-value": "^2.0.0",
+        "to-object-path": "^0.3.0",
+        "union-value": "^1.0.0",
+        "unset-value": "^1.0.0"
+      },
+      "dependencies": {
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        }
+      }
+    },
+    "call-me-maybe": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/call-me-maybe/-/call-me-maybe-1.0.1.tgz",
+      "integrity": "sha1-JtII6onje1y95gJQoV8DHBak1ms="
+    },
+    "callsite": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/callsite/-/callsite-1.0.0.tgz",
+      "integrity": "sha1-KAOY5dZkvXQDi28JBRU+borxvCA="
+    },
+    "callsites": {
+      "version": "3.1.0",
+      "resolved": "https://registry.npmjs.org/callsites/-/callsites-3.1.0.tgz",
+      "integrity": "sha512-P8BjAsXvZS+VIDUI11hHCQEv74YT67YUi5JJFNWIqL235sBmjX4+qx9Muvls5ivyNENctx46xQLQ3aTuE7ssaQ==",
+      "dev": true
+    },
+    "camelcase": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-3.0.0.tgz",
+      "integrity": "sha1-MvxLn82vhF/N9+c7uXysImHwqwo="
+    },
+    "caseless": {
+      "version": "0.12.0",
+      "resolved": "https://registry.npmjs.org/caseless/-/caseless-0.12.0.tgz",
+      "integrity": "sha1-G2gcIf+EAzyCZUMJBolCDRhxUdw="
+    },
+    "chai": {
+      "version": "4.2.0",
+      "resolved": "https://registry.npmjs.org/chai/-/chai-4.2.0.tgz",
+      "integrity": "sha512-XQU3bhBukrOsQCuwZndwGcCVQHyZi53fQ6Ys1Fym7E4olpIqqZZhhoFJoaKVvV17lWQoXYwgWN2nF5crA8J2jw==",
+      "dev": true,
+      "requires": {
+        "assertion-error": "^1.1.0",
+        "check-error": "^1.0.2",
+        "deep-eql": "^3.0.1",
+        "get-func-name": "^2.0.0",
+        "pathval": "^1.1.0",
+        "type-detect": "^4.0.5"
+      }
+    },
+    "chalk": {
+      "version": "1.1.3",
+      "resolved": "https://registry.npmjs.org/chalk/-/chalk-1.1.3.tgz",
+      "integrity": "sha1-qBFcVeSnAv5NFQq9OHKCKn4J/Jg=",
+      "requires": {
+        "ansi-styles": "^2.2.1",
+        "escape-string-regexp": "^1.0.2",
+        "has-ansi": "^2.0.0",
+        "strip-ansi": "^3.0.0",
+        "supports-color": "^2.0.0"
+      }
+    },
+    "chardet": {
+      "version": "0.7.0",
+      "resolved": "https://registry.npmjs.org/chardet/-/chardet-0.7.0.tgz",
+      "integrity": "sha512-mT8iDcrh03qDGRRmoA2hmBJnxpllMR+0/0qlzjqZES6NdiWDcZkCNAk4rPFZ9Q85r27unkiNNg8ZOiwZXBHwcA==",
+      "dev": true
+    },
+    "check-error": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/check-error/-/check-error-1.0.2.tgz",
+      "integrity": "sha1-V00xLt2Iu13YkS6Sht1sCu1KrII=",
+      "dev": true
+    },
+    "chokidar": {
+      "version": "1.7.0",
+      "resolved": "https://registry.npmjs.org/chokidar/-/chokidar-1.7.0.tgz",
+      "integrity": "sha1-eY5ol3gVHIB2tLNg5e3SjNortGg=",
+      "optional": true,
+      "requires": {
+        "anymatch": "^1.3.0",
+        "async-each": "^1.0.0",
+        "fsevents": "^1.0.0",
+        "glob-parent": "^2.0.0",
+        "inherits": "^2.0.1",
+        "is-binary-path": "^1.0.0",
+        "is-glob": "^2.0.0",
+        "path-is-absolute": "^1.0.0",
+        "readdirp": "^2.0.0"
+      }
+    },
+    "class-utils": {
+      "version": "0.3.6",
+      "resolved": "https://registry.npmjs.org/class-utils/-/class-utils-0.3.6.tgz",
+      "integrity": "sha512-qOhPa/Fj7s6TY8H8esGu5QNpMMQxz79h+urzrNYN6mn+9BnxlDGf5QZ+XeCDsxSjPqsSR56XOZOJmpeurnLMeg==",
+      "requires": {
+        "arr-union": "^3.1.0",
+        "define-property": "^0.2.5",
+        "isobject": "^3.0.0",
+        "static-extend": "^0.1.1"
+      },
+      "dependencies": {
+        "define-property": {
+          "version": "0.2.5",
+          "resolved": "https://registry.npmjs.org/define-property/-/define-property-0.2.5.tgz",
+          "integrity": "sha1-w1se+RjsPJkPmlvFe+BKrOxcgRY=",
+          "requires": {
+            "is-descriptor": "^0.1.0"
+          }
+        },
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        }
+      }
+    },
+    "cli-cursor": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/cli-cursor/-/cli-cursor-1.0.2.tgz",
+      "integrity": "sha1-ZNo/fValRBLll5S9Ytw1KV6PKYc=",
+      "requires": {
+        "restore-cursor": "^1.0.1"
+      }
+    },
+    "cli-width": {
+      "version": "2.2.0",
+      "resolved": "https://registry.npmjs.org/cli-width/-/cli-width-2.2.0.tgz",
+      "integrity": "sha1-/xnt6Kml5XkyQUewwR8PvLq+1jk="
+    },
+    "cliui": {
+      "version": "3.2.0",
+      "resolved": "https://registry.npmjs.org/cliui/-/cliui-3.2.0.tgz",
+      "integrity": "sha1-EgYBU3qRbSmUD5NNo7SNWFo5IT0=",
+      "requires": {
+        "string-width": "^1.0.1",
+        "strip-ansi": "^3.0.1",
+        "wrap-ansi": "^2.0.0"
+      }
+    },
+    "code-point-at": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/code-point-at/-/code-point-at-1.1.0.tgz",
+      "integrity": "sha1-DQcLTQQ6W+ozovGkDi7bPZpMz3c="
+    },
+    "collection-visit": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/collection-visit/-/collection-visit-1.0.0.tgz",
+      "integrity": "sha1-S8A3PBZLwykbTTaMgpzxqApZ3KA=",
+      "requires": {
+        "map-visit": "^1.0.0",
+        "object-visit": "^1.0.0"
+      }
+    },
+    "color-convert": {
+      "version": "1.9.3",
+      "resolved": "https://registry.npmjs.org/color-convert/-/color-convert-1.9.3.tgz",
+      "integrity": "sha512-QfAUtd+vFdAtFQcC8CCyYt1fYWxSqAiK2cSD6zDB8N3cpsEBAvRxp9zOGg6G/SHHJYAT88/az/IuDGALsNVbGg==",
+      "requires": {
+        "color-name": "1.1.3"
+      }
+    },
+    "color-name": {
+      "version": "1.1.3",
+      "resolved": "https://registry.npmjs.org/color-name/-/color-name-1.1.3.tgz",
+      "integrity": "sha1-p9BVi9icQveV3UIyj3QIMcpTvCU="
+    },
+    "colors": {
+      "version": "1.3.3",
+      "resolved": "https://registry.npmjs.org/colors/-/colors-1.3.3.tgz",
+      "integrity": "sha512-mmGt/1pZqYRjMxB1axhTo16/snVZ5krrKkcmMeVKxzECMMXoCgnvTPp10QgHfcbQZw8Dq2jMNG6je4JlWU0gWg=="
+    },
+    "combined-stream": {
+      "version": "1.0.7",
+      "resolved": "https://registry.npmjs.org/combined-stream/-/combined-stream-1.0.7.tgz",
+      "integrity": "sha512-brWl9y6vOB1xYPZcpZde3N9zDByXTosAeMDo4p1wzo6UMOX4vumB+TP1RZ76sfE6Md68Q0NJSrE/gbezd4Ul+w==",
+      "requires": {
+        "delayed-stream": "~1.0.0"
+      }
+    },
+    "commander": {
+      "version": "2.20.0",
+      "resolved": "https://registry.npmjs.org/commander/-/commander-2.20.0.tgz",
+      "integrity": "sha512-7j2y+40w61zy6YC2iRNpUe/NwhNyoXrYpHMrSunaMG64nRnaf96zO/KMQR4OyN/UnE5KLyEBnKHd4aG3rskjpQ=="
+    },
+    "commondir": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/commondir/-/commondir-1.0.1.tgz",
+      "integrity": "sha1-3dgA2gxmEnOTzKWVDqloo6rxJTs=",
+      "dev": true
+    },
+    "component-bind": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/component-bind/-/component-bind-1.0.0.tgz",
+      "integrity": "sha1-AMYIq33Nk4l8AAllGx06jh5zu9E="
+    },
+    "component-emitter": {
+      "version": "1.3.0",
+      "resolved": "https://registry.npmjs.org/component-emitter/-/component-emitter-1.3.0.tgz",
+      "integrity": "sha512-Rd3se6QB+sO1TwqZjscQrurpEPIfO0/yYnSin6Q/rD3mOutHvUrCAhJub3r90uNb+SESBuE0QYoB90YdfatsRg=="
+    },
+    "component-inherit": {
+      "version": "0.0.3",
+      "resolved": "https://registry.npmjs.org/component-inherit/-/component-inherit-0.0.3.tgz",
+      "integrity": "sha1-ZF/ErfWLcrZJ1crmUTVhnbJv8UM="
+    },
+    "concat-map": {
+      "version": "0.0.1",
+      "resolved": "https://registry.npmjs.org/concat-map/-/concat-map-0.0.1.tgz",
+      "integrity": "sha1-2Klr13/Wjfd5OnMDajug1UBdR3s="
+    },
+    "concat-stream": {
+      "version": "1.6.2",
+      "resolved": "https://registry.npmjs.org/concat-stream/-/concat-stream-1.6.2.tgz",
+      "integrity": "sha512-27HBghJxjiZtIk3Ycvn/4kbJk/1uZuJFfuPEns6LaEvpvG1f0hTea8lilrouyo9mVc2GWdcEZ8OLoGmSADlrCw==",
+      "requires": {
+        "buffer-from": "^1.0.0",
+        "inherits": "^2.0.3",
+        "readable-stream": "^2.2.2",
+        "typedarray": "^0.0.6"
+      }
+    },
+    "connect-mongodb-session": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/connect-mongodb-session/-/connect-mongodb-session-2.1.1.tgz",
+      "integrity": "sha512-k8NF+C32tJZuR3sSFfdz56e1NKzxejWlD/X5PVYBIZQ8/dzqkMGTKxcdGXsBreU5M48WZ+vYGrJSruSRTzFu4Q==",
+      "requires": {
+        "archetype": "0.8.x",
+        "mongodb": "~3.1.8"
+      }
+    },
+    "content-disposition": {
+      "version": "0.5.2",
+      "resolved": "https://registry.npmjs.org/content-disposition/-/content-disposition-0.5.2.tgz",
+      "integrity": "sha1-DPaLud318r55YcOoUXjLhdunjLQ="
+    },
+    "content-type": {
+      "version": "1.0.4",
+      "resolved": "https://registry.npmjs.org/content-type/-/content-type-1.0.4.tgz",
+      "integrity": "sha512-hIP3EEPs8tB9AT1L+NUqtwOAps4mk2Zob89MWXMHjHWg9milF/j4osnnQLXBCBFBk/tvIG/tUc9mOUJiPBhPXA=="
+    },
+    "convert-source-map": {
+      "version": "1.6.0",
+      "resolved": "https://registry.npmjs.org/convert-source-map/-/convert-source-map-1.6.0.tgz",
+      "integrity": "sha512-eFu7XigvxdZ1ETfbgPBohgyQ/Z++C0eEhTor0qRwBw9unw+L0/6V8wkSuGgzdThkiS5lSpdptOQPD8Ak40a+7A==",
+      "requires": {
+        "safe-buffer": "~5.1.1"
+      }
+    },
+    "cookie": {
+      "version": "0.3.1",
+      "resolved": "https://registry.npmjs.org/cookie/-/cookie-0.3.1.tgz",
+      "integrity": "sha1-5+Ch+e9DtMi6klxcWpboBtFoc7s="
+    },
+    "cookie-parser": {
+      "version": "1.4.4",
+      "resolved": "https://registry.npmjs.org/cookie-parser/-/cookie-parser-1.4.4.tgz",
+      "integrity": "sha512-lo13tqF3JEtFO7FyA49CqbhaFkskRJ0u/UAiINgrIXeRCY41c88/zxtrECl8AKH3B0hj9q10+h3Kt8I7KlW4tw==",
+      "requires": {
+        "cookie": "0.3.1",
+        "cookie-signature": "1.0.6"
+      }
+    },
+    "cookie-signature": {
+      "version": "1.0.6",
+      "resolved": "https://registry.npmjs.org/cookie-signature/-/cookie-signature-1.0.6.tgz",
+      "integrity": "sha1-4wOogrNCzD7oylE6eZmXNNqzriw="
+    },
+    "cookiejar": {
+      "version": "2.1.2",
+      "resolved": "https://registry.npmjs.org/cookiejar/-/cookiejar-2.1.2.tgz",
+      "integrity": "sha512-Mw+adcfzPxcPeI+0WlvRrr/3lGVO0bD75SxX6811cxSh1Wbxx7xZBGK1eVtDf6si8rg2lhnUjsVLMFMfbRIuwA==",
+      "dev": true
+    },
+    "copy-descriptor": {
+      "version": "0.1.1",
+      "resolved": "https://registry.npmjs.org/copy-descriptor/-/copy-descriptor-0.1.1.tgz",
+      "integrity": "sha1-Z29us8OZl8LuGsOpJP1hJHSPV40="
+    },
+    "core-js": {
+      "version": "2.6.5",
+      "resolved": "https://registry.npmjs.org/core-js/-/core-js-2.6.5.tgz",
+      "integrity": "sha512-klh/kDpwX8hryYL14M9w/xei6vrv6sE8gTHDG7/T/+SEovB/G4ejwcfE/CBzO6Edsu+OETZMZ3wcX/EjUkrl5A=="
+    },
+    "core-util-is": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/core-util-is/-/core-util-is-1.0.2.tgz",
+      "integrity": "sha1-tf1UIgqivFq1eqtxQMlAdUUDwac="
+    },
+    "cross-env": {
+      "version": "5.2.0",
+      "resolved": "https://registry.npmjs.org/cross-env/-/cross-env-5.2.0.tgz",
+      "integrity": "sha512-jtdNFfFW1hB7sMhr/H6rW1Z45LFqyI431m3qU6bFXcQ3Eh7LtBuG3h74o7ohHZ3crrRkkqHlo4jYHFPcjroANg==",
+      "dev": true,
+      "requires": {
+        "cross-spawn": "^6.0.5",
+        "is-windows": "^1.0.0"
+      }
+    },
+    "cross-spawn": {
+      "version": "6.0.5",
+      "resolved": "https://registry.npmjs.org/cross-spawn/-/cross-spawn-6.0.5.tgz",
+      "integrity": "sha512-eTVLrBSt7fjbDygz805pMnstIs2VTBNkRm0qxZd+M7A5XDdxVRWO5MxGBXZhjY4cqLYLdtrGqRf8mBPmzwSpWQ==",
+      "dev": true,
+      "requires": {
+        "nice-try": "^1.0.4",
+        "path-key": "^2.0.1",
+        "semver": "^5.5.0",
+        "shebang-command": "^1.2.0",
+        "which": "^1.2.9"
+      }
+    },
+    "dashdash": {
+      "version": "1.14.1",
+      "resolved": "https://registry.npmjs.org/dashdash/-/dashdash-1.14.1.tgz",
+      "integrity": "sha1-hTz6D3y+L+1d4gMmuN1YEDX24vA=",
+      "requires": {
+        "assert-plus": "^1.0.0"
+      }
+    },
+    "debug": {
+      "version": "2.6.9",
+      "resolved": "https://registry.npmjs.org/debug/-/debug-2.6.9.tgz",
+      "integrity": "sha512-bC7ElrdJaJnPbAP+1EotYvqZsb3ecl5wi6Bfi6BJTUcNowp6cvspg0jXznRTKDjm/E7AdgFBVeAPVMNcKGsHMA==",
+      "requires": {
+        "ms": "2.0.0"
+      }
+    },
+    "decamelize": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/decamelize/-/decamelize-1.2.0.tgz",
+      "integrity": "sha1-9lNNFRSCabIDUue+4m9QH5oZEpA="
+    },
+    "decode-uri-component": {
+      "version": "0.2.0",
+      "resolved": "https://registry.npmjs.org/decode-uri-component/-/decode-uri-component-0.2.0.tgz",
+      "integrity": "sha1-6zkTMzRYd1y4TNGh+uBiEGu4dUU="
+    },
+    "decompress": {
+      "version": "4.2.0",
+      "resolved": "https://registry.npmjs.org/decompress/-/decompress-4.2.0.tgz",
+      "integrity": "sha1-eu3YVCflqS2s/lVnSnxQXpbQH50=",
+      "requires": {
+        "decompress-tar": "^4.0.0",
+        "decompress-tarbz2": "^4.0.0",
+        "decompress-targz": "^4.0.0",
+        "decompress-unzip": "^4.0.1",
+        "graceful-fs": "^4.1.10",
+        "make-dir": "^1.0.0",
+        "pify": "^2.3.0",
+        "strip-dirs": "^2.0.0"
+      }
+    },
+    "decompress-tar": {
+      "version": "4.1.1",
+      "resolved": "https://registry.npmjs.org/decompress-tar/-/decompress-tar-4.1.1.tgz",
+      "integrity": "sha512-JdJMaCrGpB5fESVyxwpCx4Jdj2AagLmv3y58Qy4GE6HMVjWz1FeVQk1Ct4Kye7PftcdOo/7U7UKzYBJgqnGeUQ==",
+      "requires": {
+        "file-type": "^5.2.0",
+        "is-stream": "^1.1.0",
+        "tar-stream": "^1.5.2"
+      }
+    },
+    "decompress-tarbz2": {
+      "version": "4.1.1",
+      "resolved": "https://registry.npmjs.org/decompress-tarbz2/-/decompress-tarbz2-4.1.1.tgz",
+      "integrity": "sha512-s88xLzf1r81ICXLAVQVzaN6ZmX4A6U4z2nMbOwobxkLoIIfjVMBg7TeguTUXkKeXni795B6y5rnvDw7rxhAq9A==",
+      "requires": {
+        "decompress-tar": "^4.1.0",
+        "file-type": "^6.1.0",
+        "is-stream": "^1.1.0",
+        "seek-bzip": "^1.0.5",
+        "unbzip2-stream": "^1.0.9"
+      },
+      "dependencies": {
+        "file-type": {
+          "version": "6.2.0",
+          "resolved": "https://registry.npmjs.org/file-type/-/file-type-6.2.0.tgz",
+          "integrity": "sha512-YPcTBDV+2Tm0VqjybVd32MHdlEGAtuxS3VAYsumFokDSMG+ROT5wawGlnHDoz7bfMcMDt9hxuXvXwoKUx2fkOg=="
+        }
+      }
+    },
+    "decompress-targz": {
+      "version": "4.1.1",
+      "resolved": "https://registry.npmjs.org/decompress-targz/-/decompress-targz-4.1.1.tgz",
+      "integrity": "sha512-4z81Znfr6chWnRDNfFNqLwPvm4db3WuZkqV+UgXQzSngG3CEKdBkw5jrv3axjjL96glyiiKjsxJG3X6WBZwX3w==",
+      "requires": {
+        "decompress-tar": "^4.1.1",
+        "file-type": "^5.2.0",
+        "is-stream": "^1.1.0"
+      }
+    },
+    "decompress-unzip": {
+      "version": "4.0.1",
+      "resolved": "https://registry.npmjs.org/decompress-unzip/-/decompress-unzip-4.0.1.tgz",
+      "integrity": "sha1-3qrM39FK6vhVePczroIQ+bSEj2k=",
+      "requires": {
+        "file-type": "^3.8.0",
+        "get-stream": "^2.2.0",
+        "pify": "^2.3.0",
+        "yauzl": "^2.4.2"
+      },
+      "dependencies": {
+        "file-type": {
+          "version": "3.9.0",
+          "resolved": "https://registry.npmjs.org/file-type/-/file-type-3.9.0.tgz",
+          "integrity": "sha1-JXoHg4TR24CHvESdEH1SpSZyuek="
+        }
+      }
+    },
+    "dedent": {
+      "version": "0.7.0",
+      "resolved": "https://registry.npmjs.org/dedent/-/dedent-0.7.0.tgz",
+      "integrity": "sha1-JJXduvbrh0q7Dhvp3yLS5aVEMmw=",
+      "dev": true
+    },
+    "deep-eql": {
+      "version": "3.0.1",
+      "resolved": "https://registry.npmjs.org/deep-eql/-/deep-eql-3.0.1.tgz",
+      "integrity": "sha512-+QeIQyN5ZuO+3Uk5DYh6/1eKO0m0YmJFGNmFHGACpf1ClL1nmlV/p4gNgbl2pJGxgXb4faqo6UE+M5ACEMyVcw==",
+      "dev": true,
+      "requires": {
+        "type-detect": "^4.0.0"
+      }
+    },
+    "deep-is": {
+      "version": "0.1.3",
+      "resolved": "https://registry.npmjs.org/deep-is/-/deep-is-0.1.3.tgz",
+      "integrity": "sha1-s2nW+128E+7PUk+RsHD+7cNXzzQ="
+    },
+    "define-properties": {
+      "version": "1.1.3",
+      "resolved": "https://registry.npmjs.org/define-properties/-/define-properties-1.1.3.tgz",
+      "integrity": "sha512-3MqfYKj2lLzdMSf8ZIZE/V+Zuy+BgD6f164e8K2w7dgnpKArBDerGYpM46IYYcjnkdPNMjPk9A6VFB8+3SKlXQ==",
+      "dev": true,
+      "requires": {
+        "object-keys": "^1.0.12"
+      }
+    },
+    "define-property": {
+      "version": "2.0.2",
+      "resolved": "https://registry.npmjs.org/define-property/-/define-property-2.0.2.tgz",
+      "integrity": "sha512-jwK2UV4cnPpbcG7+VRARKTZPUWowwXA8bzH5NP6ud0oeAxyYPuGZUAC7hMugpCdz4BeSZl2Dl9k66CHJ/46ZYQ==",
+      "requires": {
+        "is-descriptor": "^1.0.2",
+        "isobject": "^3.0.1"
+      },
+      "dependencies": {
+        "is-accessor-descriptor": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-accessor-descriptor/-/is-accessor-descriptor-1.0.0.tgz",
+          "integrity": "sha512-m5hnHTkcVsPfqx3AKlyttIPb7J+XykHvJP2B9bZDjlhLIoEq4XoK64Vg7boZlVWYK6LUY94dYPEE7Lh0ZkZKcQ==",
+          "requires": {
+            "kind-of": "^6.0.0"
+          }
+        },
+        "is-data-descriptor": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-data-descriptor/-/is-data-descriptor-1.0.0.tgz",
+          "integrity": "sha512-jbRXy1FmtAoCjQkVmIVYwuuqDFUbaOeDjmed1tOGPrsMhtJA4rD9tkgA0F1qJ3gRFRXcHYVkdeaP50Q5rE/jLQ==",
+          "requires": {
+            "kind-of": "^6.0.0"
+          }
+        },
+        "is-descriptor": {
+          "version": "1.0.2",
+          "resolved": "https://registry.npmjs.org/is-descriptor/-/is-descriptor-1.0.2.tgz",
+          "integrity": "sha512-2eis5WqQGV7peooDyLmNEPUrps9+SXX5c9pL3xEB+4e9HnGuDa7mB7kHxHw4CbqS9k1T2hOH3miL8n8WtiYVtg==",
+          "requires": {
+            "is-accessor-descriptor": "^1.0.0",
+            "is-data-descriptor": "^1.0.0",
+            "kind-of": "^6.0.2"
+          }
+        },
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        },
+        "kind-of": {
+          "version": "6.0.2",
+          "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-6.0.2.tgz",
+          "integrity": "sha512-s5kLOcnH0XqDO+FvuaLX8DDjZ18CGFk7VygH40QoKPUQhW4e2rvM0rwUq0t8IQDOwYSeLK01U90OjzBTme2QqA=="
+        }
+      }
+    },
+    "delayed-stream": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/delayed-stream/-/delayed-stream-1.0.0.tgz",
+      "integrity": "sha1-3zrhmayt+31ECqrgsp4icrJOxhk="
+    },
+    "depd": {
+      "version": "1.1.2",
+      "resolved": "https://registry.npmjs.org/depd/-/depd-1.1.2.tgz",
+      "integrity": "sha1-m81S4UwJd2PnSbJ0xDRu0uVgtak="
+    },
+    "destroy": {
+      "version": "1.0.4",
+      "resolved": "https://registry.npmjs.org/destroy/-/destroy-1.0.4.tgz",
+      "integrity": "sha1-l4hXRCxEdJ5CBmE+N5RiBYJqvYA="
+    },
+    "detect-indent": {
+      "version": "4.0.0",
+      "resolved": "https://registry.npmjs.org/detect-indent/-/detect-indent-4.0.0.tgz",
+      "integrity": "sha1-920GQ1LN9Docts5hnE7jqUdd4gg=",
+      "requires": {
+        "repeating": "^2.0.0"
+      }
+    },
+    "diff": {
+      "version": "3.5.0",
+      "resolved": "https://registry.npmjs.org/diff/-/diff-3.5.0.tgz",
+      "integrity": "sha512-A46qtFgd+g7pDZinpnwiRJtxbC1hpgf0uzP3iG89scHk0AUC7A1TGxf5OiiOUv/JMZR8GOt8hL900hV0bOy5xA=="
+    },
+    "dir-glob": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/dir-glob/-/dir-glob-2.0.0.tgz",
+      "integrity": "sha512-37qirFDz8cA5fimp9feo43fSuRo2gHwaIn6dXL8Ber1dGwUosDrGZeCCXq57WnIqE4aQ+u3eQZzsk1yOzhdwag==",
+      "requires": {
+        "arrify": "^1.0.1",
+        "path-type": "^3.0.0"
+      },
+      "dependencies": {
+        "path-type": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/path-type/-/path-type-3.0.0.tgz",
+          "integrity": "sha512-T2ZUsdZFHgA3u4e5PfPbjd7HDDpxPnQb5jN0SrDsjNSuVXHJqtwTnWqG0B1jZrgmJ/7lj1EmVIByWt1gxGkWvg==",
+          "requires": {
+            "pify": "^3.0.0"
+          }
+        },
+        "pify": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/pify/-/pify-3.0.0.tgz",
+          "integrity": "sha1-5aSs0sEB/fPZpNB/DbxNtJ3SgXY="
+        }
+      }
+    },
+    "doctrine": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/doctrine/-/doctrine-3.0.0.tgz",
+      "integrity": "sha512-yS+Q5i3hBf7GBkd4KG8a7eBNNWNGLTaEwwYWUijIYM7zrlYDM0BFXHjjPWlWZ1Rg7UaddZeIDmi9jF3HmqiQ2w==",
+      "dev": true,
+      "requires": {
+        "esutils": "^2.0.2"
+      }
+    },
+    "dotenv": {
+      "version": "5.0.1",
+      "resolved": "https://registry.npmjs.org/dotenv/-/dotenv-5.0.1.tgz",
+      "integrity": "sha512-4As8uPrjfwb7VXC+WnLCbXK7y+Ueb2B3zgNCePYfhxS1PYeaO1YTeplffTEcbfLhvFNGLAz90VvJs9yomG7bow=="
+    },
+    "ecc-jsbn": {
+      "version": "0.1.2",
+      "resolved": "https://registry.npmjs.org/ecc-jsbn/-/ecc-jsbn-0.1.2.tgz",
+      "integrity": "sha1-OoOpBOVDUyh4dMVkt1SThoSamMk=",
+      "requires": {
+        "jsbn": "~0.1.0",
+        "safer-buffer": "^2.1.0"
+      }
+    },
+    "ee-first": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/ee-first/-/ee-first-1.1.1.tgz",
+      "integrity": "sha1-WQxhFWsK4vTwJVcyoViyZrxWsh0="
+    },
+    "emoji-regex": {
+      "version": "7.0.3",
+      "resolved": "https://registry.npmjs.org/emoji-regex/-/emoji-regex-7.0.3.tgz",
+      "integrity": "sha512-CwBLREIQ7LvYFB0WyRvwhq5N5qPhc6PMjD6bYggFlI5YyDgl+0vxq5VHbMOFqLg7hfWzmu8T5Z1QofhmTIhItA==",
+      "dev": true
+    },
+    "encodeurl": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/encodeurl/-/encodeurl-1.0.2.tgz",
+      "integrity": "sha1-rT/0yG7C0CkyL1oCw6mmBslbP1k="
+    },
+    "end-of-stream": {
+      "version": "1.4.1",
+      "resolved": "https://registry.npmjs.org/end-of-stream/-/end-of-stream-1.4.1.tgz",
+      "integrity": "sha512-1MkrZNvWTKCaigbn+W15elq2BB/L22nqrSY5DKlo3X6+vclJm8Bb5djXJBmEX6fS3+zCh/F4VBK5Z2KxJt4s2Q==",
+      "requires": {
+        "once": "^1.4.0"
+      }
+    },
+    "engine.io": {
+      "version": "3.2.1",
+      "resolved": "https://registry.npmjs.org/engine.io/-/engine.io-3.2.1.tgz",
+      "integrity": "sha512-+VlKzHzMhaU+GsCIg4AoXF1UdDFjHHwMmMKqMJNDNLlUlejz58FCy4LBqB2YVJskHGYl06BatYWKP2TVdVXE5w==",
+      "requires": {
+        "accepts": "~1.3.4",
+        "base64id": "1.0.0",
+        "cookie": "0.3.1",
+        "debug": "~3.1.0",
+        "engine.io-parser": "~2.1.0",
+        "ws": "~3.3.1"
+      },
+      "dependencies": {
+        "debug": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.1.0.tgz",
+          "integrity": "sha512-OX8XqP7/1a9cqkxYw2yXss15f26NKWBpDXQd0/uK/KPqdQhxbPa994hnzjcE2VqQpDslf55723cKPUOGSmMY3g==",
+          "requires": {
+            "ms": "2.0.0"
+          }
+        }
+      }
+    },
+    "engine.io-client": {
+      "version": "3.2.1",
+      "resolved": "https://registry.npmjs.org/engine.io-client/-/engine.io-client-3.2.1.tgz",
+      "integrity": "sha512-y5AbkytWeM4jQr7m/koQLc5AxpRKC1hEVUb/s1FUAWEJq5AzJJ4NLvzuKPuxtDi5Mq755WuDvZ6Iv2rXj4PTzw==",
+      "requires": {
+        "component-emitter": "1.2.1",
+        "component-inherit": "0.0.3",
+        "debug": "~3.1.0",
+        "engine.io-parser": "~2.1.1",
+        "has-cors": "1.1.0",
+        "indexof": "0.0.1",
+        "parseqs": "0.0.5",
+        "parseuri": "0.0.5",
+        "ws": "~3.3.1",
+        "xmlhttprequest-ssl": "~1.5.4",
+        "yeast": "0.1.2"
+      },
+      "dependencies": {
+        "component-emitter": {
+          "version": "1.2.1",
+          "resolved": "https://registry.npmjs.org/component-emitter/-/component-emitter-1.2.1.tgz",
+          "integrity": "sha1-E3kY1teCg/ffemt8WmPhQOaUJeY="
+        },
+        "debug": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.1.0.tgz",
+          "integrity": "sha512-OX8XqP7/1a9cqkxYw2yXss15f26NKWBpDXQd0/uK/KPqdQhxbPa994hnzjcE2VqQpDslf55723cKPUOGSmMY3g==",
+          "requires": {
+            "ms": "2.0.0"
+          }
+        }
+      }
+    },
+    "engine.io-parser": {
+      "version": "2.1.3",
+      "resolved": "https://registry.npmjs.org/engine.io-parser/-/engine.io-parser-2.1.3.tgz",
+      "integrity": "sha512-6HXPre2O4Houl7c4g7Ic/XzPnHBvaEmN90vtRO9uLmwtRqQmTOw0QMevL1TOfL2Cpu1VzsaTmMotQgMdkzGkVA==",
+      "requires": {
+        "after": "0.8.2",
+        "arraybuffer.slice": "~0.0.7",
+        "base64-arraybuffer": "0.1.5",
+        "blob": "0.0.5",
+        "has-binary2": "~1.0.2"
+      }
+    },
+    "error-ex": {
+      "version": "1.3.2",
+      "resolved": "https://registry.npmjs.org/error-ex/-/error-ex-1.3.2.tgz",
+      "integrity": "sha512-7dFHNmqeFSEt2ZBsCriorKnn3Z2pj+fd9kmI6QoWw4//DL+icEBfc0U7qJCisqrTsKTjw4fNFy2pW9OqStD84g==",
+      "requires": {
+        "is-arrayish": "^0.2.1"
+      }
+    },
+    "es-abstract": {
+      "version": "1.13.0",
+      "resolved": "https://registry.npmjs.org/es-abstract/-/es-abstract-1.13.0.tgz",
+      "integrity": "sha512-vDZfg/ykNxQVwup/8E1BZhVzFfBxs9NqMzGcvIJrqg5k2/5Za2bWo40dK2J1pgLngZ7c+Shh8lwYtLGyrwPutg==",
+      "dev": true,
+      "requires": {
+        "es-to-primitive": "^1.2.0",
+        "function-bind": "^1.1.1",
+        "has": "^1.0.3",
+        "is-callable": "^1.1.4",
+        "is-regex": "^1.0.4",
+        "object-keys": "^1.0.12"
+      }
+    },
+    "es-to-primitive": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/es-to-primitive/-/es-to-primitive-1.2.0.tgz",
+      "integrity": "sha512-qZryBOJjV//LaxLTV6UC//WewneB3LcXOL9NP++ozKVXsIIIpm/2c13UDiD9Jp2eThsecw9m3jPqDwTyobcdbg==",
+      "dev": true,
+      "requires": {
+        "is-callable": "^1.1.4",
+        "is-date-object": "^1.0.1",
+        "is-symbol": "^1.0.2"
+      }
+    },
+    "es6-promise": {
+      "version": "4.2.6",
+      "resolved": "https://registry.npmjs.org/es6-promise/-/es6-promise-4.2.6.tgz",
+      "integrity": "sha512-aRVgGdnmW2OiySVPUC9e6m+plolMAJKjZnQlCwNSuK5yQ0JN61DZSO1X1Ufd1foqWRAlig0rhduTCHe7sVtK5Q==",
+      "dev": true
+    },
+    "es6-promisify": {
+      "version": "5.0.0",
+      "resolved": "https://registry.npmjs.org/es6-promisify/-/es6-promisify-5.0.0.tgz",
+      "integrity": "sha1-UQnWLz5W6pZ8S2NQWu8IKRyKUgM=",
+      "dev": true,
+      "requires": {
+        "es6-promise": "^4.0.3"
+      }
+    },
+    "escape-html": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/escape-html/-/escape-html-1.0.3.tgz",
+      "integrity": "sha1-Aljq5NPQwJdN4cFpGI7wBR0dGYg="
+    },
+    "escape-string-regexp": {
+      "version": "1.0.5",
+      "resolved": "https://registry.npmjs.org/escape-string-regexp/-/escape-string-regexp-1.0.5.tgz",
+      "integrity": "sha1-G2HAViGQqN/2rjuyzwIAyhMLhtQ="
+    },
+    "escodegen": {
+      "version": "1.11.0",
+      "resolved": "https://registry.npmjs.org/escodegen/-/escodegen-1.11.0.tgz",
+      "integrity": "sha512-IeMV45ReixHS53K/OmfKAIztN/igDHzTJUhZM3k1jMhIZWjk45SMwAtBsEXiJp3vSPmTcu6CXn7mDvFHRN66fw==",
+      "requires": {
+        "esprima": "^3.1.3",
+        "estraverse": "^4.2.0",
+        "esutils": "^2.0.2",
+        "optionator": "^0.8.1",
+        "source-map": "~0.6.1"
+      },
+      "dependencies": {
+        "source-map": {
+          "version": "0.6.1",
+          "resolved": "https://registry.npmjs.org/source-map/-/source-map-0.6.1.tgz",
+          "integrity": "sha512-UjgapumWlbMhkBgzT7Ykc5YXUT46F0iKu8SGXq0bcwP5dz/h0Plj6enJqjz1Zbq2l5WaqYnrVbwWOWMyF3F47g==",
+          "optional": true
+        }
+      }
+    },
+    "eslint": {
+      "version": "5.16.0",
+      "resolved": "https://registry.npmjs.org/eslint/-/eslint-5.16.0.tgz",
+      "integrity": "sha512-S3Rz11i7c8AA5JPv7xAH+dOyq/Cu/VXHiHXBPOU1k/JAM5dXqQPt3qcrhpHSorXmrpu2g0gkIBVXAqCpzfoZIg==",
+      "dev": true,
+      "requires": {
+        "@babel/code-frame": "^7.0.0",
+        "ajv": "^6.9.1",
+        "chalk": "^2.1.0",
+        "cross-spawn": "^6.0.5",
+        "debug": "^4.0.1",
+        "doctrine": "^3.0.0",
+        "eslint-scope": "^4.0.3",
+        "eslint-utils": "^1.3.1",
+        "eslint-visitor-keys": "^1.0.0",
+        "espree": "^5.0.1",
+        "esquery": "^1.0.1",
+        "esutils": "^2.0.2",
+        "file-entry-cache": "^5.0.1",
+        "functional-red-black-tree": "^1.0.1",
+        "glob": "^7.1.2",
+        "globals": "^11.7.0",
+        "ignore": "^4.0.6",
+        "import-fresh": "^3.0.0",
+        "imurmurhash": "^0.1.4",
+        "inquirer": "^6.2.2",
+        "js-yaml": "^3.13.0",
+        "json-stable-stringify-without-jsonify": "^1.0.1",
+        "levn": "^0.3.0",
+        "lodash": "^4.17.11",
+        "minimatch": "^3.0.4",
+        "mkdirp": "^0.5.1",
+        "natural-compare": "^1.4.0",
+        "optionator": "^0.8.2",
+        "path-is-inside": "^1.0.2",
+        "progress": "^2.0.0",
+        "regexpp": "^2.0.1",
+        "semver": "^5.5.1",
+        "strip-ansi": "^4.0.0",
+        "strip-json-comments": "^2.0.1",
+        "table": "^5.2.3",
+        "text-table": "^0.2.0"
+      },
+      "dependencies": {
+        "ansi-escapes": {
+          "version": "3.2.0",
+          "resolved": "https://registry.npmjs.org/ansi-escapes/-/ansi-escapes-3.2.0.tgz",
+          "integrity": "sha512-cBhpre4ma+U0T1oM5fXg7Dy1Jw7zzwv7lt/GoCpr+hDQJoYnKVPLL4dCvSEFMmQurOQvSrwT7SL/DAlhBI97RQ==",
+          "dev": true
+        },
+        "ansi-regex": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-3.0.0.tgz",
+          "integrity": "sha1-7QMXwyIGT3lGbAKWa922Bas32Zg=",
+          "dev": true
+        },
+        "ansi-styles": {
+          "version": "3.2.1",
+          "resolved": "https://registry.npmjs.org/ansi-styles/-/ansi-styles-3.2.1.tgz",
+          "integrity": "sha512-VT0ZI6kZRdTh8YyJw3SMbYm/u+NqfsAxEpWO0Pf9sq8/e94WxxOpPKx9FR1FlyCtOVDNOQ+8ntlqFxiRc+r5qA==",
+          "dev": true,
+          "requires": {
+            "color-convert": "^1.9.0"
+          }
+        },
+        "chalk": {
+          "version": "2.4.2",
+          "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.4.2.tgz",
+          "integrity": "sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==",
+          "dev": true,
+          "requires": {
+            "ansi-styles": "^3.2.1",
+            "escape-string-regexp": "^1.0.5",
+            "supports-color": "^5.3.0"
+          }
+        },
+        "cli-cursor": {
+          "version": "2.1.0",
+          "resolved": "https://registry.npmjs.org/cli-cursor/-/cli-cursor-2.1.0.tgz",
+          "integrity": "sha1-s12sN2R5+sw+lHR9QdDQ9SOP/LU=",
+          "dev": true,
+          "requires": {
+            "restore-cursor": "^2.0.0"
+          }
+        },
+        "debug": {
+          "version": "4.1.1",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-4.1.1.tgz",
+          "integrity": "sha512-pYAIzeRo8J6KPEaJ0VWOh5Pzkbw/RetuzehGM7QRRX5he4fPHx2rdKMB256ehJCkX+XRQm16eZLqLNS8RSZXZw==",
+          "dev": true,
+          "requires": {
+            "ms": "^2.1.1"
+          }
+        },
+        "figures": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/figures/-/figures-2.0.0.tgz",
+          "integrity": "sha1-OrGi0qYsi/tDGgyUy3l6L84nyWI=",
+          "dev": true,
+          "requires": {
+            "escape-string-regexp": "^1.0.5"
+          }
+        },
+        "globals": {
+          "version": "11.11.0",
+          "resolved": "https://registry.npmjs.org/globals/-/globals-11.11.0.tgz",
+          "integrity": "sha512-WHq43gS+6ufNOEqlrDBxVEbb8ntfXrfAUU2ZOpCxrBdGKW3gyv8mCxAfIBD0DroPKGrJ2eSsXsLtY9MPntsyTw==",
+          "dev": true
+        },
+        "ignore": {
+          "version": "4.0.6",
+          "resolved": "https://registry.npmjs.org/ignore/-/ignore-4.0.6.tgz",
+          "integrity": "sha512-cyFDKrqc/YdcWFniJhzI42+AzS+gNwmUzOSFcRCQYwySuBBBy/KjuxWLZ/FHEH6Moq1NizMOBWyTcv8O4OZIMg==",
+          "dev": true
+        },
+        "inquirer": {
+          "version": "6.3.1",
+          "resolved": "https://registry.npmjs.org/inquirer/-/inquirer-6.3.1.tgz",
+          "integrity": "sha512-MmL624rfkFt4TG9y/Jvmt8vdmOo836U7Y0Hxr2aFk3RelZEGX4Igk0KabWrcaaZaTv9uzglOqWh1Vly+FAWAXA==",
+          "dev": true,
+          "requires": {
+            "ansi-escapes": "^3.2.0",
+            "chalk": "^2.4.2",
+            "cli-cursor": "^2.1.0",
+            "cli-width": "^2.0.0",
+            "external-editor": "^3.0.3",
+            "figures": "^2.0.0",
+            "lodash": "^4.17.11",
+            "mute-stream": "0.0.7",
+            "run-async": "^2.2.0",
+            "rxjs": "^6.4.0",
+            "string-width": "^2.1.0",
+            "strip-ansi": "^5.1.0",
+            "through": "^2.3.6"
+          },
+          "dependencies": {
+            "ansi-regex": {
+              "version": "4.1.0",
+              "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-4.1.0.tgz",
+              "integrity": "sha512-1apePfXM1UOSqw0o9IiFAovVz9M5S1Dg+4TrDwfMewQ6p/rmMueb7tWZjQ1rx4Loy1ArBggoqGpfqqdI4rondg==",
+              "dev": true
+            },
+            "strip-ansi": {
+              "version": "5.2.0",
+              "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-5.2.0.tgz",
+              "integrity": "sha512-DuRs1gKbBqsMKIZlrffwlug8MHkcnpjs5VPmL1PAh+mA30U0DTotfDZ0d2UUsXpPmPmMMJ6W773MaA3J+lbiWA==",
+              "dev": true,
+              "requires": {
+                "ansi-regex": "^4.1.0"
+              }
+            }
+          }
+        },
+        "is-fullwidth-code-point": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-2.0.0.tgz",
+          "integrity": "sha1-o7MKXE8ZkYMWeqq5O+764937ZU8=",
+          "dev": true
+        },
+        "minimatch": {
+          "version": "3.0.4",
+          "resolved": "https://registry.npmjs.org/minimatch/-/minimatch-3.0.4.tgz",
+          "integrity": "sha512-yJHVQEhyqPLUTgt9B83PXu6W3rx4MvvHvSUvToogpwoGDOUQ+yDrR0HRot+yOCdCO7u4hX3pWft6kWBBcqh0UA==",
+          "dev": true,
+          "requires": {
+            "brace-expansion": "^1.1.7"
+          }
+        },
+        "ms": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/ms/-/ms-2.1.1.tgz",
+          "integrity": "sha512-tgp+dl5cGk28utYktBsrFqA7HKgrhgPsg6Z/EfhWI4gl1Hwq8B/GmY/0oXZ6nF8hDVesS/FpnYaD/kOWhYQvyg==",
+          "dev": true
+        },
+        "mute-stream": {
+          "version": "0.0.7",
+          "resolved": "https://registry.npmjs.org/mute-stream/-/mute-stream-0.0.7.tgz",
+          "integrity": "sha1-MHXOk7whuPq0PhvE2n6BFe0ee6s=",
+          "dev": true
+        },
+        "onetime": {
+          "version": "2.0.1",
+          "resolved": "https://registry.npmjs.org/onetime/-/onetime-2.0.1.tgz",
+          "integrity": "sha1-BnQoIw/WdEOyeUsiu6UotoZ5YtQ=",
+          "dev": true,
+          "requires": {
+            "mimic-fn": "^1.0.0"
+          }
+        },
+        "restore-cursor": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/restore-cursor/-/restore-cursor-2.0.0.tgz",
+          "integrity": "sha1-n37ih/gv0ybU/RYpI9YhKe7g368=",
+          "dev": true,
+          "requires": {
+            "onetime": "^2.0.0",
+            "signal-exit": "^3.0.2"
+          }
+        },
+        "run-async": {
+          "version": "2.3.0",
+          "resolved": "https://registry.npmjs.org/run-async/-/run-async-2.3.0.tgz",
+          "integrity": "sha1-A3GrSuC91yDUFm19/aZP96RFpsA=",
+          "dev": true,
+          "requires": {
+            "is-promise": "^2.1.0"
+          }
+        },
+        "string-width": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/string-width/-/string-width-2.1.1.tgz",
+          "integrity": "sha512-nOqH59deCq9SRHlxq1Aw85Jnt4w6KvLKqWVik6oA9ZklXLNIOlqg4F2yrT1MVaTjAqvVwdfeZ7w7aCvJD7ugkw==",
+          "dev": true,
+          "requires": {
+            "is-fullwidth-code-point": "^2.0.0",
+            "strip-ansi": "^4.0.0"
+          }
+        },
+        "strip-ansi": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
+          "integrity": "sha1-qEeQIusaw2iocTibY1JixQXuNo8=",
+          "dev": true,
+          "requires": {
+            "ansi-regex": "^3.0.0"
+          }
+        },
+        "supports-color": {
+          "version": "5.5.0",
+          "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-5.5.0.tgz",
+          "integrity": "sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==",
+          "dev": true,
+          "requires": {
+            "has-flag": "^3.0.0"
+          }
+        }
+      }
+    },
+    "eslint-formatter-friendly": {
+      "version": "6.0.0",
+      "resolved": "https://registry.npmjs.org/eslint-formatter-friendly/-/eslint-formatter-friendly-6.0.0.tgz",
+      "integrity": "sha512-fOBwGn2r8BPQ1KSKyVzjXP8VFxJ2tWKxxn2lIF+k1ezN/pFB44HDlrn5kBm1vxbyyRa/LC+1vHJwc7WETUAZ2Q==",
+      "dev": true,
+      "requires": {
+        "babel-code-frame": "6.26.0",
+        "chalk": "^2.0.1",
+        "extend": "^3.0.0",
+        "strip-ansi": "^4.0.0",
+        "text-table": "^0.2.0"
+      },
+      "dependencies": {
+        "ansi-regex": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-3.0.0.tgz",
+          "integrity": "sha1-7QMXwyIGT3lGbAKWa922Bas32Zg=",
+          "dev": true
+        },
+        "ansi-styles": {
+          "version": "3.2.1",
+          "resolved": "https://registry.npmjs.org/ansi-styles/-/ansi-styles-3.2.1.tgz",
+          "integrity": "sha512-VT0ZI6kZRdTh8YyJw3SMbYm/u+NqfsAxEpWO0Pf9sq8/e94WxxOpPKx9FR1FlyCtOVDNOQ+8ntlqFxiRc+r5qA==",
+          "dev": true,
+          "requires": {
+            "color-convert": "^1.9.0"
+          }
+        },
+        "chalk": {
+          "version": "2.4.2",
+          "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.4.2.tgz",
+          "integrity": "sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==",
+          "dev": true,
+          "requires": {
+            "ansi-styles": "^3.2.1",
+            "escape-string-regexp": "^1.0.5",
+            "supports-color": "^5.3.0"
+          }
+        },
+        "strip-ansi": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
+          "integrity": "sha1-qEeQIusaw2iocTibY1JixQXuNo8=",
+          "dev": true,
+          "requires": {
+            "ansi-regex": "^3.0.0"
+          }
+        },
+        "supports-color": {
+          "version": "5.5.0",
+          "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-5.5.0.tgz",
+          "integrity": "sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==",
+          "dev": true,
+          "requires": {
+            "has-flag": "^3.0.0"
+          }
+        }
+      }
+    },
+    "eslint-scope": {
+      "version": "4.0.3",
+      "resolved": "https://registry.npmjs.org/eslint-scope/-/eslint-scope-4.0.3.tgz",
+      "integrity": "sha512-p7VutNr1O/QrxysMo3E45FjYDTeXBy0iTltPFNSqKAIfjDSXC+4dj+qfyuD8bfAXrW/y6lW3O76VaYNPKfpKrg==",
+      "dev": true,
+      "requires": {
+        "esrecurse": "^4.1.0",
+        "estraverse": "^4.1.1"
+      }
+    },
+    "eslint-utils": {
+      "version": "1.3.1",
+      "resolved": "https://registry.npmjs.org/eslint-utils/-/eslint-utils-1.3.1.tgz",
+      "integrity": "sha512-Z7YjnIldX+2XMcjr7ZkgEsOj/bREONV60qYeB/bjMAqqqZ4zxKyWX+BOUkdmRmA9riiIPVvo5x86m5elviOk0Q==",
+      "dev": true
+    },
+    "eslint-visitor-keys": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/eslint-visitor-keys/-/eslint-visitor-keys-1.0.0.tgz",
+      "integrity": "sha512-qzm/XxIbxm/FHyH341ZrbnMUpe+5Bocte9xkmFMzPMjRaZMcXww+MpBptFvtU+79L362nqiLhekCxCxDPaUMBQ==",
+      "dev": true
+    },
+    "espree": {
+      "version": "5.0.1",
+      "resolved": "https://registry.npmjs.org/espree/-/espree-5.0.1.tgz",
+      "integrity": "sha512-qWAZcWh4XE/RwzLJejfcofscgMc9CamR6Tn1+XRXNzrvUSSbiAjGOI/fggztjIi7y9VLPqnICMIPiGyr8JaZ0A==",
+      "dev": true,
+      "requires": {
+        "acorn": "^6.0.7",
+        "acorn-jsx": "^5.0.0",
+        "eslint-visitor-keys": "^1.0.0"
+      }
+    },
+    "esprima": {
+      "version": "3.1.3",
+      "resolved": "https://registry.npmjs.org/esprima/-/esprima-3.1.3.tgz",
+      "integrity": "sha1-/cpRzuYTOJXjyI1TXOSdv/YqRjM="
+    },
+    "esquery": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/esquery/-/esquery-1.0.1.tgz",
+      "integrity": "sha512-SmiyZ5zIWH9VM+SRUReLS5Q8a7GxtRdxEBVZpm98rJM7Sb+A9DVCndXfkeFUd3byderg+EbDkfnevfCwynWaNA==",
+      "dev": true,
+      "requires": {
+        "estraverse": "^4.0.0"
+      }
+    },
+    "esrecurse": {
+      "version": "4.2.1",
+      "resolved": "https://registry.npmjs.org/esrecurse/-/esrecurse-4.2.1.tgz",
+      "integrity": "sha512-64RBB++fIOAXPw3P9cy89qfMlvZEXZkqqJkjqqXIvzP5ezRZjW+lPWjw35UX/3EhUPFYbg5ER4JYgDw4007/DQ==",
+      "dev": true,
+      "requires": {
+        "estraverse": "^4.1.0"
+      }
+    },
+    "estraverse": {
+      "version": "4.2.0",
+      "resolved": "https://registry.npmjs.org/estraverse/-/estraverse-4.2.0.tgz",
+      "integrity": "sha1-De4/7TH81GlhjOc0IJn8GvoL2xM="
+    },
+    "esutils": {
+      "version": "2.0.2",
+      "resolved": "https://registry.npmjs.org/esutils/-/esutils-2.0.2.tgz",
+      "integrity": "sha1-Cr9PHKpbyx96nYrMbepPqqBLrJs="
+    },
+    "etag": {
+      "version": "1.8.1",
+      "resolved": "https://registry.npmjs.org/etag/-/etag-1.8.1.tgz",
+      "integrity": "sha1-Qa4u62XvpiJorr/qg6x9eSmbCIc="
+    },
+    "execa": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/execa/-/execa-1.0.0.tgz",
+      "integrity": "sha512-adbxcyWV46qiHyvSp50TKt05tB4tK3HcmF7/nxfAdhnox83seTDbwnaqKO4sXRy7roHAIFqJP/Rw/AuEbX61LA==",
+      "dev": true,
+      "requires": {
+        "cross-spawn": "^6.0.0",
+        "get-stream": "^4.0.0",
+        "is-stream": "^1.1.0",
+        "npm-run-path": "^2.0.0",
+        "p-finally": "^1.0.0",
+        "signal-exit": "^3.0.0",
+        "strip-eof": "^1.0.0"
+      },
+      "dependencies": {
+        "get-stream": {
+          "version": "4.1.0",
+          "resolved": "https://registry.npmjs.org/get-stream/-/get-stream-4.1.0.tgz",
+          "integrity": "sha512-GMat4EJ5161kIy2HevLlr4luNjBgvmj413KaQA7jt4V8B4RDsfpHk7WQ9GVqfYyyx8OS/L66Kox+rJRNklLK7w==",
+          "dev": true,
+          "requires": {
+            "pump": "^3.0.0"
+          }
+        }
+      }
+    },
+    "exit-hook": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/exit-hook/-/exit-hook-1.1.1.tgz",
+      "integrity": "sha1-8FyiM7SMBdVP/wd2XfhQfpXAL/g="
+    },
+    "expand-brackets": {
+      "version": "0.1.5",
+      "resolved": "https://registry.npmjs.org/expand-brackets/-/expand-brackets-0.1.5.tgz",
+      "integrity": "sha1-3wcoTjQqgHzXM6xa9yQR5YHRF3s=",
+      "optional": true,
+      "requires": {
+        "is-posix-bracket": "^0.1.0"
+      }
+    },
+    "expand-range": {
+      "version": "1.8.2",
+      "resolved": "https://registry.npmjs.org/expand-range/-/expand-range-1.8.2.tgz",
+      "integrity": "sha1-opnv/TNf4nIeuujiV+x5ZE/IUzc=",
+      "optional": true,
+      "requires": {
+        "fill-range": "^2.1.0"
+      }
+    },
+    "expand-template": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/expand-template/-/expand-template-1.1.1.tgz",
+      "integrity": "sha512-cebqLtV8KOZfw0UI8TEFWxtczxxC1jvyUvx6H4fyp1K1FN7A4Q+uggVUlOsI1K8AGU0rwOGqP8nCapdrw8CYQg=="
+    },
+    "express": {
+      "version": "4.16.4",
+      "resolved": "https://registry.npmjs.org/express/-/express-4.16.4.tgz",
+      "integrity": "sha512-j12Uuyb4FMrd/qQAm6uCHAkPtO8FDTRJZBDd5D2KOL2eLaz1yUNdUB/NOIyq0iU4q4cFarsUCrnFDPBcnksuOg==",
+      "requires": {
+        "accepts": "~1.3.5",
+        "array-flatten": "1.1.1",
+        "body-parser": "1.18.3",
+        "content-disposition": "0.5.2",
+        "content-type": "~1.0.4",
+        "cookie": "0.3.1",
+        "cookie-signature": "1.0.6",
+        "debug": "2.6.9",
+        "depd": "~1.1.2",
+        "encodeurl": "~1.0.2",
+        "escape-html": "~1.0.3",
+        "etag": "~1.8.1",
+        "finalhandler": "1.1.1",
+        "fresh": "0.5.2",
+        "merge-descriptors": "1.0.1",
+        "methods": "~1.1.2",
+        "on-finished": "~2.3.0",
+        "parseurl": "~1.3.2",
+        "path-to-regexp": "0.1.7",
+        "proxy-addr": "~2.0.4",
+        "qs": "6.5.2",
+        "range-parser": "~1.2.0",
+        "safe-buffer": "5.1.2",
+        "send": "0.16.2",
+        "serve-static": "1.13.2",
+        "setprototypeof": "1.1.0",
+        "statuses": "~1.4.0",
+        "type-is": "~1.6.16",
+        "utils-merge": "1.0.1",
+        "vary": "~1.1.2"
+      },
+      "dependencies": {
+        "body-parser": {
+          "version": "1.18.3",
+          "resolved": "https://registry.npmjs.org/body-parser/-/body-parser-1.18.3.tgz",
+          "integrity": "sha1-WykhmP/dVTs6DyDe0FkrlWlVyLQ=",
+          "requires": {
+            "bytes": "3.0.0",
+            "content-type": "~1.0.4",
+            "debug": "2.6.9",
+            "depd": "~1.1.2",
+            "http-errors": "~1.6.3",
+            "iconv-lite": "0.4.23",
+            "on-finished": "~2.3.0",
+            "qs": "6.5.2",
+            "raw-body": "2.3.3",
+            "type-is": "~1.6.16"
+          }
+        },
+        "bytes": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/bytes/-/bytes-3.0.0.tgz",
+          "integrity": "sha1-0ygVQE1olpn4Wk6k+odV3ROpYEg="
+        },
+        "http-errors": {
+          "version": "1.6.3",
+          "resolved": "https://registry.npmjs.org/http-errors/-/http-errors-1.6.3.tgz",
+          "integrity": "sha1-i1VoC7S+KDoLW/TqLjhYC+HZMg0=",
+          "requires": {
+            "depd": "~1.1.2",
+            "inherits": "2.0.3",
+            "setprototypeof": "1.1.0",
+            "statuses": ">= 1.4.0 < 2"
+          }
+        },
+        "iconv-lite": {
+          "version": "0.4.23",
+          "resolved": "https://registry.npmjs.org/iconv-lite/-/iconv-lite-0.4.23.tgz",
+          "integrity": "sha512-neyTUVFtahjf0mB3dZT77u+8O0QB89jFdnBkd5P1JgYPbPaia3gXXOVL2fq8VyU2gMMD7SaN7QukTB/pmXYvDA==",
+          "requires": {
+            "safer-buffer": ">= 2.1.2 < 3"
+          }
+        },
+        "qs": {
+          "version": "6.5.2",
+          "resolved": "https://registry.npmjs.org/qs/-/qs-6.5.2.tgz",
+          "integrity": "sha512-N5ZAX4/LxJmF+7wN74pUD6qAh9/wnvdQcjq9TZjevvXzSUo7bfmw91saqMjzGS2xq91/odN2dW/WOl7qQHNDGA=="
+        },
+        "raw-body": {
+          "version": "2.3.3",
+          "resolved": "https://registry.npmjs.org/raw-body/-/raw-body-2.3.3.tgz",
+          "integrity": "sha512-9esiElv1BrZoI3rCDuOuKCBRbuApGGaDPQfjSflGxdy4oyzqghxu6klEkkVIvBje+FF0BX9coEv8KqW6X/7njw==",
+          "requires": {
+            "bytes": "3.0.0",
+            "http-errors": "1.6.3",
+            "iconv-lite": "0.4.23",
+            "unpipe": "1.0.0"
+          }
+        },
+        "setprototypeof": {
+          "version": "1.1.0",
+          "resolved": "https://registry.npmjs.org/setprototypeof/-/setprototypeof-1.1.0.tgz",
+          "integrity": "sha512-BvE/TwpZX4FXExxOxZyRGQQv651MSwmWKZGqvmPcRIjDqWub67kTKuIMx43cZZrS/cBBzwBcNDWoFxt2XEFIpQ=="
+        },
+        "statuses": {
+          "version": "1.4.0",
+          "resolved": "https://registry.npmjs.org/statuses/-/statuses-1.4.0.tgz",
+          "integrity": "sha512-zhSCtt8v2NDrRlPQpCNtw/heZLtfUDqxBM1udqikb/Hbk52LK4nQSwr10u77iopCW5LsyHpuXS0GnEc48mLeew=="
+        }
+      }
+    },
+    "express-mongo-sanitize": {
+      "version": "1.3.2",
+      "resolved": "https://registry.npmjs.org/express-mongo-sanitize/-/express-mongo-sanitize-1.3.2.tgz",
+      "integrity": "sha1-+6QE9sBBV3y+7sTdkFfO+7Q53lo="
+    },
+    "express-session": {
+      "version": "1.16.1",
+      "resolved": "https://registry.npmjs.org/express-session/-/express-session-1.16.1.tgz",
+      "integrity": "sha512-pWvUL8Tl5jUy1MLH7DhgUlpoKeVPUTe+y6WQD9YhcN0C5qAhsh4a8feVjiUXo3TFhIy191YGZ4tewW9edbl2xQ==",
+      "requires": {
+        "cookie": "0.3.1",
+        "cookie-signature": "1.0.6",
+        "debug": "2.6.9",
+        "depd": "~2.0.0",
+        "on-headers": "~1.0.2",
+        "parseurl": "~1.3.2",
+        "safe-buffer": "5.1.2",
+        "uid-safe": "~2.1.5"
+      },
+      "dependencies": {
+        "depd": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/depd/-/depd-2.0.0.tgz",
+          "integrity": "sha512-g7nH6P6dyDioJogAAGprGpCtVImJhpPk/roCzdb3fIh61/s/nPsfR6onyMwkCAR/OlC3yBC0lESvUoQEAssIrw=="
+        }
+      }
+    },
+    "extend": {
+      "version": "3.0.2",
+      "resolved": "https://registry.npmjs.org/extend/-/extend-3.0.2.tgz",
+      "integrity": "sha512-fjquC59cD7CyW6urNXK0FBufkZcoiGG80wTuPujX590cB5Ttln20E2UB4S/WARVqhXffZl2LNgS+gQdPIIim/g=="
+    },
+    "extend-shallow": {
+      "version": "3.0.2",
+      "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-3.0.2.tgz",
+      "integrity": "sha1-Jqcarwc7OfshJxcnRhMcJwQCjbg=",
+      "requires": {
+        "assign-symbols": "^1.0.0",
+        "is-extendable": "^1.0.1"
+      },
+      "dependencies": {
+        "is-extendable": {
+          "version": "1.0.1",
+          "resolved": "https://registry.npmjs.org/is-extendable/-/is-extendable-1.0.1.tgz",
+          "integrity": "sha512-arnXMxT1hhoKo9k1LZdmlNyJdDDfy2v0fXjFlmok4+i8ul/6WlbVge9bhM74OpNPQPMGUToDtz+KXa1PneJxOA==",
+          "requires": {
+            "is-plain-object": "^2.0.4"
+          }
+        }
+      }
+    },
+    "external-editor": {
+      "version": "3.0.3",
+      "resolved": "https://registry.npmjs.org/external-editor/-/external-editor-3.0.3.tgz",
+      "integrity": "sha512-bn71H9+qWoOQKyZDo25mOMVpSmXROAsTJVVVYzrrtol3d4y+AsKjf4Iwl2Q+IuT0kFSQ1qo166UuIwqYq7mGnA==",
+      "dev": true,
+      "requires": {
+        "chardet": "^0.7.0",
+        "iconv-lite": "^0.4.24",
+        "tmp": "^0.0.33"
+      }
+    },
+    "extglob": {
+      "version": "0.3.2",
+      "resolved": "https://registry.npmjs.org/extglob/-/extglob-0.3.2.tgz",
+      "integrity": "sha1-Lhj/PS9JqydlzskCPwEdqo2DSaE=",
+      "optional": true,
+      "requires": {
+        "is-extglob": "^1.0.0"
+      }
+    },
+    "extsprintf": {
+      "version": "1.3.0",
+      "resolved": "https://registry.npmjs.org/extsprintf/-/extsprintf-1.3.0.tgz",
+      "integrity": "sha1-lpGEQOMEGnpBT4xS48V06zw+HgU="
+    },
+    "fast-deep-equal": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-2.0.1.tgz",
+      "integrity": "sha1-ewUhjd+WZ79/Nwv3/bLLFf3Qqkk="
+    },
+    "fast-glob": {
+      "version": "2.2.6",
+      "resolved": "https://registry.npmjs.org/fast-glob/-/fast-glob-2.2.6.tgz",
+      "integrity": "sha512-0BvMaZc1k9F+MeWWMe8pL6YltFzZYcJsYU7D4JyDA6PAczaXvxqQQ/z+mDF7/4Mw01DeUc+i3CTKajnkANkV4w==",
+      "requires": {
+        "@mrmlnc/readdir-enhanced": "^2.2.1",
+        "@nodelib/fs.stat": "^1.1.2",
+        "glob-parent": "^3.1.0",
+        "is-glob": "^4.0.0",
+        "merge2": "^1.2.3",
+        "micromatch": "^3.1.10"
+      },
+      "dependencies": {
+        "arr-diff": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/arr-diff/-/arr-diff-4.0.0.tgz",
+          "integrity": "sha1-1kYQdP6/7HHn4VI1dhoyml3HxSA="
+        },
+        "array-unique": {
+          "version": "0.3.2",
+          "resolved": "https://registry.npmjs.org/array-unique/-/array-unique-0.3.2.tgz",
+          "integrity": "sha1-qJS3XUvE9s1nnvMkSp/Y9Gri1Cg="
+        },
+        "braces": {
+          "version": "2.3.2",
+          "resolved": "https://registry.npmjs.org/braces/-/braces-2.3.2.tgz",
+          "integrity": "sha512-aNdbnj9P8PjdXU4ybaWLK2IF3jc/EoDYbC7AazW6to3TRsfXxscC9UXOB5iDiEQrkyIbWp2SLQda4+QAa7nc3w==",
+          "requires": {
+            "arr-flatten": "^1.1.0",
+            "array-unique": "^0.3.2",
+            "extend-shallow": "^2.0.1",
+            "fill-range": "^4.0.0",
+            "isobject": "^3.0.1",
+            "repeat-element": "^1.1.2",
+            "snapdragon": "^0.8.1",
+            "snapdragon-node": "^2.0.1",
+            "split-string": "^3.0.2",
+            "to-regex": "^3.0.1"
+          },
+          "dependencies": {
+            "extend-shallow": {
+              "version": "2.0.1",
+              "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+              "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+              "requires": {
+                "is-extendable": "^0.1.0"
+              }
+            }
+          }
+        },
+        "expand-brackets": {
+          "version": "2.1.4",
+          "resolved": "https://registry.npmjs.org/expand-brackets/-/expand-brackets-2.1.4.tgz",
+          "integrity": "sha1-t3c14xXOMPa27/D4OwQVGiJEliI=",
+          "requires": {
+            "debug": "^2.3.3",
+            "define-property": "^0.2.5",
+            "extend-shallow": "^2.0.1",
+            "posix-character-classes": "^0.1.0",
+            "regex-not": "^1.0.0",
+            "snapdragon": "^0.8.1",
+            "to-regex": "^3.0.1"
+          },
+          "dependencies": {
+            "define-property": {
+              "version": "0.2.5",
+              "resolved": "https://registry.npmjs.org/define-property/-/define-property-0.2.5.tgz",
+              "integrity": "sha1-w1se+RjsPJkPmlvFe+BKrOxcgRY=",
+              "requires": {
+                "is-descriptor": "^0.1.0"
+              }
+            },
+            "extend-shallow": {
+              "version": "2.0.1",
+              "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+              "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+              "requires": {
+                "is-extendable": "^0.1.0"
+              }
+            },
+            "is-accessor-descriptor": {
+              "version": "0.1.6",
+              "resolved": "https://registry.npmjs.org/is-accessor-descriptor/-/is-accessor-descriptor-0.1.6.tgz",
+              "integrity": "sha1-qeEss66Nh2cn7u84Q/igiXtcmNY=",
+              "requires": {
+                "kind-of": "^3.0.2"
+              },
+              "dependencies": {
+                "kind-of": {
+                  "version": "3.2.2",
+                  "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-3.2.2.tgz",
+                  "integrity": "sha1-MeohpzS6ubuw8yRm2JOupR5KPGQ=",
+                  "requires": {
+                    "is-buffer": "^1.1.5"
+                  }
+                }
+              }
+            },
+            "is-data-descriptor": {
+              "version": "0.1.4",
+              "resolved": "https://registry.npmjs.org/is-data-descriptor/-/is-data-descriptor-0.1.4.tgz",
+              "integrity": "sha1-C17mSDiOLIYCgueT8YVv7D8wG1Y=",
+              "requires": {
+                "kind-of": "^3.0.2"
+              },
+              "dependencies": {
+                "kind-of": {
+                  "version": "3.2.2",
+                  "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-3.2.2.tgz",
+                  "integrity": "sha1-MeohpzS6ubuw8yRm2JOupR5KPGQ=",
+                  "requires": {
+                    "is-buffer": "^1.1.5"
+                  }
+                }
+              }
+            },
+            "is-descriptor": {
+              "version": "0.1.6",
+              "resolved": "https://registry.npmjs.org/is-descriptor/-/is-descriptor-0.1.6.tgz",
+              "integrity": "sha512-avDYr0SB3DwO9zsMov0gKCESFYqCnE4hq/4z3TdUlukEy5t9C0YRq7HLrsN52NAcqXKaepeCD0n+B0arnVG3Hg==",
+              "requires": {
+                "is-accessor-descriptor": "^0.1.6",
+                "is-data-descriptor": "^0.1.4",
+                "kind-of": "^5.0.0"
+              }
+            },
+            "kind-of": {
+              "version": "5.1.0",
+              "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-5.1.0.tgz",
+              "integrity": "sha512-NGEErnH6F2vUuXDh+OlbcKW7/wOcfdRHaZ7VWtqCztfHri/++YKmP51OdWeGPuqCOba6kk2OTe5d02VmTB80Pw=="
+            }
+          }
+        },
+        "extglob": {
+          "version": "2.0.4",
+          "resolved": "https://registry.npmjs.org/extglob/-/extglob-2.0.4.tgz",
+          "integrity": "sha512-Nmb6QXkELsuBr24CJSkilo6UHHgbekK5UiZgfE6UHD3Eb27YC6oD+bhcT+tJ6cl8dmsgdQxnWlcry8ksBIBLpw==",
+          "requires": {
+            "array-unique": "^0.3.2",
+            "define-property": "^1.0.0",
+            "expand-brackets": "^2.1.4",
+            "extend-shallow": "^2.0.1",
+            "fragment-cache": "^0.2.1",
+            "regex-not": "^1.0.0",
+            "snapdragon": "^0.8.1",
+            "to-regex": "^3.0.1"
+          },
+          "dependencies": {
+            "define-property": {
+              "version": "1.0.0",
+              "resolved": "https://registry.npmjs.org/define-property/-/define-property-1.0.0.tgz",
+              "integrity": "sha1-dp66rz9KY6rTr56NMEybvnm/sOY=",
+              "requires": {
+                "is-descriptor": "^1.0.0"
+              }
+            },
+            "extend-shallow": {
+              "version": "2.0.1",
+              "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+              "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+              "requires": {
+                "is-extendable": "^0.1.0"
+              }
+            }
+          }
+        },
+        "fill-range": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/fill-range/-/fill-range-4.0.0.tgz",
+          "integrity": "sha1-1USBHUKPmOsGpj3EAtJAPDKMOPc=",
+          "requires": {
+            "extend-shallow": "^2.0.1",
+            "is-number": "^3.0.0",
+            "repeat-string": "^1.6.1",
+            "to-regex-range": "^2.1.0"
+          },
+          "dependencies": {
+            "extend-shallow": {
+              "version": "2.0.1",
+              "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+              "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+              "requires": {
+                "is-extendable": "^0.1.0"
+              }
+            }
+          }
+        },
+        "glob-parent": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/glob-parent/-/glob-parent-3.1.0.tgz",
+          "integrity": "sha1-nmr2KZ2NO9K9QEMIMr0RPfkGxa4=",
+          "requires": {
+            "is-glob": "^3.1.0",
+            "path-dirname": "^1.0.0"
+          },
+          "dependencies": {
+            "is-glob": {
+              "version": "3.1.0",
+              "resolved": "https://registry.npmjs.org/is-glob/-/is-glob-3.1.0.tgz",
+              "integrity": "sha1-e6WuJCF4BKxwcHuWkiVnSGzD6Eo=",
+              "requires": {
+                "is-extglob": "^2.1.0"
+              }
+            }
+          }
+        },
+        "is-accessor-descriptor": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-accessor-descriptor/-/is-accessor-descriptor-1.0.0.tgz",
+          "integrity": "sha512-m5hnHTkcVsPfqx3AKlyttIPb7J+XykHvJP2B9bZDjlhLIoEq4XoK64Vg7boZlVWYK6LUY94dYPEE7Lh0ZkZKcQ==",
+          "requires": {
+            "kind-of": "^6.0.0"
+          }
+        },
+        "is-data-descriptor": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-data-descriptor/-/is-data-descriptor-1.0.0.tgz",
+          "integrity": "sha512-jbRXy1FmtAoCjQkVmIVYwuuqDFUbaOeDjmed1tOGPrsMhtJA4rD9tkgA0F1qJ3gRFRXcHYVkdeaP50Q5rE/jLQ==",
+          "requires": {
+            "kind-of": "^6.0.0"
+          }
+        },
+        "is-descriptor": {
+          "version": "1.0.2",
+          "resolved": "https://registry.npmjs.org/is-descriptor/-/is-descriptor-1.0.2.tgz",
+          "integrity": "sha512-2eis5WqQGV7peooDyLmNEPUrps9+SXX5c9pL3xEB+4e9HnGuDa7mB7kHxHw4CbqS9k1T2hOH3miL8n8WtiYVtg==",
+          "requires": {
+            "is-accessor-descriptor": "^1.0.0",
+            "is-data-descriptor": "^1.0.0",
+            "kind-of": "^6.0.2"
+          }
+        },
+        "is-extglob": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/is-extglob/-/is-extglob-2.1.1.tgz",
+          "integrity": "sha1-qIwCU1eR8C7TfHahueqXc8gz+MI="
+        },
+        "is-glob": {
+          "version": "4.0.1",
+          "resolved": "https://registry.npmjs.org/is-glob/-/is-glob-4.0.1.tgz",
+          "integrity": "sha512-5G0tKtBTFImOqDnLB2hG6Bp2qcKEFduo4tZu9MT/H6NQv/ghhy30o55ufafxJ/LdH79LLs2Kfrn85TLKyA7BUg==",
+          "requires": {
+            "is-extglob": "^2.1.1"
+          }
+        },
+        "is-number": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/is-number/-/is-number-3.0.0.tgz",
+          "integrity": "sha1-JP1iAaR4LPUFYcgQJ2r8fRLXEZU=",
+          "requires": {
+            "kind-of": "^3.0.2"
+          },
+          "dependencies": {
+            "kind-of": {
+              "version": "3.2.2",
+              "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-3.2.2.tgz",
+              "integrity": "sha1-MeohpzS6ubuw8yRm2JOupR5KPGQ=",
+              "requires": {
+                "is-buffer": "^1.1.5"
+              }
+            }
+          }
+        },
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        },
+        "kind-of": {
+          "version": "6.0.2",
+          "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-6.0.2.tgz",
+          "integrity": "sha512-s5kLOcnH0XqDO+FvuaLX8DDjZ18CGFk7VygH40QoKPUQhW4e2rvM0rwUq0t8IQDOwYSeLK01U90OjzBTme2QqA=="
+        },
+        "micromatch": {
+          "version": "3.1.10",
+          "resolved": "https://registry.npmjs.org/micromatch/-/micromatch-3.1.10.tgz",
+          "integrity": "sha512-MWikgl9n9M3w+bpsY3He8L+w9eF9338xRl8IAO5viDizwSzziFEyUzo2xrrloB64ADbTf8uA8vRqqttDTOmccg==",
+          "requires": {
+            "arr-diff": "^4.0.0",
+            "array-unique": "^0.3.2",
+            "braces": "^2.3.1",
+            "define-property": "^2.0.2",
+            "extend-shallow": "^3.0.2",
+            "extglob": "^2.0.4",
+            "fragment-cache": "^0.2.1",
+            "kind-of": "^6.0.2",
+            "nanomatch": "^1.2.9",
+            "object.pick": "^1.3.0",
+            "regex-not": "^1.0.0",
+            "snapdragon": "^0.8.1",
+            "to-regex": "^3.0.2"
+          }
+        }
+      }
+    },
+    "fast-json-stable-stringify": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/fast-json-stable-stringify/-/fast-json-stable-stringify-2.0.0.tgz",
+      "integrity": "sha1-1RQsDK7msRifh9OnYREGT4bIu/I="
+    },
+    "fast-levenshtein": {
+      "version": "2.0.6",
+      "resolved": "https://registry.npmjs.org/fast-levenshtein/-/fast-levenshtein-2.0.6.tgz",
+      "integrity": "sha1-PYpcZog6FqMMqGQ+hR8Zuqd5eRc="
+    },
+    "fd-slicer": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/fd-slicer/-/fd-slicer-1.1.0.tgz",
+      "integrity": "sha1-JcfInLH5B3+IkbvmHY85Dq4lbx4=",
+      "requires": {
+        "pend": "~1.2.0"
+      }
+    },
+    "figures": {
+      "version": "1.7.0",
+      "resolved": "https://registry.npmjs.org/figures/-/figures-1.7.0.tgz",
+      "integrity": "sha1-y+Hjr/zxzUS4DK3+0o3Hk6lwHS4=",
+      "requires": {
+        "escape-string-regexp": "^1.0.5",
+        "object-assign": "^4.1.0"
+      }
+    },
+    "file-entry-cache": {
+      "version": "5.0.1",
+      "resolved": "https://registry.npmjs.org/file-entry-cache/-/file-entry-cache-5.0.1.tgz",
+      "integrity": "sha512-bCg29ictuBaKUwwArK4ouCaqDgLZcysCFLmM/Yn/FDoqndh/9vNuQfXRDvTuXKLxfD/JtZQGKFT8MGcJBK644g==",
+      "dev": true,
+      "requires": {
+        "flat-cache": "^2.0.1"
+      }
+    },
+    "file-type": {
+      "version": "5.2.0",
+      "resolved": "https://registry.npmjs.org/file-type/-/file-type-5.2.0.tgz",
+      "integrity": "sha1-LdvqfHP/42No365J3DOMBYwritY="
+    },
+    "filename-regex": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/filename-regex/-/filename-regex-2.0.1.tgz",
+      "integrity": "sha1-wcS5vuPglyXdsQa3XB4wH+LxiyY=",
+      "optional": true
+    },
+    "fill-range": {
+      "version": "2.2.4",
+      "resolved": "https://registry.npmjs.org/fill-range/-/fill-range-2.2.4.tgz",
+      "integrity": "sha512-cnrcCbj01+j2gTG921VZPnHbjmdAf8oQV/iGeV2kZxGSyfYjjTyY79ErsK1WJWMpw6DaApEX72binqJE+/d+5Q==",
+      "optional": true,
+      "requires": {
+        "is-number": "^2.1.0",
+        "isobject": "^2.0.0",
+        "randomatic": "^3.0.0",
+        "repeat-element": "^1.1.2",
+        "repeat-string": "^1.5.2"
+      }
+    },
+    "finalhandler": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/finalhandler/-/finalhandler-1.1.1.tgz",
+      "integrity": "sha512-Y1GUDo39ez4aHAw7MysnUD5JzYX+WaIj8I57kO3aEPT1fFRL4sr7mjei97FgnwhAyyzRYmQZaTHb2+9uZ1dPtg==",
+      "requires": {
+        "debug": "2.6.9",
+        "encodeurl": "~1.0.2",
+        "escape-html": "~1.0.3",
+        "on-finished": "~2.3.0",
+        "parseurl": "~1.3.2",
+        "statuses": "~1.4.0",
+        "unpipe": "~1.0.0"
+      },
+      "dependencies": {
+        "statuses": {
+          "version": "1.4.0",
+          "resolved": "https://registry.npmjs.org/statuses/-/statuses-1.4.0.tgz",
+          "integrity": "sha512-zhSCtt8v2NDrRlPQpCNtw/heZLtfUDqxBM1udqikb/Hbk52LK4nQSwr10u77iopCW5LsyHpuXS0GnEc48mLeew=="
+        }
+      }
+    },
+    "find-cache-dir": {
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/find-cache-dir/-/find-cache-dir-2.1.0.tgz",
+      "integrity": "sha512-Tq6PixE0w/VMFfCgbONnkiQIVol/JJL7nRMi20fqzA4NRs9AfeqMGeRdPi3wIhYkxjeBaWh2rxwapn5Tu3IqOQ==",
+      "dev": true,
+      "requires": {
+        "commondir": "^1.0.1",
+        "make-dir": "^2.0.0",
+        "pkg-dir": "^3.0.0"
+      },
+      "dependencies": {
+        "make-dir": {
+          "version": "2.1.0",
+          "resolved": "https://registry.npmjs.org/make-dir/-/make-dir-2.1.0.tgz",
+          "integrity": "sha512-LS9X+dc8KLxXCb8dni79fLIIUA5VyZoyjSMCwTluaXA0o27cCK0bhXkpgw+sTXVpPy/lSO57ilRixqk0vDmtRA==",
+          "dev": true,
+          "requires": {
+            "pify": "^4.0.1",
+            "semver": "^5.6.0"
+          }
+        },
+        "pify": {
+          "version": "4.0.1",
+          "resolved": "https://registry.npmjs.org/pify/-/pify-4.0.1.tgz",
+          "integrity": "sha512-uB80kBFb/tfd68bVleG9T5GGsGPjJrLAUpR5PZIrhBnIaRTQRjqdJSsIKkOP6OAIFbj7GOrcudc5pNjZ+geV2g==",
+          "dev": true
+        }
+      }
+    },
+    "find-package-json": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/find-package-json/-/find-package-json-1.2.0.tgz",
+      "integrity": "sha512-+SOGcLGYDJHtyqHd87ysBhmaeQ95oWspDKnMXBrnQ9Eq4OkLNqejgoaD8xVWu6GPa0B6roa6KinCMEMcVeqONw==",
+      "dev": true
+    },
+    "find-up": {
+      "version": "1.1.2",
+      "resolved": "https://registry.npmjs.org/find-up/-/find-up-1.1.2.tgz",
+      "integrity": "sha1-ay6YIrGizgpgq2TWEOzK1TyyTQ8=",
+      "requires": {
+        "path-exists": "^2.0.0",
+        "pinkie-promise": "^2.0.0"
+      }
+    },
+    "fire-up": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/fire-up/-/fire-up-1.0.0.tgz",
+      "integrity": "sha1-cyXaXgqCyH77X39wM6uil1EB/0I=",
+      "requires": {
+        "bluebird": "^3.3.4",
+        "lodash": "^4.7.0",
+        "simple-glob": "0.1.1"
+      }
+    },
+    "flat": {
+      "version": "4.1.0",
+      "resolved": "https://registry.npmjs.org/flat/-/flat-4.1.0.tgz",
+      "integrity": "sha512-Px/TiLIznH7gEDlPXcUD4KnBusa6kR6ayRUVcnEAbreRIuhkqow/mun59BuRXwoYk7ZQOLW1ZM05ilIvK38hFw==",
+      "dev": true,
+      "requires": {
+        "is-buffer": "~2.0.3"
+      },
+      "dependencies": {
+        "is-buffer": {
+          "version": "2.0.3",
+          "resolved": "https://registry.npmjs.org/is-buffer/-/is-buffer-2.0.3.tgz",
+          "integrity": "sha512-U15Q7MXTuZlrbymiz95PJpZxu8IlipAp4dtS3wOdgPXx3mqBnslrWU14kxfHB+Py/+2PVKSr37dMAgM2A4uArw==",
+          "dev": true
+        }
+      }
+    },
+    "flat-cache": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/flat-cache/-/flat-cache-2.0.1.tgz",
+      "integrity": "sha512-LoQe6yDuUMDzQAEH8sgmh4Md6oZnc/7PjtwjNFSzveXqSHt6ka9fPBuso7IGf9Rz4uqnSnWiFH2B/zj24a5ReA==",
+      "dev": true,
+      "requires": {
+        "flatted": "^2.0.0",
+        "rimraf": "2.6.3",
+        "write": "1.0.3"
+      }
+    },
+    "flatted": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/flatted/-/flatted-2.0.0.tgz",
+      "integrity": "sha512-R+H8IZclI8AAkSBRQJLVOsxwAoHd6WC40b4QTNWIjzAa6BXOBfQcM587MXDTVPeYaopFNWHUFLx7eNmHDSxMWg==",
+      "dev": true
+    },
+    "for-in": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/for-in/-/for-in-1.0.2.tgz",
+      "integrity": "sha1-gQaNKVqBQuwKxybG4iAMMPttXoA="
+    },
+    "for-own": {
+      "version": "0.1.5",
+      "resolved": "https://registry.npmjs.org/for-own/-/for-own-0.1.5.tgz",
+      "integrity": "sha1-UmXGgaTylNq78XyVCbZ2OqhFEM4=",
+      "optional": true,
+      "requires": {
+        "for-in": "^1.0.1"
+      }
+    },
+    "forever-agent": {
+      "version": "0.6.1",
+      "resolved": "https://registry.npmjs.org/forever-agent/-/forever-agent-0.6.1.tgz",
+      "integrity": "sha1-+8cfDEGt6zf5bFd60e1C2P2sypE="
+    },
+    "form-data": {
+      "version": "2.3.3",
+      "resolved": "https://registry.npmjs.org/form-data/-/form-data-2.3.3.tgz",
+      "integrity": "sha512-1lLKB2Mu3aGP1Q/2eCOx0fNbRMe7XdwktwOruhfqqd0rIJWwN4Dh+E3hrPSlDCXnSR7UtZ1N38rVXm+6+MEhJQ==",
+      "requires": {
+        "asynckit": "^0.4.0",
+        "combined-stream": "^1.0.6",
+        "mime-types": "^2.1.12"
+      }
+    },
+    "formidable": {
+      "version": "1.2.1",
+      "resolved": "https://registry.npmjs.org/formidable/-/formidable-1.2.1.tgz",
+      "integrity": "sha512-Fs9VRguL0gqGHkXS5GQiMCr1VhZBxz0JnJs4JmMp/2jL18Fmbzvv7vOFRU+U8TBkHEE/CX1qDXzJplVULgsLeg==",
+      "dev": true
+    },
+    "forwarded": {
+      "version": "0.1.2",
+      "resolved": "https://registry.npmjs.org/forwarded/-/forwarded-0.1.2.tgz",
+      "integrity": "sha1-mMI9qxF1ZXuMBXPozszZGw/xjIQ="
+    },
+    "fragment-cache": {
+      "version": "0.2.1",
+      "resolved": "https://registry.npmjs.org/fragment-cache/-/fragment-cache-0.2.1.tgz",
+      "integrity": "sha1-QpD60n8T6Jvn8zeZxrxaCr//DRk=",
+      "requires": {
+        "map-cache": "^0.2.2"
+      }
+    },
+    "fresh": {
+      "version": "0.5.2",
+      "resolved": "https://registry.npmjs.org/fresh/-/fresh-0.5.2.tgz",
+      "integrity": "sha1-PYyt2Q2XZWn6g1qx+OSyOhBWBac="
+    },
+    "from2": {
+      "version": "2.3.0",
+      "resolved": "https://registry.npmjs.org/from2/-/from2-2.3.0.tgz",
+      "integrity": "sha1-i/tVAr3kpNNs/e6gB/zKIdfjgq8=",
+      "requires": {
+        "inherits": "^2.0.1",
+        "readable-stream": "^2.0.0"
+      }
+    },
+    "fs-constants": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/fs-constants/-/fs-constants-1.0.0.tgz",
+      "integrity": "sha512-y6OAwoSIf7FyjMIv94u+b5rdheZEjzR63GTyZJm5qh4Bi+2YgwLCcI/fPFZkL5PSixOt6ZNKm+w+Hfp/Bciwow=="
+    },
+    "fs-extra": {
+      "version": "2.1.2",
+      "resolved": "https://registry.npmjs.org/fs-extra/-/fs-extra-2.1.2.tgz",
+      "integrity": "sha1-BGxwFjzvmq1GsOSn+kZ/si1x3jU=",
+      "requires": {
+        "graceful-fs": "^4.1.2",
+        "jsonfile": "^2.1.0"
+      }
+    },
+    "fs-readdir-recursive": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/fs-readdir-recursive/-/fs-readdir-recursive-1.1.0.tgz",
+      "integrity": "sha512-GNanXlVr2pf02+sPN40XN8HG+ePaNcvM0q5mZBd668Obwb0yD5GiUbZOFgwn8kGMY6I3mdyDJzieUy3PTYyTRA=="
+    },
+    "fs.realpath": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/fs.realpath/-/fs.realpath-1.0.0.tgz",
+      "integrity": "sha1-FQStJSMVjKpA20onh8sBQRmU6k8="
+    },
+    "fsevents": {
+      "version": "1.2.8",
+      "resolved": "https://registry.npmjs.org/fsevents/-/fsevents-1.2.8.tgz",
+      "integrity": "sha512-tPvHgPGB7m40CZ68xqFGkKuzN+RnpGmSV+hgeKxhRpbxdqKXUFJGC3yonBOLzQBcJyGpdZFDfCsdOC2KFsXzeA==",
+      "optional": true,
+      "requires": {
+        "nan": "^2.12.1",
+        "node-pre-gyp": "^0.12.0"
+      },
+      "dependencies": {
+        "abbrev": {
+          "version": "1.1.1",
+          "bundled": true,
+          "optional": true
+        },
+        "ansi-regex": {
+          "version": "2.1.1",
+          "bundled": true
+        },
+        "aproba": {
+          "version": "1.2.0",
+          "bundled": true,
+          "optional": true
+        },
+        "are-we-there-yet": {
+          "version": "1.1.5",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "delegates": "^1.0.0",
+            "readable-stream": "^2.0.6"
+          }
+        },
+        "balanced-match": {
+          "version": "1.0.0",
+          "bundled": true
+        },
+        "brace-expansion": {
+          "version": "1.1.11",
+          "bundled": true,
+          "requires": {
+            "balanced-match": "^1.0.0",
+            "concat-map": "0.0.1"
+          }
+        },
+        "chownr": {
+          "version": "1.1.1",
+          "bundled": true,
+          "optional": true
+        },
+        "code-point-at": {
+          "version": "1.1.0",
+          "bundled": true
+        },
+        "concat-map": {
+          "version": "0.0.1",
+          "bundled": true
+        },
+        "console-control-strings": {
+          "version": "1.1.0",
+          "bundled": true
+        },
+        "core-util-is": {
+          "version": "1.0.2",
+          "bundled": true,
+          "optional": true
+        },
+        "debug": {
+          "version": "4.1.1",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "ms": "^2.1.1"
+          }
+        },
+        "deep-extend": {
+          "version": "0.6.0",
+          "bundled": true,
+          "optional": true
+        },
+        "delegates": {
+          "version": "1.0.0",
+          "bundled": true,
+          "optional": true
+        },
+        "detect-libc": {
+          "version": "1.0.3",
+          "bundled": true,
+          "optional": true
+        },
+        "fs-minipass": {
+          "version": "1.2.5",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "minipass": "^2.2.1"
+          }
+        },
+        "fs.realpath": {
+          "version": "1.0.0",
+          "bundled": true,
+          "optional": true
+        },
+        "gauge": {
+          "version": "2.7.4",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "aproba": "^1.0.3",
+            "console-control-strings": "^1.0.0",
+            "has-unicode": "^2.0.0",
+            "object-assign": "^4.1.0",
+            "signal-exit": "^3.0.0",
+            "string-width": "^1.0.1",
+            "strip-ansi": "^3.0.1",
+            "wide-align": "^1.1.0"
+          }
+        },
+        "glob": {
+          "version": "7.1.3",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "fs.realpath": "^1.0.0",
+            "inflight": "^1.0.4",
+            "inherits": "2",
+            "minimatch": "^3.0.4",
+            "once": "^1.3.0",
+            "path-is-absolute": "^1.0.0"
+          }
+        },
+        "has-unicode": {
+          "version": "2.0.1",
+          "bundled": true,
+          "optional": true
+        },
+        "iconv-lite": {
+          "version": "0.4.24",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "safer-buffer": ">= 2.1.2 < 3"
+          }
+        },
+        "ignore-walk": {
+          "version": "3.0.1",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "minimatch": "^3.0.4"
+          }
+        },
+        "inflight": {
+          "version": "1.0.6",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "once": "^1.3.0",
+            "wrappy": "1"
+          }
+        },
+        "inherits": {
+          "version": "2.0.3",
+          "bundled": true
+        },
+        "ini": {
+          "version": "1.3.5",
+          "bundled": true,
+          "optional": true
+        },
+        "is-fullwidth-code-point": {
+          "version": "1.0.0",
+          "bundled": true,
+          "requires": {
+            "number-is-nan": "^1.0.0"
+          }
+        },
+        "isarray": {
+          "version": "1.0.0",
+          "bundled": true,
+          "optional": true
+        },
+        "minimatch": {
+          "version": "3.0.4",
+          "bundled": true,
+          "requires": {
+            "brace-expansion": "^1.1.7"
+          }
+        },
+        "minimist": {
+          "version": "0.0.8",
+          "bundled": true
+        },
+        "minipass": {
+          "version": "2.3.5",
+          "bundled": true,
+          "requires": {
+            "safe-buffer": "^5.1.2",
+            "yallist": "^3.0.0"
+          }
+        },
+        "minizlib": {
+          "version": "1.2.1",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "minipass": "^2.2.1"
+          }
+        },
+        "mkdirp": {
+          "version": "0.5.1",
+          "bundled": true,
+          "requires": {
+            "minimist": "0.0.8"
+          }
+        },
+        "ms": {
+          "version": "2.1.1",
+          "bundled": true,
+          "optional": true
+        },
+        "needle": {
+          "version": "2.3.0",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "debug": "^4.1.0",
+            "iconv-lite": "^0.4.4",
+            "sax": "^1.2.4"
+          }
+        },
+        "node-pre-gyp": {
+          "version": "0.12.0",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "detect-libc": "^1.0.2",
+            "mkdirp": "^0.5.1",
+            "needle": "^2.2.1",
+            "nopt": "^4.0.1",
+            "npm-packlist": "^1.1.6",
+            "npmlog": "^4.0.2",
+            "rc": "^1.2.7",
+            "rimraf": "^2.6.1",
+            "semver": "^5.3.0",
+            "tar": "^4"
+          }
+        },
+        "nopt": {
+          "version": "4.0.1",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "abbrev": "1",
+            "osenv": "^0.1.4"
+          }
+        },
+        "npm-bundled": {
+          "version": "1.0.6",
+          "bundled": true,
+          "optional": true
+        },
+        "npm-packlist": {
+          "version": "1.4.1",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "ignore-walk": "^3.0.1",
+            "npm-bundled": "^1.0.1"
+          }
+        },
+        "npmlog": {
+          "version": "4.1.2",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "are-we-there-yet": "~1.1.2",
+            "console-control-strings": "~1.1.0",
+            "gauge": "~2.7.3",
+            "set-blocking": "~2.0.0"
+          }
+        },
+        "number-is-nan": {
+          "version": "1.0.1",
+          "bundled": true
+        },
+        "object-assign": {
+          "version": "4.1.1",
+          "bundled": true,
+          "optional": true
+        },
+        "once": {
+          "version": "1.4.0",
+          "bundled": true,
+          "requires": {
+            "wrappy": "1"
+          }
+        },
+        "os-homedir": {
+          "version": "1.0.2",
+          "bundled": true,
+          "optional": true
+        },
+        "os-tmpdir": {
+          "version": "1.0.2",
+          "bundled": true,
+          "optional": true
+        },
+        "osenv": {
+          "version": "0.1.5",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "os-homedir": "^1.0.0",
+            "os-tmpdir": "^1.0.0"
+          }
+        },
+        "path-is-absolute": {
+          "version": "1.0.1",
+          "bundled": true,
+          "optional": true
+        },
+        "process-nextick-args": {
+          "version": "2.0.0",
+          "bundled": true,
+          "optional": true
+        },
+        "rc": {
+          "version": "1.2.8",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "deep-extend": "^0.6.0",
+            "ini": "~1.3.0",
+            "minimist": "^1.2.0",
+            "strip-json-comments": "~2.0.1"
+          },
+          "dependencies": {
+            "minimist": {
+              "version": "1.2.0",
+              "bundled": true,
+              "optional": true
+            }
+          }
+        },
+        "readable-stream": {
+          "version": "2.3.6",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "core-util-is": "~1.0.0",
+            "inherits": "~2.0.3",
+            "isarray": "~1.0.0",
+            "process-nextick-args": "~2.0.0",
+            "safe-buffer": "~5.1.1",
+            "string_decoder": "~1.1.1",
+            "util-deprecate": "~1.0.1"
+          }
+        },
+        "rimraf": {
+          "version": "2.6.3",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "glob": "^7.1.3"
+          }
+        },
+        "safe-buffer": {
+          "version": "5.1.2",
+          "bundled": true
+        },
+        "safer-buffer": {
+          "version": "2.1.2",
+          "bundled": true,
+          "optional": true
+        },
+        "sax": {
+          "version": "1.2.4",
+          "bundled": true,
+          "optional": true
+        },
+        "semver": {
+          "version": "5.7.0",
+          "bundled": true,
+          "optional": true
+        },
+        "set-blocking": {
+          "version": "2.0.0",
+          "bundled": true,
+          "optional": true
+        },
+        "signal-exit": {
+          "version": "3.0.2",
+          "bundled": true,
+          "optional": true
+        },
+        "string-width": {
+          "version": "1.0.2",
+          "bundled": true,
+          "requires": {
+            "code-point-at": "^1.0.0",
+            "is-fullwidth-code-point": "^1.0.0",
+            "strip-ansi": "^3.0.0"
+          }
+        },
+        "string_decoder": {
+          "version": "1.1.1",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "safe-buffer": "~5.1.0"
+          }
+        },
+        "strip-ansi": {
+          "version": "3.0.1",
+          "bundled": true,
+          "requires": {
+            "ansi-regex": "^2.0.0"
+          }
+        },
+        "strip-json-comments": {
+          "version": "2.0.1",
+          "bundled": true,
+          "optional": true
+        },
+        "tar": {
+          "version": "4.4.8",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "chownr": "^1.1.1",
+            "fs-minipass": "^1.2.5",
+            "minipass": "^2.3.4",
+            "minizlib": "^1.1.1",
+            "mkdirp": "^0.5.0",
+            "safe-buffer": "^5.1.2",
+            "yallist": "^3.0.2"
+          }
+        },
+        "util-deprecate": {
+          "version": "1.0.2",
+          "bundled": true,
+          "optional": true
+        },
+        "wide-align": {
+          "version": "1.1.3",
+          "bundled": true,
+          "optional": true,
+          "requires": {
+            "string-width": "^1.0.2 || 2"
+          }
+        },
+        "wrappy": {
+          "version": "1.0.2",
+          "bundled": true
+        },
+        "yallist": {
+          "version": "3.0.3",
+          "bundled": true
+        }
+      }
+    },
+    "function-bind": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/function-bind/-/function-bind-1.1.1.tgz",
+      "integrity": "sha512-yIovAzMX49sF8Yl58fSCWJ5svSLuaibPxXQJFLmBObTuCr0Mf1KiPopGM9NiFjiYBCbfaa2Fh6breQ6ANVTI0A==",
+      "dev": true
+    },
+    "functional-red-black-tree": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/functional-red-black-tree/-/functional-red-black-tree-1.0.1.tgz",
+      "integrity": "sha1-GwqzvVU7Kg1jmdKcDj6gslIHgyc=",
+      "dev": true
+    },
+    "generaterr": {
+      "version": "1.5.0",
+      "resolved": "https://registry.npmjs.org/generaterr/-/generaterr-1.5.0.tgz",
+      "integrity": "sha1-sM62zFFk3yoGEzjMNAqGFTlcUvw="
+    },
+    "get-caller-file": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-1.0.3.tgz",
+      "integrity": "sha512-3t6rVToeoZfYSGd8YoLFR2DJkiQrIiUrGcjvFX2mDw3bn6k2OtwHN0TNCLbBO+w8qTvimhDkv+LSscbJY1vE6w=="
+    },
+    "get-func-name": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/get-func-name/-/get-func-name-2.0.0.tgz",
+      "integrity": "sha1-6td0q+5y4gQJQzoGY2YCPdaIekE=",
+      "dev": true
+    },
+    "get-port": {
+      "version": "4.2.0",
+      "resolved": "https://registry.npmjs.org/get-port/-/get-port-4.2.0.tgz",
+      "integrity": "sha512-/b3jarXkH8KJoOMQc3uVGHASwGLPq3gSFJ7tgJm2diza+bydJPTGOibin2steecKeOylE8oY2JERlVWkAJO6yw==",
+      "dev": true
+    },
+    "get-stream": {
+      "version": "2.3.1",
+      "resolved": "https://registry.npmjs.org/get-stream/-/get-stream-2.3.1.tgz",
+      "integrity": "sha1-Xzj5PzRgCWZu4BUKBUFn+Rvdld4=",
+      "requires": {
+        "object-assign": "^4.0.1",
+        "pinkie-promise": "^2.0.0"
+      }
+    },
+    "get-value": {
+      "version": "2.0.6",
+      "resolved": "https://registry.npmjs.org/get-value/-/get-value-2.0.6.tgz",
+      "integrity": "sha1-3BXKHGcjh8p2vTesCjlbogQqLCg="
+    },
+    "getos": {
+      "version": "2.8.4",
+      "resolved": "https://registry.npmjs.org/getos/-/getos-2.8.4.tgz",
+      "integrity": "sha1-e4YD02GcKOOMsP56T2PDrLgNUWM=",
+      "requires": {
+        "async": "2.1.4"
+      },
+      "dependencies": {
+        "async": {
+          "version": "2.1.4",
+          "resolved": "https://registry.npmjs.org/async/-/async-2.1.4.tgz",
+          "integrity": "sha1-LSFgx3iAMuTdbL4lAvH5osj2zeQ=",
+          "requires": {
+            "lodash": "^4.14.0"
+          }
+        }
+      }
+    },
+    "getpass": {
+      "version": "0.1.7",
+      "resolved": "https://registry.npmjs.org/getpass/-/getpass-0.1.7.tgz",
+      "integrity": "sha1-Xv+OPmhNVprkyysSgmBOi6YhSfo=",
+      "requires": {
+        "assert-plus": "^1.0.0"
+      }
+    },
+    "glob": {
+      "version": "7.1.3",
+      "resolved": "https://registry.npmjs.org/glob/-/glob-7.1.3.tgz",
+      "integrity": "sha512-vcfuiIxogLV4DlGBHIUOwI0IbrJ8HWPc4MU7HzviGeNho/UJDfi6B5p3sHeWIQ0KGIU0Jpxi5ZHxemQfLkkAwQ==",
+      "requires": {
+        "fs.realpath": "^1.0.0",
+        "inflight": "^1.0.4",
+        "inherits": "2",
+        "minimatch": "^3.0.4",
+        "once": "^1.3.0",
+        "path-is-absolute": "^1.0.0"
+      },
+      "dependencies": {
+        "minimatch": {
+          "version": "3.0.4",
+          "resolved": "https://registry.npmjs.org/minimatch/-/minimatch-3.0.4.tgz",
+          "integrity": "sha512-yJHVQEhyqPLUTgt9B83PXu6W3rx4MvvHvSUvToogpwoGDOUQ+yDrR0HRot+yOCdCO7u4hX3pWft6kWBBcqh0UA==",
+          "requires": {
+            "brace-expansion": "^1.1.7"
+          }
+        }
+      }
+    },
+    "glob-base": {
+      "version": "0.3.0",
+      "resolved": "https://registry.npmjs.org/glob-base/-/glob-base-0.3.0.tgz",
+      "integrity": "sha1-27Fk9iIbHAscz4Kuoyi0l98Oo8Q=",
+      "optional": true,
+      "requires": {
+        "glob-parent": "^2.0.0",
+        "is-glob": "^2.0.0"
+      }
+    },
+    "glob-parent": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/glob-parent/-/glob-parent-2.0.0.tgz",
+      "integrity": "sha1-gTg9ctsFT8zPUzbaqQLxgvbtuyg=",
+      "requires": {
+        "is-glob": "^2.0.0"
+      }
+    },
+    "glob-to-regexp": {
+      "version": "0.3.0",
+      "resolved": "https://registry.npmjs.org/glob-to-regexp/-/glob-to-regexp-0.3.0.tgz",
+      "integrity": "sha1-jFoUlNIGbFcMw7/kSWF1rMTVAqs="
+    },
+    "globals": {
+      "version": "9.18.0",
+      "resolved": "https://registry.npmjs.org/globals/-/globals-9.18.0.tgz",
+      "integrity": "sha512-S0nG3CLEQiY/ILxqtztTWH/3iRRdyBLw6KMDxnKMchrtbj2OFmehVh0WUCfW3DUrIgx/qFrJPICrq4Z4sTR9UQ=="
+    },
+    "globby": {
+      "version": "8.0.2",
+      "resolved": "https://registry.npmjs.org/globby/-/globby-8.0.2.tgz",
+      "integrity": "sha512-yTzMmKygLp8RUpG1Ymu2VXPSJQZjNAZPD4ywgYEaG7e4tBJeUQBO8OpXrf1RCNcEs5alsoJYPAMiIHP0cmeC7w==",
+      "requires": {
+        "array-union": "^1.0.1",
+        "dir-glob": "2.0.0",
+        "fast-glob": "^2.0.2",
+        "glob": "^7.1.2",
+        "ignore": "^3.3.5",
+        "pify": "^3.0.0",
+        "slash": "^1.0.0"
+      },
+      "dependencies": {
+        "pify": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/pify/-/pify-3.0.0.tgz",
+          "integrity": "sha1-5aSs0sEB/fPZpNB/DbxNtJ3SgXY="
+        }
+      }
+    },
+    "graceful-fs": {
+      "version": "4.1.15",
+      "resolved": "https://registry.npmjs.org/graceful-fs/-/graceful-fs-4.1.15.tgz",
+      "integrity": "sha512-6uHUhOPEBgQ24HM+r6b/QwWfZq+yiFcipKFrOFiBEnWdy5sdzYoi+pJeQaPI5qOLRFqWmAXUPQNsielzdLoecA=="
+    },
+    "graceful-readlink": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/graceful-readlink/-/graceful-readlink-1.0.1.tgz",
+      "integrity": "sha1-TK+tdrxi8C+gObL5Tpo906ORpyU="
+    },
+    "growl": {
+      "version": "1.10.5",
+      "resolved": "https://registry.npmjs.org/growl/-/growl-1.10.5.tgz",
+      "integrity": "sha512-qBr4OuELkhPenW6goKVXiv47US3clb3/IbuWF9KNKEijAy9oeHxU9IgzjvJhHkUzhaj7rOUD7+YGWqUjLp5oSA==",
+      "dev": true
+    },
+    "har-schema": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/har-schema/-/har-schema-2.0.0.tgz",
+      "integrity": "sha1-qUwiJOvKwEeCoNkDVSHyRzW37JI="
+    },
+    "har-validator": {
+      "version": "5.1.3",
+      "resolved": "https://registry.npmjs.org/har-validator/-/har-validator-5.1.3.tgz",
+      "integrity": "sha512-sNvOCzEQNr/qrvJgc3UG/kD4QtlHycrzwS+6mfTrrSq97BvaYcPZZI1ZSqGSPR73Cxn4LKTD4PttRwfU7jWq5g==",
+      "requires": {
+        "ajv": "^6.5.5",
+        "har-schema": "^2.0.0"
+      }
+    },
+    "has": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/has/-/has-1.0.3.tgz",
+      "integrity": "sha512-f2dvO0VU6Oej7RkWJGrehjbzMAjFp5/VKPp5tTpWIV4JHHZK1/BxbFRtf/siA2SWTe09caDmVtYYzWEIbBS4zw==",
+      "dev": true,
+      "requires": {
+        "function-bind": "^1.1.1"
+      }
+    },
+    "has-ansi": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/has-ansi/-/has-ansi-2.0.0.tgz",
+      "integrity": "sha1-NPUEnOHs3ysGSa8+8k5F7TVBbZE=",
+      "requires": {
+        "ansi-regex": "^2.0.0"
+      }
+    },
+    "has-binary2": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/has-binary2/-/has-binary2-1.0.3.tgz",
+      "integrity": "sha512-G1LWKhDSvhGeAQ8mPVQlqNcOB2sJdwATtZKl2pDKKHfpf/rYj24lkinxf69blJbnsvtqqNU+L3SL50vzZhXOnw==",
+      "requires": {
+        "isarray": "2.0.1"
+      },
+      "dependencies": {
+        "isarray": {
+          "version": "2.0.1",
+          "resolved": "https://registry.npmjs.org/isarray/-/isarray-2.0.1.tgz",
+          "integrity": "sha1-o32U7ZzaLVmGXJ92/llu4fM4dB4="
+        }
+      }
+    },
+    "has-cors": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/has-cors/-/has-cors-1.1.0.tgz",
+      "integrity": "sha1-XkdHk/fqmEPRu5nCPu9J/xJv/zk="
+    },
+    "has-flag": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/has-flag/-/has-flag-3.0.0.tgz",
+      "integrity": "sha1-tdRU3CGZriJWmfNGfloH87lVuv0="
+    },
+    "has-symbols": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/has-symbols/-/has-symbols-1.0.0.tgz",
+      "integrity": "sha1-uhqPGvKg/DllD1yFA2dwQSIGO0Q=",
+      "dev": true
+    },
+    "has-value": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/has-value/-/has-value-1.0.0.tgz",
+      "integrity": "sha1-GLKB2lhbHFxR3vJMkw7SmgvmsXc=",
+      "requires": {
+        "get-value": "^2.0.6",
+        "has-values": "^1.0.0",
+        "isobject": "^3.0.0"
+      },
+      "dependencies": {
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        }
+      }
+    },
+    "has-values": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/has-values/-/has-values-1.0.0.tgz",
+      "integrity": "sha1-lbC2P+whRmGab+V/51Yo1aOe/k8=",
+      "requires": {
+        "is-number": "^3.0.0",
+        "kind-of": "^4.0.0"
+      },
+      "dependencies": {
+        "is-number": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/is-number/-/is-number-3.0.0.tgz",
+          "integrity": "sha1-JP1iAaR4LPUFYcgQJ2r8fRLXEZU=",
+          "requires": {
+            "kind-of": "^3.0.2"
+          },
+          "dependencies": {
+            "kind-of": {
+              "version": "3.2.2",
+              "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-3.2.2.tgz",
+              "integrity": "sha1-MeohpzS6ubuw8yRm2JOupR5KPGQ=",
+              "requires": {
+                "is-buffer": "^1.1.5"
+              }
+            }
+          }
+        },
+        "kind-of": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-4.0.0.tgz",
+          "integrity": "sha1-IIE989cSkosgc3hpGkUGb65y3Vc=",
+          "requires": {
+            "is-buffer": "^1.1.5"
+          }
+        }
+      }
+    },
+    "he": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/he/-/he-1.2.0.tgz",
+      "integrity": "sha512-F/1DnUGPopORZi0ni+CvrCgHQ5FyEAHRLSApuYWMmrbSwoN2Mn/7k+Gl38gJnR7yyDZk6WLXwiGod1JOWNDKGw==",
+      "dev": true
+    },
+    "home-or-tmp": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/home-or-tmp/-/home-or-tmp-2.0.0.tgz",
+      "integrity": "sha1-42w/LSyufXRqhX440Y1fMqeILbg=",
+      "requires": {
+        "os-homedir": "^1.0.0",
+        "os-tmpdir": "^1.0.1"
+      }
+    },
+    "hosted-git-info": {
+      "version": "2.7.1",
+      "resolved": "https://registry.npmjs.org/hosted-git-info/-/hosted-git-info-2.7.1.tgz",
+      "integrity": "sha512-7T/BxH19zbcCTa8XkMlbK5lTo1WtgkFi3GvdWEyNuc4Vex7/9Dqbnpsf4JMydcfj9HCg4zUWFTL3Za6lapg5/w=="
+    },
+    "http-errors": {
+      "version": "1.7.2",
+      "resolved": "https://registry.npmjs.org/http-errors/-/http-errors-1.7.2.tgz",
+      "integrity": "sha512-uUQBt3H/cSIVfch6i1EuPNy/YsRSOUBXTVfZ+yR7Zjez3qjBz6i9+i4zjNaoqcoFVI4lQJ5plg63TvGfRSDCRg==",
+      "requires": {
+        "depd": "~1.1.2",
+        "inherits": "2.0.3",
+        "setprototypeof": "1.1.1",
+        "statuses": ">= 1.5.0 < 2",
+        "toidentifier": "1.0.0"
+      }
+    },
+    "http-signature": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/http-signature/-/http-signature-1.2.0.tgz",
+      "integrity": "sha1-muzZJRFHcvPZW2WmCruPfBj7rOE=",
+      "requires": {
+        "assert-plus": "^1.0.0",
+        "jsprim": "^1.2.2",
+        "sshpk": "^1.7.0"
+      }
+    },
+    "https-proxy-agent": {
+      "version": "2.2.1",
+      "resolved": "https://registry.npmjs.org/https-proxy-agent/-/https-proxy-agent-2.2.1.tgz",
+      "integrity": "sha512-HPCTS1LW51bcyMYbxUIOO4HEOlQ1/1qRaFWcyxvwaqUS9TY88aoEuHUY33kuAh1YhVVaDQhLZsnPd+XNARWZlQ==",
+      "dev": true,
+      "requires": {
+        "agent-base": "^4.1.0",
+        "debug": "^3.1.0"
+      },
+      "dependencies": {
+        "debug": {
+          "version": "3.2.6",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.2.6.tgz",
+          "integrity": "sha512-mel+jf7nrtEl5Pn1Qx46zARXKDpBbvzezse7p7LqINmdoIk8PYP5SySaxEmYv6TZ0JyEKA1hsCId6DIhgITtWQ==",
+          "dev": true,
+          "requires": {
+            "ms": "^2.1.1"
+          }
+        },
+        "ms": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/ms/-/ms-2.1.1.tgz",
+          "integrity": "sha512-tgp+dl5cGk28utYktBsrFqA7HKgrhgPsg6Z/EfhWI4gl1Hwq8B/GmY/0oXZ6nF8hDVesS/FpnYaD/kOWhYQvyg==",
+          "dev": true
+        }
+      }
+    },
+    "iconv-lite": {
+      "version": "0.4.24",
+      "resolved": "https://registry.npmjs.org/iconv-lite/-/iconv-lite-0.4.24.tgz",
+      "integrity": "sha512-v3MXnZAcvnywkTUEZomIActle7RXXeedOR31wwl7VlyoXO4Qi9arvSenNQWne1TcRwhCL1HwLI21bEqdpj8/rA==",
+      "requires": {
+        "safer-buffer": ">= 2.1.2 < 3"
+      }
+    },
+    "ieee754": {
+      "version": "1.1.13",
+      "resolved": "https://registry.npmjs.org/ieee754/-/ieee754-1.1.13.tgz",
+      "integrity": "sha512-4vf7I2LYV/HaWerSo3XmlMkp5eZ83i+/CDluXi/IGTs/O1sejBNhTtnxzmRZfvOUqj7lZjqHkeTvpgSFDlWZTg=="
+    },
+    "ignore": {
+      "version": "3.3.10",
+      "resolved": "https://registry.npmjs.org/ignore/-/ignore-3.3.10.tgz",
+      "integrity": "sha512-Pgs951kaMm5GXP7MOvxERINe3gsaVjUWFm+UZPSq9xYriQAksyhg0csnS0KXSNRD5NmNdapXEpjxG49+AKh/ug=="
+    },
+    "immediate": {
+      "version": "3.0.6",
+      "resolved": "https://registry.npmjs.org/immediate/-/immediate-3.0.6.tgz",
+      "integrity": "sha1-nbHb0Pr43m++D13V5Wu2BigN5ps="
+    },
+    "import-fresh": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/import-fresh/-/import-fresh-3.0.0.tgz",
+      "integrity": "sha512-pOnA9tfM3Uwics+SaBLCNyZZZbK+4PTu0OPZtLlMIrv17EdBoC15S9Kn8ckJ9TZTyKb3ywNE5y1yeDxxGA7nTQ==",
+      "dev": true,
+      "requires": {
+        "parent-module": "^1.0.0",
+        "resolve-from": "^4.0.0"
+      },
+      "dependencies": {
+        "resolve-from": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/resolve-from/-/resolve-from-4.0.0.tgz",
+          "integrity": "sha512-pb/MYmXstAkysRFx8piNI1tGFNQIFA3vkE3Gq4EuA1dF6gHp/+vgZqsCGJapvy8N3Q+4o7FwvquPJcnZ7RYy4g==",
+          "dev": true
+        }
+      }
+    },
+    "imurmurhash": {
+      "version": "0.1.4",
+      "resolved": "https://registry.npmjs.org/imurmurhash/-/imurmurhash-0.1.4.tgz",
+      "integrity": "sha1-khi5srkoojixPcT7a21XbyMUU+o=",
+      "dev": true
+    },
+    "in-publish": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/in-publish/-/in-publish-2.0.0.tgz",
+      "integrity": "sha1-4g/146KvwmkDILbcVSaCqcf631E="
+    },
+    "indexof": {
+      "version": "0.0.1",
+      "resolved": "https://registry.npmjs.org/indexof/-/indexof-0.0.1.tgz",
+      "integrity": "sha1-gtwzbSMrkGIXnQWrMpOmYFn9Q10="
+    },
+    "inflight": {
+      "version": "1.0.6",
+      "resolved": "https://registry.npmjs.org/inflight/-/inflight-1.0.6.tgz",
+      "integrity": "sha1-Sb1jMdfQLQwJvJEKEHW6gWW1bfk=",
+      "requires": {
+        "once": "^1.3.0",
+        "wrappy": "1"
+      }
+    },
+    "inherits": {
+      "version": "2.0.3",
+      "resolved": "https://registry.npmjs.org/inherits/-/inherits-2.0.3.tgz",
+      "integrity": "sha1-Yzwsg+PaQqUC9SRmAiSA9CCCYd4="
+    },
+    "ini": {
+      "version": "1.3.5",
+      "resolved": "https://registry.npmjs.org/ini/-/ini-1.3.5.tgz",
+      "integrity": "sha512-RZY5huIKCMRWDUqZlEi72f/lmXKMvuszcMBduliQ3nnWbx9X/ZBQO7DijMEYS9EhHBb2qacRUMtC7svLwe0lcw=="
+    },
+    "inquirer": {
+      "version": "0.12.0",
+      "resolved": "https://registry.npmjs.org/inquirer/-/inquirer-0.12.0.tgz",
+      "integrity": "sha1-HvK/1jUE3wvHV4X/+MLEHfEvB34=",
+      "requires": {
+        "ansi-escapes": "^1.1.0",
+        "ansi-regex": "^2.0.0",
+        "chalk": "^1.0.0",
+        "cli-cursor": "^1.0.1",
+        "cli-width": "^2.0.0",
+        "figures": "^1.3.5",
+        "lodash": "^4.3.0",
+        "readline2": "^1.0.1",
+        "run-async": "^0.1.0",
+        "rx-lite": "^3.1.2",
+        "string-width": "^1.0.1",
+        "strip-ansi": "^3.0.0",
+        "through": "^2.3.6"
+      }
+    },
+    "into-stream": {
+      "version": "4.0.0",
+      "resolved": "https://registry.npmjs.org/into-stream/-/into-stream-4.0.0.tgz",
+      "integrity": "sha512-i29KNyE5r0Y/UQzcQ0IbZO1MYJ53Jn0EcFRZPj5FzWKYH17kDFEOwuA+3jroymOI06SW1dEDnly9A1CAreC5dg==",
+      "requires": {
+        "from2": "^2.1.1",
+        "p-is-promise": "^2.0.0"
+      }
+    },
+    "invariant": {
+      "version": "2.2.4",
+      "resolved": "https://registry.npmjs.org/invariant/-/invariant-2.2.4.tgz",
+      "integrity": "sha512-phJfQVBuaJM5raOpJjSfkiD6BpbCE4Ns//LaXl6wGYtUBY83nWS6Rf9tXm2e8VaK60JEjYldbPif/A2B1C2gNA==",
+      "requires": {
+        "loose-envify": "^1.0.0"
+      }
+    },
+    "invert-kv": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-1.0.0.tgz",
+      "integrity": "sha1-EEqOSqym09jNFXqO+L+rLXo//bY="
+    },
+    "ipaddr.js": {
+      "version": "1.9.0",
+      "resolved": "https://registry.npmjs.org/ipaddr.js/-/ipaddr.js-1.9.0.tgz",
+      "integrity": "sha512-M4Sjn6N/+O6/IXSJseKqHoFc+5FdGJ22sXqnjTpdZweHK64MzEPAyQZyEU3R/KRv2GLoa7nNtg/C2Ev6m7z+eA=="
+    },
+    "is-accessor-descriptor": {
+      "version": "0.1.6",
+      "resolved": "https://registry.npmjs.org/is-accessor-descriptor/-/is-accessor-descriptor-0.1.6.tgz",
+      "integrity": "sha1-qeEss66Nh2cn7u84Q/igiXtcmNY=",
+      "requires": {
+        "kind-of": "^3.0.2"
+      }
+    },
+    "is-arrayish": {
+      "version": "0.2.1",
+      "resolved": "https://registry.npmjs.org/is-arrayish/-/is-arrayish-0.2.1.tgz",
+      "integrity": "sha1-d8mYQFJ6qOyxqLppe4BkWnqSap0="
+    },
+    "is-binary-path": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/is-binary-path/-/is-binary-path-1.0.1.tgz",
+      "integrity": "sha1-dfFmQrSA8YenEcgUFh/TpKdlWJg=",
+      "optional": true,
+      "requires": {
+        "binary-extensions": "^1.0.0"
+      }
+    },
+    "is-buffer": {
+      "version": "1.1.6",
+      "resolved": "https://registry.npmjs.org/is-buffer/-/is-buffer-1.1.6.tgz",
+      "integrity": "sha512-NcdALwpXkTm5Zvvbk7owOUSvVvBKDgKP5/ewfXEznmQFfs4ZRmanOeKBTjRVjka3QFoN6XJ+9F3USqfHqTaU5w=="
+    },
+    "is-callable": {
+      "version": "1.1.4",
+      "resolved": "https://registry.npmjs.org/is-callable/-/is-callable-1.1.4.tgz",
+      "integrity": "sha512-r5p9sxJjYnArLjObpjA4xu5EKI3CuKHkJXMhT7kwbpUyIFD1n5PMAsoPvWnvtZiNz7LjkYDRZhd7FlI0eMijEA==",
+      "dev": true
+    },
+    "is-data-descriptor": {
+      "version": "0.1.4",
+      "resolved": "https://registry.npmjs.org/is-data-descriptor/-/is-data-descriptor-0.1.4.tgz",
+      "integrity": "sha1-C17mSDiOLIYCgueT8YVv7D8wG1Y=",
+      "requires": {
+        "kind-of": "^3.0.2"
+      }
+    },
+    "is-date-object": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/is-date-object/-/is-date-object-1.0.1.tgz",
+      "integrity": "sha1-mqIOtq7rv/d/vTPnTKAbM1gdOhY=",
+      "dev": true
+    },
+    "is-descriptor": {
+      "version": "0.1.6",
+      "resolved": "https://registry.npmjs.org/is-descriptor/-/is-descriptor-0.1.6.tgz",
+      "integrity": "sha512-avDYr0SB3DwO9zsMov0gKCESFYqCnE4hq/4z3TdUlukEy5t9C0YRq7HLrsN52NAcqXKaepeCD0n+B0arnVG3Hg==",
+      "requires": {
+        "is-accessor-descriptor": "^0.1.6",
+        "is-data-descriptor": "^0.1.4",
+        "kind-of": "^5.0.0"
+      },
+      "dependencies": {
+        "kind-of": {
+          "version": "5.1.0",
+          "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-5.1.0.tgz",
+          "integrity": "sha512-NGEErnH6F2vUuXDh+OlbcKW7/wOcfdRHaZ7VWtqCztfHri/++YKmP51OdWeGPuqCOba6kk2OTe5d02VmTB80Pw=="
+        }
+      }
+    },
+    "is-dotfile": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/is-dotfile/-/is-dotfile-1.0.3.tgz",
+      "integrity": "sha1-pqLzL/0t+wT1yiXs0Pa4PPeYoeE=",
+      "optional": true
+    },
+    "is-equal-shallow": {
+      "version": "0.1.3",
+      "resolved": "https://registry.npmjs.org/is-equal-shallow/-/is-equal-shallow-0.1.3.tgz",
+      "integrity": "sha1-IjgJj8Ih3gvPpdnqxMRdY4qhxTQ=",
+      "optional": true,
+      "requires": {
+        "is-primitive": "^2.0.0"
+      }
+    },
+    "is-extendable": {
+      "version": "0.1.1",
+      "resolved": "https://registry.npmjs.org/is-extendable/-/is-extendable-0.1.1.tgz",
+      "integrity": "sha1-YrEQ4omkcUGOPsNqYX1HLjAd/Ik="
+    },
+    "is-extglob": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/is-extglob/-/is-extglob-1.0.0.tgz",
+      "integrity": "sha1-rEaBd8SUNAWgkvyPKXYMb/xiBsA="
+    },
+    "is-finite": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/is-finite/-/is-finite-1.0.2.tgz",
+      "integrity": "sha1-zGZ3aVYCvlUO8R6LSqYwU0K20Ko=",
+      "requires": {
+        "number-is-nan": "^1.0.0"
+      }
+    },
+    "is-fullwidth-code-point": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-1.0.0.tgz",
+      "integrity": "sha1-754xOG8DGn8NZDr4L95QxFfvAMs=",
+      "requires": {
+        "number-is-nan": "^1.0.0"
+      }
+    },
+    "is-glob": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/is-glob/-/is-glob-2.0.1.tgz",
+      "integrity": "sha1-0Jb5JqPe1WAPP9/ZEZjLCIjC2GM=",
+      "requires": {
+        "is-extglob": "^1.0.0"
+      }
+    },
+    "is-natural-number": {
+      "version": "4.0.1",
+      "resolved": "https://registry.npmjs.org/is-natural-number/-/is-natural-number-4.0.1.tgz",
+      "integrity": "sha1-q5124dtM7VHjXeDHLr7PCfc0zeg="
+    },
+    "is-number": {
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/is-number/-/is-number-2.1.0.tgz",
+      "integrity": "sha1-Afy7s5NGOlSPL0ZszhbezknbkI8=",
+      "optional": true,
+      "requires": {
+        "kind-of": "^3.0.2"
+      }
+    },
+    "is-plain-object": {
+      "version": "2.0.4",
+      "resolved": "https://registry.npmjs.org/is-plain-object/-/is-plain-object-2.0.4.tgz",
+      "integrity": "sha512-h5PpgXkWitc38BBMYawTYMWJHFZJVnBquFE57xFpjB8pJFiF6gZ+bU+WyI/yqXiFR5mdLsgYNaPe8uao6Uv9Og==",
+      "requires": {
+        "isobject": "^3.0.1"
+      },
+      "dependencies": {
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        }
+      }
+    },
+    "is-posix-bracket": {
+      "version": "0.1.1",
+      "resolved": "https://registry.npmjs.org/is-posix-bracket/-/is-posix-bracket-0.1.1.tgz",
+      "integrity": "sha1-MzTceXdDaOkvAW5vvAqI9c1ua8Q=",
+      "optional": true
+    },
+    "is-primitive": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/is-primitive/-/is-primitive-2.0.0.tgz",
+      "integrity": "sha1-IHurkWOEmcB7Kt8kCkGochADRXU=",
+      "optional": true
+    },
+    "is-promise": {
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/is-promise/-/is-promise-2.1.0.tgz",
+      "integrity": "sha1-eaKp7OfwlugPNtKy87wWwf9L8/o=",
+      "dev": true
+    },
+    "is-regex": {
+      "version": "1.0.4",
+      "resolved": "https://registry.npmjs.org/is-regex/-/is-regex-1.0.4.tgz",
+      "integrity": "sha1-VRdIm1RwkbCTDglWVM7SXul+lJE=",
+      "dev": true,
+      "requires": {
+        "has": "^1.0.1"
+      }
+    },
+    "is-stream": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/is-stream/-/is-stream-1.1.0.tgz",
+      "integrity": "sha1-EtSj3U5o4Lec6428hBc66A2RykQ="
+    },
+    "is-symbol": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/is-symbol/-/is-symbol-1.0.2.tgz",
+      "integrity": "sha512-HS8bZ9ox60yCJLH9snBpIwv9pYUAkcuLhSA1oero1UB5y9aiQpRA8y2ex945AOtCZL1lJDeIk3G5LthswI46Lw==",
+      "dev": true,
+      "requires": {
+        "has-symbols": "^1.0.0"
+      }
+    },
+    "is-typedarray": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/is-typedarray/-/is-typedarray-1.0.0.tgz",
+      "integrity": "sha1-5HnICFjfDBsR3dppQPlgEfzaSpo="
+    },
+    "is-utf8": {
+      "version": "0.2.1",
+      "resolved": "https://registry.npmjs.org/is-utf8/-/is-utf8-0.2.1.tgz",
+      "integrity": "sha1-Sw2hRCEE0bM2NA6AeX6GXPOffXI="
+    },
+    "is-windows": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/is-windows/-/is-windows-1.0.2.tgz",
+      "integrity": "sha512-eXK1UInq2bPmjyX6e3VHIzMLobc4J94i4AWn+Hpq3OU5KkrRC96OAcR3PRJ/pGu6m8TRnBHP9dkXQVsT/COVIA=="
+    },
+    "isarray": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/isarray/-/isarray-1.0.0.tgz",
+      "integrity": "sha1-u5NdSFgsuhaMBoNJV6VKPgcSTxE="
+    },
+    "isexe": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/isexe/-/isexe-2.0.0.tgz",
+      "integrity": "sha1-6PvzdNxVb/iUehDcsFctYz8s+hA=",
+      "dev": true
+    },
+    "isobject": {
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/isobject/-/isobject-2.1.0.tgz",
+      "integrity": "sha1-8GVWEJaj8dou9GJy+BXIQNh+DIk=",
+      "optional": true,
+      "requires": {
+        "isarray": "1.0.0"
+      }
+    },
+    "isstream": {
+      "version": "0.1.2",
+      "resolved": "https://registry.npmjs.org/isstream/-/isstream-0.1.2.tgz",
+      "integrity": "sha1-R+Y/evVa+m+S4VAOaQ64uFKcCZo="
+    },
+    "js-tokens": {
+      "version": "3.0.2",
+      "resolved": "https://registry.npmjs.org/js-tokens/-/js-tokens-3.0.2.tgz",
+      "integrity": "sha1-mGbfOVECEw449/mWvOtlRDIJwls="
+    },
+    "js-yaml": {
+      "version": "3.13.1",
+      "resolved": "https://registry.npmjs.org/js-yaml/-/js-yaml-3.13.1.tgz",
+      "integrity": "sha512-YfbcO7jXDdyj0DGxYVSlSeQNHbD7XPWvrVWeVUujrQEoZzWJIRrCPoyk6kL6IAjAG2IolMK4T0hNUe0HOUs5Jw==",
+      "dev": true,
+      "requires": {
+        "argparse": "^1.0.7",
+        "esprima": "^4.0.0"
+      },
+      "dependencies": {
+        "esprima": {
+          "version": "4.0.1",
+          "resolved": "https://registry.npmjs.org/esprima/-/esprima-4.0.1.tgz",
+          "integrity": "sha512-eGuFFw7Upda+g4p+QHvnW0RyTX/SVeJBDM/gCtMARO0cLuT2HcEKnTPvhjV6aGeqrCB/sbNop0Kszm0jsaWU4A==",
+          "dev": true
+        }
+      }
+    },
+    "jsbn": {
+      "version": "0.1.1",
+      "resolved": "https://registry.npmjs.org/jsbn/-/jsbn-0.1.1.tgz",
+      "integrity": "sha1-peZUwuWi3rXyAdls77yoDA7y9RM="
+    },
+    "jsesc": {
+      "version": "1.3.0",
+      "resolved": "https://registry.npmjs.org/jsesc/-/jsesc-1.3.0.tgz",
+      "integrity": "sha1-RsP+yMGJKxKwgz25vHYiF226s0s="
+    },
+    "json-schema": {
+      "version": "0.2.3",
+      "resolved": "https://registry.npmjs.org/json-schema/-/json-schema-0.2.3.tgz",
+      "integrity": "sha1-tIDIkuWaLwWVTOcnvT8qTogvnhM="
+    },
+    "json-schema-traverse": {
+      "version": "0.4.1",
+      "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.4.1.tgz",
+      "integrity": "sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg=="
+    },
+    "json-stable-stringify-without-jsonify": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/json-stable-stringify-without-jsonify/-/json-stable-stringify-without-jsonify-1.0.1.tgz",
+      "integrity": "sha1-nbe1lJatPzz+8wp1FC0tkwrXJlE=",
+      "dev": true
+    },
+    "json-stringify-safe": {
+      "version": "5.0.1",
+      "resolved": "https://registry.npmjs.org/json-stringify-safe/-/json-stringify-safe-5.0.1.tgz",
+      "integrity": "sha1-Epai1Y/UXxmg9s4B1lcB4sc1tus="
+    },
+    "json5": {
+      "version": "0.5.1",
+      "resolved": "https://registry.npmjs.org/json5/-/json5-0.5.1.tgz",
+      "integrity": "sha1-Hq3nrMASA0rYTiOWdn6tn6VJWCE="
+    },
+    "jsonfile": {
+      "version": "2.4.0",
+      "resolved": "https://registry.npmjs.org/jsonfile/-/jsonfile-2.4.0.tgz",
+      "integrity": "sha1-NzaitCi4e72gzIO1P6PWM6NcKug=",
+      "requires": {
+        "graceful-fs": "^4.1.6"
+      }
+    },
+    "jsprim": {
+      "version": "1.4.1",
+      "resolved": "https://registry.npmjs.org/jsprim/-/jsprim-1.4.1.tgz",
+      "integrity": "sha1-MT5mvB5cwG5Di8G3SZwuXFastqI=",
+      "requires": {
+        "assert-plus": "1.0.0",
+        "extsprintf": "1.3.0",
+        "json-schema": "0.2.3",
+        "verror": "1.10.0"
+      }
+    },
+    "jszip": {
+      "version": "3.2.1",
+      "resolved": "https://registry.npmjs.org/jszip/-/jszip-3.2.1.tgz",
+      "integrity": "sha512-iCMBbo4eE5rb1VCpm5qXOAaUiRKRUKiItn8ah2YQQx9qymmSAY98eyQfioChEYcVQLh0zxJ3wS4A0mh90AVPvw==",
+      "requires": {
+        "lie": "~3.3.0",
+        "pako": "~1.0.2",
+        "readable-stream": "~2.3.6",
+        "set-immediate-shim": "~1.0.1"
+      }
+    },
+    "kareem": {
+      "version": "2.3.0",
+      "resolved": "https://registry.npmjs.org/kareem/-/kareem-2.3.0.tgz",
+      "integrity": "sha512-6hHxsp9e6zQU8nXsP+02HGWXwTkOEw6IROhF2ZA28cYbUk4eJ6QbtZvdqZOdD9YPKghG3apk5eOCvs+tLl3lRg=="
+    },
+    "kind-of": {
+      "version": "3.2.2",
+      "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-3.2.2.tgz",
+      "integrity": "sha1-MeohpzS6ubuw8yRm2JOupR5KPGQ=",
+      "requires": {
+        "is-buffer": "^1.1.5"
+      }
+    },
+    "lcid": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/lcid/-/lcid-1.0.0.tgz",
+      "integrity": "sha1-MIrMr6C8SDo4Z7S28rlQYlHRuDU=",
+      "requires": {
+        "invert-kv": "^1.0.0"
+      }
+    },
+    "levn": {
+      "version": "0.3.0",
+      "resolved": "https://registry.npmjs.org/levn/-/levn-0.3.0.tgz",
+      "integrity": "sha1-OwmSTt+fCDwEkP3UwLxEIeBHZO4=",
+      "requires": {
+        "prelude-ls": "~1.1.2",
+        "type-check": "~0.3.2"
+      }
+    },
+    "lie": {
+      "version": "3.3.0",
+      "resolved": "https://registry.npmjs.org/lie/-/lie-3.3.0.tgz",
+      "integrity": "sha512-UaiMJzeWRlEujzAuw5LokY1L5ecNQYZKfmyZ9L7wDHb/p5etKaxXhohBcrw0EYby+G/NA52vRSN4N39dxHAIwQ==",
+      "requires": {
+        "immediate": "~3.0.5"
+      }
+    },
+    "load-json-file": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/load-json-file/-/load-json-file-1.1.0.tgz",
+      "integrity": "sha1-lWkFcI1YtLq0wiYbBPWfMcmTdMA=",
+      "requires": {
+        "graceful-fs": "^4.1.2",
+        "parse-json": "^2.2.0",
+        "pify": "^2.0.0",
+        "pinkie-promise": "^2.0.0",
+        "strip-bom": "^2.0.0"
+      }
+    },
+    "locate-path": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/locate-path/-/locate-path-3.0.0.tgz",
+      "integrity": "sha512-7AO748wWnIhNqAuaty2ZWHkQHRSNfPVIsPIfwEOWO22AmaoVrWavlOcMR5nzTLNYvp36X220/maaRsrec1G65A==",
+      "dev": true,
+      "requires": {
+        "p-locate": "^3.0.0",
+        "path-exists": "^3.0.0"
+      },
+      "dependencies": {
+        "path-exists": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/path-exists/-/path-exists-3.0.0.tgz",
+          "integrity": "sha1-zg6+ql94yxiSXqfYENe1mwEP1RU=",
+          "dev": true
+        }
+      }
+    },
+    "lockfile": {
+      "version": "1.0.4",
+      "resolved": "https://registry.npmjs.org/lockfile/-/lockfile-1.0.4.tgz",
+      "integrity": "sha512-cvbTwETRfsFh4nHsL1eGWapU1XFi5Ot9E85sWAwia7Y7EgB7vfqcZhTKZ+l7hCGxSPoushMv5GKhT5PdLv03WA==",
+      "dev": true,
+      "requires": {
+        "signal-exit": "^3.0.2"
+      }
+    },
+    "lodash": {
+      "version": "4.17.11",
+      "resolved": "https://registry.npmjs.org/lodash/-/lodash-4.17.11.tgz",
+      "integrity": "sha512-cQKh8igo5QUhZ7lg38DYWAxMvjSAKG0A8wGSVimP07SIUEK2UO+arSRKbRZWtelMtN5V0Hkwh5ryOto/SshYIg=="
+    },
+    "lodash.assign": {
+      "version": "4.2.0",
+      "resolved": "https://registry.npmjs.org/lodash.assign/-/lodash.assign-4.2.0.tgz",
+      "integrity": "sha1-DZnzzNem0mHRm9rrkkUAXShYCOc="
+    },
+    "lodash.clonedeep": {
+      "version": "4.5.0",
+      "resolved": "https://registry.npmjs.org/lodash.clonedeep/-/lodash.clonedeep-4.5.0.tgz",
+      "integrity": "sha1-4j8/nE+Pvd6HJSnBBxhXoIblzO8="
+    },
+    "lodash.set": {
+      "version": "4.3.2",
+      "resolved": "https://registry.npmjs.org/lodash.set/-/lodash.set-4.3.2.tgz",
+      "integrity": "sha1-2HV7HagH3eJIFrDWqEvqGnYjCyM="
+    },
+    "lodash.unset": {
+      "version": "4.5.2",
+      "resolved": "https://registry.npmjs.org/lodash.unset/-/lodash.unset-4.5.2.tgz",
+      "integrity": "sha1-Nw0dPoW3Kn4bDN8tJyEhMG8j5O0="
+    },
+    "log-symbols": {
+      "version": "2.2.0",
+      "resolved": "https://registry.npmjs.org/log-symbols/-/log-symbols-2.2.0.tgz",
+      "integrity": "sha512-VeIAFslyIerEJLXHziedo2basKbMKtTw3vfn5IzG0XTjhAVEJyNHnL2p7vc+wBDSdQuUpNw3M2u6xb9QsAY5Eg==",
+      "dev": true,
+      "requires": {
+        "chalk": "^2.0.1"
+      },
+      "dependencies": {
+        "ansi-styles": {
+          "version": "3.2.1",
+          "resolved": "https://registry.npmjs.org/ansi-styles/-/ansi-styles-3.2.1.tgz",
+          "integrity": "sha512-VT0ZI6kZRdTh8YyJw3SMbYm/u+NqfsAxEpWO0Pf9sq8/e94WxxOpPKx9FR1FlyCtOVDNOQ+8ntlqFxiRc+r5qA==",
+          "dev": true,
+          "requires": {
+            "color-convert": "^1.9.0"
+          }
+        },
+        "chalk": {
+          "version": "2.4.2",
+          "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.4.2.tgz",
+          "integrity": "sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==",
+          "dev": true,
+          "requires": {
+            "ansi-styles": "^3.2.1",
+            "escape-string-regexp": "^1.0.5",
+            "supports-color": "^5.3.0"
+          }
+        },
+        "supports-color": {
+          "version": "5.5.0",
+          "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-5.5.0.tgz",
+          "integrity": "sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==",
+          "dev": true,
+          "requires": {
+            "has-flag": "^3.0.0"
+          }
+        }
+      }
+    },
+    "loose-envify": {
+      "version": "1.4.0",
+      "resolved": "https://registry.npmjs.org/loose-envify/-/loose-envify-1.4.0.tgz",
+      "integrity": "sha512-lyuxPGr/Wfhrlem2CL/UcnUc1zcqKAImBDzukY7Y5F/yQiNdko6+fRLevlw1HgMySw7f611UIY408EtxRSoK3Q==",
+      "requires": {
+        "js-tokens": "^3.0.0 || ^4.0.0"
+      }
+    },
+    "lru-cache": {
+      "version": "2.7.3",
+      "resolved": "https://registry.npmjs.org/lru-cache/-/lru-cache-2.7.3.tgz",
+      "integrity": "sha1-bUUk6LlV+V1PW1iFHOId1y+06VI="
+    },
+    "make-dir": {
+      "version": "1.3.0",
+      "resolved": "https://registry.npmjs.org/make-dir/-/make-dir-1.3.0.tgz",
+      "integrity": "sha512-2w31R7SJtieJJnQtGc7RVL2StM2vGYVfqUOvUDxH6bC6aJTxPxTF0GnIgCyu7tjockiUWAYQRbxa7vKn34s5sQ==",
+      "requires": {
+        "pify": "^3.0.0"
+      },
+      "dependencies": {
+        "pify": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/pify/-/pify-3.0.0.tgz",
+          "integrity": "sha1-5aSs0sEB/fPZpNB/DbxNtJ3SgXY="
+        }
+      }
+    },
+    "make-error": {
+      "version": "1.3.5",
+      "resolved": "https://registry.npmjs.org/make-error/-/make-error-1.3.5.tgz",
+      "integrity": "sha512-c3sIjNUow0+8swNwVpqoH4YCShKNFkMaw6oH1mNS2haDZQqkeZFlHS3dhoeEbKKmJB4vXpJucU6oH75aDYeE9g=="
+    },
+    "map-age-cleaner": {
+      "version": "0.1.3",
+      "resolved": "https://registry.npmjs.org/map-age-cleaner/-/map-age-cleaner-0.1.3.tgz",
+      "integrity": "sha512-bJzx6nMoP6PDLPBFmg7+xRKeFZvFboMrGlxmNj9ClvX53KrmvM5bXFXEWjbz4cz1AFn+jWJ9z/DJSz7hrs0w3w==",
+      "dev": true,
+      "requires": {
+        "p-defer": "^1.0.0"
+      }
+    },
+    "map-cache": {
+      "version": "0.2.2",
+      "resolved": "https://registry.npmjs.org/map-cache/-/map-cache-0.2.2.tgz",
+      "integrity": "sha1-wyq9C9ZSXZsFFkW7TyasXcmKDb8="
+    },
+    "map-visit": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/map-visit/-/map-visit-1.0.0.tgz",
+      "integrity": "sha1-7Nyo8TFE5mDxtb1B8S80edmN+48=",
+      "requires": {
+        "object-visit": "^1.0.0"
+      }
+    },
+    "math-random": {
+      "version": "1.0.4",
+      "resolved": "https://registry.npmjs.org/math-random/-/math-random-1.0.4.tgz",
+      "integrity": "sha512-rUxjysqif/BZQH2yhd5Aaq7vXMSx9NdEsQcyA07uEzIvxgI7zIr33gGsh+RU0/XjmQpCW7RsVof1vlkvQVCK5A==",
+      "optional": true
+    },
+    "md5-file": {
+      "version": "3.1.1",
+      "resolved": "https://registry.npmjs.org/md5-file/-/md5-file-3.1.1.tgz",
+      "integrity": "sha1-2zySwJu9pcLeiD+lSQ3XEf3burk="
+    },
+    "media-typer": {
+      "version": "0.3.0",
+      "resolved": "https://registry.npmjs.org/media-typer/-/media-typer-0.3.0.tgz",
+      "integrity": "sha1-hxDXrwqmJvj/+hzgAWhUUmMlV0g="
+    },
+    "mem": {
+      "version": "4.3.0",
+      "resolved": "https://registry.npmjs.org/mem/-/mem-4.3.0.tgz",
+      "integrity": "sha512-qX2bG48pTqYRVmDB37rn/6PT7LcR8T7oAX3bf99u1Tt1nzxYfxkgqDwUwolPlXweM0XzBOBFzSx4kfp7KP1s/w==",
+      "dev": true,
+      "requires": {
+        "map-age-cleaner": "^0.1.1",
+        "mimic-fn": "^2.0.0",
+        "p-is-promise": "^2.0.0"
+      },
+      "dependencies": {
+        "mimic-fn": {
+          "version": "2.1.0",
+          "resolved": "https://registry.npmjs.org/mimic-fn/-/mimic-fn-2.1.0.tgz",
+          "integrity": "sha512-OqbOk5oEQeAZ8WXWydlu9HJjz9WVdEIvamMCcXmuqUYjTknH/sqsWvhQ3vgwKFRR1HpjvNBKQ37nbJgYzGqGcg==",
+          "dev": true
+        }
+      }
+    },
+    "memory-pager": {
+      "version": "1.5.0",
+      "resolved": "https://registry.npmjs.org/memory-pager/-/memory-pager-1.5.0.tgz",
+      "integrity": "sha512-ZS4Bp4r/Zoeq6+NLJpP+0Zzm0pR8whtGPf1XExKLJBAczGMnSi3It14OiNCStjQjM6NU1okjQGSxgEZN8eBYKg==",
+      "optional": true
+    },
+    "merge-descriptors": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/merge-descriptors/-/merge-descriptors-1.0.1.tgz",
+      "integrity": "sha1-sAqqVW3YtEVoFQ7J0blT8/kMu2E="
+    },
+    "merge2": {
+      "version": "1.2.3",
+      "resolved": "https://registry.npmjs.org/merge2/-/merge2-1.2.3.tgz",
+      "integrity": "sha512-gdUU1Fwj5ep4kplwcmftruWofEFt6lfpkkr3h860CXbAB9c3hGb55EOL2ali0Td5oebvW0E1+3Sr+Ur7XfKpRA=="
+    },
+    "methods": {
+      "version": "1.1.2",
+      "resolved": "https://registry.npmjs.org/methods/-/methods-1.1.2.tgz",
+      "integrity": "sha1-VSmk1nZUE07cxSZmVoNbD4Ua/O4="
+    },
+    "micromatch": {
+      "version": "2.3.11",
+      "resolved": "https://registry.npmjs.org/micromatch/-/micromatch-2.3.11.tgz",
+      "integrity": "sha1-hmd8l9FyCzY0MdBNDRUpO9OMFWU=",
+      "optional": true,
+      "requires": {
+        "arr-diff": "^2.0.0",
+        "array-unique": "^0.2.1",
+        "braces": "^1.8.2",
+        "expand-brackets": "^0.1.4",
+        "extglob": "^0.3.1",
+        "filename-regex": "^2.0.0",
+        "is-extglob": "^1.0.0",
+        "is-glob": "^2.0.1",
+        "kind-of": "^3.0.2",
+        "normalize-path": "^2.0.1",
+        "object.omit": "^2.0.0",
+        "parse-glob": "^3.0.4",
+        "regex-cache": "^0.4.2"
+      }
+    },
+    "migrate-mongoose-typescript": {
+      "version": "3.3.4",
+      "resolved": "https://registry.npmjs.org/migrate-mongoose-typescript/-/migrate-mongoose-typescript-3.3.4.tgz",
+      "integrity": "sha512-0CE8HldEfCNWhQzLOBmn7QqNR1Pb9ynaW5w1BABuUkIYTH7uI08lYq0YUd1OgZuk9xPfzV5SYBxATbR2jFiRrA==",
+      "requires": {
+        "babel-cli": "^6.26.0",
+        "babel-core": "^6.26.3",
+        "babel-plugin-transform-runtime": "^6.23.0",
+        "babel-polyfill": "^6.26.0",
+        "babel-preset-latest": "^6.24.1",
+        "babel-register": "^6.26.0",
+        "bluebird": "^3.5.1",
+        "colors": "^1.2.4",
+        "dotenv": "^5.0.1",
+        "inquirer": "^0.12.0",
+        "mkdirp": "^0.5.1",
+        "mongoose": "^5.3.2",
+        "ts-node": "^6.0.3",
+        "yargs": "^4.8.1"
+      }
+    },
+    "mime": {
+      "version": "1.4.1",
+      "resolved": "https://registry.npmjs.org/mime/-/mime-1.4.1.tgz",
+      "integrity": "sha512-KI1+qOZu5DcW6wayYHSzR/tXKCDC5Om4s1z2QJjDULzLcmf3DvzS7oluY4HCTrc+9FiKmWUgeNLg7W3uIQvxtQ=="
+    },
+    "mime-db": {
+      "version": "1.40.0",
+      "resolved": "https://registry.npmjs.org/mime-db/-/mime-db-1.40.0.tgz",
+      "integrity": "sha512-jYdeOMPy9vnxEqFRRo6ZvTZ8d9oPb+k18PKoYNYUe2stVEBPPwsln/qWzdbmaIvnhZ9v2P+CuecK+fpUfsV2mA=="
+    },
+    "mime-types": {
+      "version": "2.1.24",
+      "resolved": "https://registry.npmjs.org/mime-types/-/mime-types-2.1.24.tgz",
+      "integrity": "sha512-WaFHS3MCl5fapm3oLxU4eYDw77IQM2ACcxQ9RIxfaC3ooc6PFuBMGZZsYpvoXS5D5QTWPieo1jjLdAm3TBP3cQ==",
+      "requires": {
+        "mime-db": "1.40.0"
+      }
+    },
+    "mimic-fn": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/mimic-fn/-/mimic-fn-1.2.0.tgz",
+      "integrity": "sha512-jf84uxzwiuiIVKiOLpfYk7N46TSy8ubTonmneY9vrpHNAnp0QBt2BxWV9dO3/j+BoVAb+a5G6YDPW3M5HOdMWQ==",
+      "dev": true
+    },
+    "minimatch": {
+      "version": "0.2.14",
+      "resolved": "https://registry.npmjs.org/minimatch/-/minimatch-0.2.14.tgz",
+      "integrity": "sha1-x054BXT2PG+aCQ6Q775u9TpqdWo=",
+      "requires": {
+        "lru-cache": "2",
+        "sigmund": "~1.0.0"
+      }
+    },
+    "minimist": {
+      "version": "0.0.8",
+      "resolved": "https://registry.npmjs.org/minimist/-/minimist-0.0.8.tgz",
+      "integrity": "sha1-hX/Kv8M5fSYluCKCYuhqp6ARsF0="
+    },
+    "mixin-deep": {
+      "version": "1.3.1",
+      "resolved": "https://registry.npmjs.org/mixin-deep/-/mixin-deep-1.3.1.tgz",
+      "integrity": "sha512-8ZItLHeEgaqEvd5lYBXfm4EZSFCX29Jb9K+lAHhDKzReKBQKj3R+7NOF6tjqYi9t4oI8VUfaWITJQm86wnXGNQ==",
+      "requires": {
+        "for-in": "^1.0.2",
+        "is-extendable": "^1.0.1"
+      },
+      "dependencies": {
+        "is-extendable": {
+          "version": "1.0.1",
+          "resolved": "https://registry.npmjs.org/is-extendable/-/is-extendable-1.0.1.tgz",
+          "integrity": "sha512-arnXMxT1hhoKo9k1LZdmlNyJdDDfy2v0fXjFlmok4+i8ul/6WlbVge9bhM74OpNPQPMGUToDtz+KXa1PneJxOA==",
+          "requires": {
+            "is-plain-object": "^2.0.4"
+          }
+        }
+      }
+    },
+    "mkdirp": {
+      "version": "0.5.1",
+      "resolved": "https://registry.npmjs.org/mkdirp/-/mkdirp-0.5.1.tgz",
+      "integrity": "sha1-MAV0OOrGz3+MR2fzhkjWaX11yQM=",
+      "requires": {
+        "minimist": "0.0.8"
+      }
+    },
+    "mocha": {
+      "version": "6.1.4",
+      "resolved": "https://registry.npmjs.org/mocha/-/mocha-6.1.4.tgz",
+      "integrity": "sha512-PN8CIy4RXsIoxoFJzS4QNnCH4psUCPWc4/rPrst/ecSJJbLBkubMiyGCP2Kj/9YnWbotFqAoeXyXMucj7gwCFg==",
+      "dev": true,
+      "requires": {
+        "ansi-colors": "3.2.3",
+        "browser-stdout": "1.3.1",
+        "debug": "3.2.6",
+        "diff": "3.5.0",
+        "escape-string-regexp": "1.0.5",
+        "find-up": "3.0.0",
+        "glob": "7.1.3",
+        "growl": "1.10.5",
+        "he": "1.2.0",
+        "js-yaml": "3.13.1",
+        "log-symbols": "2.2.0",
+        "minimatch": "3.0.4",
+        "mkdirp": "0.5.1",
+        "ms": "2.1.1",
+        "node-environment-flags": "1.0.5",
+        "object.assign": "4.1.0",
+        "strip-json-comments": "2.0.1",
+        "supports-color": "6.0.0",
+        "which": "1.3.1",
+        "wide-align": "1.1.3",
+        "yargs": "13.2.2",
+        "yargs-parser": "13.0.0",
+        "yargs-unparser": "1.5.0"
+      },
+      "dependencies": {
+        "ansi-regex": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-3.0.0.tgz",
+          "integrity": "sha1-7QMXwyIGT3lGbAKWa922Bas32Zg=",
+          "dev": true
+        },
+        "camelcase": {
+          "version": "5.3.1",
+          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.3.1.tgz",
+          "integrity": "sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==",
+          "dev": true
+        },
+        "cliui": {
+          "version": "4.1.0",
+          "resolved": "https://registry.npmjs.org/cliui/-/cliui-4.1.0.tgz",
+          "integrity": "sha512-4FG+RSG9DL7uEwRUZXZn3SS34DiDPfzP0VOiEwtUWlE+AR2EIg+hSyvrIgUUfhdgR/UkAeW2QHgeP+hWrXs7jQ==",
+          "dev": true,
+          "requires": {
+            "string-width": "^2.1.1",
+            "strip-ansi": "^4.0.0",
+            "wrap-ansi": "^2.0.0"
+          },
+          "dependencies": {
+            "string-width": {
+              "version": "2.1.1",
+              "resolved": "https://registry.npmjs.org/string-width/-/string-width-2.1.1.tgz",
+              "integrity": "sha512-nOqH59deCq9SRHlxq1Aw85Jnt4w6KvLKqWVik6oA9ZklXLNIOlqg4F2yrT1MVaTjAqvVwdfeZ7w7aCvJD7ugkw==",
+              "dev": true,
+              "requires": {
+                "is-fullwidth-code-point": "^2.0.0",
+                "strip-ansi": "^4.0.0"
+              }
+            }
+          }
+        },
+        "debug": {
+          "version": "3.2.6",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.2.6.tgz",
+          "integrity": "sha512-mel+jf7nrtEl5Pn1Qx46zARXKDpBbvzezse7p7LqINmdoIk8PYP5SySaxEmYv6TZ0JyEKA1hsCId6DIhgITtWQ==",
+          "dev": true,
+          "requires": {
+            "ms": "^2.1.1"
+          }
+        },
+        "find-up": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/find-up/-/find-up-3.0.0.tgz",
+          "integrity": "sha512-1yD6RmLI1XBfxugvORwlck6f75tYL+iR0jqwsOrOxMZyGYqUuDhJ0l4AXdO1iX/FTs9cBAMEk1gWSEx1kSbylg==",
+          "dev": true,
+          "requires": {
+            "locate-path": "^3.0.0"
+          }
+        },
+        "get-caller-file": {
+          "version": "2.0.5",
+          "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-2.0.5.tgz",
+          "integrity": "sha512-DyFP3BM/3YHTQOCUL/w0OZHR0lpKeGrxotcHWcqNEdnltqFwXVfhEBQ94eIo34AfQpo0rGki4cyIiftY06h2Fg==",
+          "dev": true
+        },
+        "invert-kv": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-2.0.0.tgz",
+          "integrity": "sha512-wPVv/y/QQ/Uiirj/vh3oP+1Ww+AWehmi1g5fFWGPF6IpCBCDVrhgHRMvrLfdYcwDh3QJbGXDW4JAuzxElLSqKA==",
+          "dev": true
+        },
+        "is-fullwidth-code-point": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-2.0.0.tgz",
+          "integrity": "sha1-o7MKXE8ZkYMWeqq5O+764937ZU8=",
+          "dev": true
+        },
+        "lcid": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/lcid/-/lcid-2.0.0.tgz",
+          "integrity": "sha512-avPEb8P8EGnwXKClwsNUgryVjllcRqtMYa49NTsbQagYuT1DcXnl1915oxWjoyGrXR6zH/Y0Zc96xWsPcoDKeA==",
+          "dev": true,
+          "requires": {
+            "invert-kv": "^2.0.0"
+          }
+        },
+        "minimatch": {
+          "version": "3.0.4",
+          "resolved": "https://registry.npmjs.org/minimatch/-/minimatch-3.0.4.tgz",
+          "integrity": "sha512-yJHVQEhyqPLUTgt9B83PXu6W3rx4MvvHvSUvToogpwoGDOUQ+yDrR0HRot+yOCdCO7u4hX3pWft6kWBBcqh0UA==",
+          "dev": true,
+          "requires": {
+            "brace-expansion": "^1.1.7"
+          }
+        },
+        "ms": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/ms/-/ms-2.1.1.tgz",
+          "integrity": "sha512-tgp+dl5cGk28utYktBsrFqA7HKgrhgPsg6Z/EfhWI4gl1Hwq8B/GmY/0oXZ6nF8hDVesS/FpnYaD/kOWhYQvyg==",
+          "dev": true
+        },
+        "os-locale": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/os-locale/-/os-locale-3.1.0.tgz",
+          "integrity": "sha512-Z8l3R4wYWM40/52Z+S265okfFj8Kt2cC2MKY+xNi3kFs+XGI7WXu/I309QQQYbRW4ijiZ+yxs9pqEhJh0DqW3Q==",
+          "dev": true,
+          "requires": {
+            "execa": "^1.0.0",
+            "lcid": "^2.0.0",
+            "mem": "^4.0.0"
+          }
+        },
+        "require-main-filename": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-2.0.0.tgz",
+          "integrity": "sha512-NKN5kMDylKuldxYLSUfrbo5Tuzh4hd+2E8NPPX02mZtn1VuREQToYe/ZdlJy+J3uCpfaiGF05e7B8W0iXbQHmg==",
+          "dev": true
+        },
+        "string-width": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/string-width/-/string-width-3.1.0.tgz",
+          "integrity": "sha512-vafcv6KjVZKSgz06oM/H6GDBrAtz8vdhQakGjFIvNrHA6y3HCF1CInLy+QLq8dTJPQ1b+KDUqDFctkdRW44e1w==",
+          "dev": true,
+          "requires": {
+            "emoji-regex": "^7.0.1",
+            "is-fullwidth-code-point": "^2.0.0",
+            "strip-ansi": "^5.1.0"
+          },
+          "dependencies": {
+            "ansi-regex": {
+              "version": "4.1.0",
+              "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-4.1.0.tgz",
+              "integrity": "sha512-1apePfXM1UOSqw0o9IiFAovVz9M5S1Dg+4TrDwfMewQ6p/rmMueb7tWZjQ1rx4Loy1ArBggoqGpfqqdI4rondg==",
+              "dev": true
+            },
+            "strip-ansi": {
+              "version": "5.2.0",
+              "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-5.2.0.tgz",
+              "integrity": "sha512-DuRs1gKbBqsMKIZlrffwlug8MHkcnpjs5VPmL1PAh+mA30U0DTotfDZ0d2UUsXpPmPmMMJ6W773MaA3J+lbiWA==",
+              "dev": true,
+              "requires": {
+                "ansi-regex": "^4.1.0"
+              }
+            }
+          }
+        },
+        "strip-ansi": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
+          "integrity": "sha1-qEeQIusaw2iocTibY1JixQXuNo8=",
+          "dev": true,
+          "requires": {
+            "ansi-regex": "^3.0.0"
+          }
+        },
+        "supports-color": {
+          "version": "6.0.0",
+          "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-6.0.0.tgz",
+          "integrity": "sha512-on9Kwidc1IUQo+bQdhi8+Tijpo0e1SS6RoGo2guUwn5vdaxw8RXOF9Vb2ws+ihWOmh4JnCJOvaziZWP1VABaLg==",
+          "dev": true,
+          "requires": {
+            "has-flag": "^3.0.0"
+          }
+        },
+        "which-module": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/which-module/-/which-module-2.0.0.tgz",
+          "integrity": "sha1-2e8H3Od7mQK4o6j6SzHD4/fm6Ho=",
+          "dev": true
+        },
+        "y18n": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/y18n/-/y18n-4.0.0.tgz",
+          "integrity": "sha512-r9S/ZyXu/Xu9q1tYlpsLIsa3EeLXXk0VwlxqTcFRfg9EhMW+17kbt9G0NrgCmhGb5vT2hyhJZLfDGx+7+5Uj/w==",
+          "dev": true
+        },
+        "yargs": {
+          "version": "13.2.2",
+          "resolved": "https://registry.npmjs.org/yargs/-/yargs-13.2.2.tgz",
+          "integrity": "sha512-WyEoxgyTD3w5XRpAQNYUB9ycVH/PQrToaTXdYXRdOXvEy1l19br+VJsc0vcO8PTGg5ro/l/GY7F/JMEBmI0BxA==",
+          "dev": true,
+          "requires": {
+            "cliui": "^4.0.0",
+            "find-up": "^3.0.0",
+            "get-caller-file": "^2.0.1",
+            "os-locale": "^3.1.0",
+            "require-directory": "^2.1.1",
+            "require-main-filename": "^2.0.0",
+            "set-blocking": "^2.0.0",
+            "string-width": "^3.0.0",
+            "which-module": "^2.0.0",
+            "y18n": "^4.0.0",
+            "yargs-parser": "^13.0.0"
+          }
+        },
+        "yargs-parser": {
+          "version": "13.0.0",
+          "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-13.0.0.tgz",
+          "integrity": "sha512-w2LXjoL8oRdRQN+hOyppuXs+V/fVAYtpcrRxZuF7Kt/Oc+Jr2uAcVntaUTNT6w5ihoWfFDpNY8CPx1QskxZ/pw==",
+          "dev": true,
+          "requires": {
+            "camelcase": "^5.0.0",
+            "decamelize": "^1.2.0"
+          }
+        }
+      }
+    },
+    "mocha-teamcity-reporter": {
+      "version": "2.5.2",
+      "resolved": "https://registry.npmjs.org/mocha-teamcity-reporter/-/mocha-teamcity-reporter-2.5.2.tgz",
+      "integrity": "sha512-zaJHKye3DSui3e9FdRKyt7fj9JxQxvlmSUu1Jow0VTyiYu6VsETY57Q4gwb2PWPZZgAugluamSnMCYC17hutGg==",
+      "dev": true,
+      "requires": {
+        "mocha": ">=3.5.0 < 6"
+      },
+      "dependencies": {
+        "commander": {
+          "version": "2.15.1",
+          "resolved": "https://registry.npmjs.org/commander/-/commander-2.15.1.tgz",
+          "integrity": "sha512-VlfT9F3V0v+jr4yxPc5gg9s62/fIVWsd2Bk2iD435um1NlGMYdVCq+MjcXnhYq2icNOizHr1kK+5TI6H0Hy0ag==",
+          "dev": true
+        },
+        "debug": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.1.0.tgz",
+          "integrity": "sha512-OX8XqP7/1a9cqkxYw2yXss15f26NKWBpDXQd0/uK/KPqdQhxbPa994hnzjcE2VqQpDslf55723cKPUOGSmMY3g==",
+          "dev": true,
+          "requires": {
+            "ms": "2.0.0"
+          }
+        },
+        "glob": {
+          "version": "7.1.2",
+          "resolved": "https://registry.npmjs.org/glob/-/glob-7.1.2.tgz",
+          "integrity": "sha512-MJTUg1kjuLeQCJ+ccE4Vpa6kKVXkPYJ2mOCQyUuKLcLQsdrMCpBPUi8qVE6+YuaJkozeA9NusTAw3hLr8Xe5EQ==",
+          "dev": true,
+          "requires": {
+            "fs.realpath": "^1.0.0",
+            "inflight": "^1.0.4",
+            "inherits": "2",
+            "minimatch": "^3.0.4",
+            "once": "^1.3.0",
+            "path-is-absolute": "^1.0.0"
+          }
+        },
+        "he": {
+          "version": "1.1.1",
+          "resolved": "https://registry.npmjs.org/he/-/he-1.1.1.tgz",
+          "integrity": "sha1-k0EP0hsAlzUVH4howvJx80J+I/0=",
+          "dev": true
+        },
+        "minimatch": {
+          "version": "3.0.4",
+          "resolved": "https://registry.npmjs.org/minimatch/-/minimatch-3.0.4.tgz",
+          "integrity": "sha512-yJHVQEhyqPLUTgt9B83PXu6W3rx4MvvHvSUvToogpwoGDOUQ+yDrR0HRot+yOCdCO7u4hX3pWft6kWBBcqh0UA==",
+          "dev": true,
+          "requires": {
+            "brace-expansion": "^1.1.7"
+          }
+        },
+        "mocha": {
+          "version": "5.2.0",
+          "resolved": "https://registry.npmjs.org/mocha/-/mocha-5.2.0.tgz",
+          "integrity": "sha512-2IUgKDhc3J7Uug+FxMXuqIyYzH7gJjXECKe/w43IGgQHTSj3InJi+yAA7T24L9bQMRKiUEHxEX37G5JpVUGLcQ==",
+          "dev": true,
+          "requires": {
+            "browser-stdout": "1.3.1",
+            "commander": "2.15.1",
+            "debug": "3.1.0",
+            "diff": "3.5.0",
+            "escape-string-regexp": "1.0.5",
+            "glob": "7.1.2",
+            "growl": "1.10.5",
+            "he": "1.1.1",
+            "minimatch": "3.0.4",
+            "mkdirp": "0.5.1",
+            "supports-color": "5.4.0"
+          }
+        },
+        "supports-color": {
+          "version": "5.4.0",
+          "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-5.4.0.tgz",
+          "integrity": "sha512-zjaXglF5nnWpsq470jSv6P9DwPvgLkuapYmfDm3JWOm0vkNTVF2tI4UrN2r6jH1qM/uc/WtxYY1hYoA2dOKj5w==",
+          "dev": true,
+          "requires": {
+            "has-flag": "^3.0.0"
+          }
+        }
+      }
+    },
+    "mongodb": {
+      "version": "3.1.13",
+      "resolved": "https://registry.npmjs.org/mongodb/-/mongodb-3.1.13.tgz",
+      "integrity": "sha512-sz2dhvBZQWf3LRNDhbd30KHVzdjZx9IKC0L+kSZ/gzYquCF5zPOgGqRz6sSCqYZtKP2ekB4nfLxhGtzGHnIKxA==",
+      "requires": {
+        "mongodb-core": "3.1.11",
+        "safe-buffer": "^5.1.2"
+      }
+    },
+    "mongodb-core": {
+      "version": "3.1.11",
+      "resolved": "https://registry.npmjs.org/mongodb-core/-/mongodb-core-3.1.11.tgz",
+      "integrity": "sha512-rD2US2s5qk/ckbiiGFHeu+yKYDXdJ1G87F6CG3YdaZpzdOm5zpoAZd/EKbPmFO6cQZ+XVXBXBJ660sSI0gc6qg==",
+      "requires": {
+        "bson": "^1.1.0",
+        "require_optional": "^1.0.1",
+        "safe-buffer": "^5.1.2",
+        "saslprep": "^1.0.0"
+      }
+    },
+    "mongodb-download": {
+      "version": "2.2.7",
+      "resolved": "https://registry.npmjs.org/mongodb-download/-/mongodb-download-2.2.7.tgz",
+      "integrity": "sha512-39/eiEmCqig0gCR3tNbmbTk6rIpWzEGqcXT0BE645stlA+DY7WlrIWZGEG51BcI3MUdGzqVYFj+qLoRw+HsJSA==",
+      "requires": {
+        "debug": "^2.2.0",
+        "decompress": "^4.0.0",
+        "fs-extra": "^2.0.0",
+        "getos": "^2.7.0",
+        "md5-file": "3.1.1",
+        "request": "^2.79.0",
+        "request-promise": "^4.1.1",
+        "semver": "^5.6.0",
+        "yargs": "^3.26.0"
+      },
+      "dependencies": {
+        "camelcase": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-2.1.1.tgz",
+          "integrity": "sha1-fB0W1nmhu+WcoCys7PsBHiAfWh8="
+        },
+        "window-size": {
+          "version": "0.1.4",
+          "resolved": "https://registry.npmjs.org/window-size/-/window-size-0.1.4.tgz",
+          "integrity": "sha1-+OGqHuWlPsW/FR/6CXQqatdpeHY="
+        },
+        "yargs": {
+          "version": "3.32.0",
+          "resolved": "https://registry.npmjs.org/yargs/-/yargs-3.32.0.tgz",
+          "integrity": "sha1-AwiOnr+edWtpdRYR0qXvWRSCyZU=",
+          "requires": {
+            "camelcase": "^2.0.1",
+            "cliui": "^3.0.3",
+            "decamelize": "^1.1.1",
+            "os-locale": "^1.4.0",
+            "string-width": "^1.0.1",
+            "window-size": "^0.1.4",
+            "y18n": "^3.2.0"
+          }
+        }
+      }
+    },
+    "mongodb-memory-server": {
+      "version": "5.1.0",
+      "resolved": "https://registry.npmjs.org/mongodb-memory-server/-/mongodb-memory-server-5.1.0.tgz",
+      "integrity": "sha512-CN4fjt90fi6A3PSJIx6xYxIRqpxF1rJoz4BcJv6LmGyRAOAvCbr3SqRbfXJMS26wTDyHylXtW32PhdykDohogA==",
+      "dev": true,
+      "requires": {
+        "mongodb-memory-server-core": "5.1.0"
+      }
+    },
+    "mongodb-memory-server-core": {
+      "version": "5.1.0",
+      "resolved": "https://registry.npmjs.org/mongodb-memory-server-core/-/mongodb-memory-server-core-5.1.0.tgz",
+      "integrity": "sha512-M/GWVvFze0geP2smoy0ns+Yz5l4BRP6Y66OKc+w9zlX422ydQEA04bLQjooPqoaBTrV90xuDj5E+zejn/YkPew==",
+      "dev": true,
+      "requires": {
+        "camelcase": "^5.3.1",
+        "debug": "^4.1.1",
+        "decompress": "^4.2.0",
+        "dedent": "^0.7.0",
+        "find-cache-dir": "^2.0.0",
+        "find-package-json": "^1.2.0",
+        "get-port": "^4.2.0",
+        "getos": "^3.1.1",
+        "https-proxy-agent": "^2.2.1",
+        "lockfile": "^1.0.4",
+        "md5-file": "^4.0.0",
+        "mkdirp": "^0.5.1",
+        "mongodb": ">=3.0.0",
+        "tmp": "^0.0.33",
+        "uuid": "^3.2.1"
+      },
+      "dependencies": {
+        "camelcase": {
+          "version": "5.3.1",
+          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.3.1.tgz",
+          "integrity": "sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==",
+          "dev": true
+        },
+        "debug": {
+          "version": "4.1.1",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-4.1.1.tgz",
+          "integrity": "sha512-pYAIzeRo8J6KPEaJ0VWOh5Pzkbw/RetuzehGM7QRRX5he4fPHx2rdKMB256ehJCkX+XRQm16eZLqLNS8RSZXZw==",
+          "dev": true,
+          "requires": {
+            "ms": "^2.1.1"
+          }
+        },
+        "getos": {
+          "version": "3.1.1",
+          "resolved": "https://registry.npmjs.org/getos/-/getos-3.1.1.tgz",
+          "integrity": "sha512-oUP1rnEhAr97rkitiszGP9EgDVYnmchgFzfqRzSkgtfv7ai6tEi7Ko8GgjNXts7VLWEqrTWyhsOKLe5C5b/Zkg==",
+          "dev": true,
+          "requires": {
+            "async": "2.6.1"
+          }
+        },
+        "md5-file": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/md5-file/-/md5-file-4.0.0.tgz",
+          "integrity": "sha512-UC0qFwyAjn4YdPpKaDNw6gNxRf7Mcx7jC1UGCY4boCzgvU2Aoc1mOGzTtrjjLKhM5ivsnhoKpQVxKPp+1j1qwg==",
+          "dev": true
+        },
+        "ms": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/ms/-/ms-2.1.1.tgz",
+          "integrity": "sha512-tgp+dl5cGk28utYktBsrFqA7HKgrhgPsg6Z/EfhWI4gl1Hwq8B/GmY/0oXZ6nF8hDVesS/FpnYaD/kOWhYQvyg==",
+          "dev": true
+        }
+      }
+    },
+    "mongodb-prebuilt": {
+      "version": "6.5.0",
+      "resolved": "https://registry.npmjs.org/mongodb-prebuilt/-/mongodb-prebuilt-6.5.0.tgz",
+      "integrity": "sha512-rwTWbV4w8uxYJAhq2tQd+lrAjOYsxo/eXJb5rvNCGEJZlddoThYOHlkfLQ4w7PagauQZN3XBEW55GhkPUadN6w==",
+      "requires": {
+        "debug": "^2.2.0",
+        "glob": "^7.1.1",
+        "mongodb-download": "^2.2.7",
+        "spawn-sync": "1.0.15",
+        "yargs": "^3.26.0"
+      },
+      "dependencies": {
+        "camelcase": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-2.1.1.tgz",
+          "integrity": "sha1-fB0W1nmhu+WcoCys7PsBHiAfWh8="
+        },
+        "window-size": {
+          "version": "0.1.4",
+          "resolved": "https://registry.npmjs.org/window-size/-/window-size-0.1.4.tgz",
+          "integrity": "sha1-+OGqHuWlPsW/FR/6CXQqatdpeHY="
+        },
+        "yargs": {
+          "version": "3.32.0",
+          "resolved": "https://registry.npmjs.org/yargs/-/yargs-3.32.0.tgz",
+          "integrity": "sha1-AwiOnr+edWtpdRYR0qXvWRSCyZU=",
+          "requires": {
+            "camelcase": "^2.0.1",
+            "cliui": "^3.0.3",
+            "decamelize": "^1.1.1",
+            "os-locale": "^1.4.0",
+            "string-width": "^1.0.1",
+            "window-size": "^0.1.4",
+            "y18n": "^3.2.0"
+          }
+        }
+      }
+    },
+    "mongoose": {
+      "version": "5.5.4",
+      "resolved": "https://registry.npmjs.org/mongoose/-/mongoose-5.5.4.tgz",
+      "integrity": "sha512-xzS7fJtXGjCOZozCtlyFS8graMub1L9knp37+1dJCDmWzOtXVHeLjV2XIC9tX0sE54cxeG5rHvSmIkLpeHjjmA==",
+      "requires": {
+        "async": "2.6.1",
+        "bson": "~1.1.1",
+        "kareem": "2.3.0",
+        "mongodb": "3.2.2",
+        "mongodb-core": "3.2.2",
+        "mongoose-legacy-pluralize": "1.0.2",
+        "mpath": "0.5.2",
+        "mquery": "3.2.0",
+        "ms": "2.1.1",
+        "regexp-clone": "0.0.1",
+        "safe-buffer": "5.1.2",
+        "sift": "7.0.1",
+        "sliced": "1.0.1"
+      },
+      "dependencies": {
+        "mongodb": {
+          "version": "3.2.2",
+          "resolved": "https://registry.npmjs.org/mongodb/-/mongodb-3.2.2.tgz",
+          "integrity": "sha512-xQ6apOOV+w7VFApdaJpWhYhzartpjIDFQjG0AwgJkLh7dBs7PTsq4A3Bia2QWpDohmAzTBIdQVLMqqLy0mwt3Q==",
+          "requires": {
+            "mongodb-core": "3.2.2",
+            "safe-buffer": "^5.1.2"
+          }
+        },
+        "mongodb-core": {
+          "version": "3.2.2",
+          "resolved": "https://registry.npmjs.org/mongodb-core/-/mongodb-core-3.2.2.tgz",
+          "integrity": "sha512-YRgC39MuzKL0uoGoRdTmV1e9m47NbMnYmuEx4IOkgWAGXPSEzRY7cwb3N0XMmrDMnD9vp7MysNyAriIIeGgIQg==",
+          "requires": {
+            "bson": "^1.1.1",
+            "require_optional": "^1.0.1",
+            "safe-buffer": "^5.1.2",
+            "saslprep": "^1.0.0"
+          }
+        },
+        "mpath": {
+          "version": "0.5.2",
+          "resolved": "https://registry.npmjs.org/mpath/-/mpath-0.5.2.tgz",
+          "integrity": "sha512-NOeCoW6AYc3hLi30npe7uzbD9b4FQZKH40YKABUCCvaKKL5agj6YzvHoNx8jQpDMNPgIa5bvSZQbQpWBAVD0Kw=="
+        },
+        "ms": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/ms/-/ms-2.1.1.tgz",
+          "integrity": "sha512-tgp+dl5cGk28utYktBsrFqA7HKgrhgPsg6Z/EfhWI4gl1Hwq8B/GmY/0oXZ6nF8hDVesS/FpnYaD/kOWhYQvyg=="
+        }
+      }
+    },
+    "mongoose-legacy-pluralize": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/mongoose-legacy-pluralize/-/mongoose-legacy-pluralize-1.0.2.tgz",
+      "integrity": "sha512-Yo/7qQU4/EyIS8YDFSeenIvXxZN+ld7YdV9LqFVQJzTLye8unujAWPZ4NWKfFA+RNjh+wvTWKY9Z3E5XM6ZZiQ=="
+    },
+    "morgan": {
+      "version": "1.9.1",
+      "resolved": "https://registry.npmjs.org/morgan/-/morgan-1.9.1.tgz",
+      "integrity": "sha512-HQStPIV4y3afTiCYVxirakhlCfGkI161c76kKFca7Fk1JusM//Qeo1ej2XaMniiNeaZklMVrh3vTtIzpzwbpmA==",
+      "requires": {
+        "basic-auth": "~2.0.0",
+        "debug": "2.6.9",
+        "depd": "~1.1.2",
+        "on-finished": "~2.3.0",
+        "on-headers": "~1.0.1"
+      }
+    },
+    "mpath": {
+      "version": "0.5.1",
+      "resolved": "https://registry.npmjs.org/mpath/-/mpath-0.5.1.tgz",
+      "integrity": "sha512-H8OVQ+QEz82sch4wbODFOz+3YQ61FYz/z3eJ5pIdbMEaUzDqA268Wd+Vt4Paw9TJfvDgVKaayC0gBzMIw2jhsg=="
+    },
+    "mquery": {
+      "version": "3.2.0",
+      "resolved": "https://registry.npmjs.org/mquery/-/mquery-3.2.0.tgz",
+      "integrity": "sha512-qPJcdK/yqcbQiKoemAt62Y0BAc0fTEKo1IThodBD+O5meQRJT/2HSe5QpBNwaa4CjskoGrYWsEyjkqgiE0qjhg==",
+      "requires": {
+        "bluebird": "3.5.1",
+        "debug": "3.1.0",
+        "regexp-clone": "0.0.1",
+        "safe-buffer": "5.1.2",
+        "sliced": "1.0.1"
+      },
+      "dependencies": {
+        "bluebird": {
+          "version": "3.5.1",
+          "resolved": "https://registry.npmjs.org/bluebird/-/bluebird-3.5.1.tgz",
+          "integrity": "sha512-MKiLiV+I1AA596t9w1sQJ8jkiSr5+ZKi0WKrYGUn6d1Fx+Ij4tIj+m2WMQSGczs5jZVxV339chE8iwk6F64wjA=="
+        },
+        "debug": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.1.0.tgz",
+          "integrity": "sha512-OX8XqP7/1a9cqkxYw2yXss15f26NKWBpDXQd0/uK/KPqdQhxbPa994hnzjcE2VqQpDslf55723cKPUOGSmMY3g==",
+          "requires": {
+            "ms": "2.0.0"
+          }
+        }
+      }
+    },
+    "ms": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/ms/-/ms-2.0.0.tgz",
+      "integrity": "sha1-VgiurfwAvmwpAd9fmGF4jeDVl8g="
+    },
+    "multistream": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/multistream/-/multistream-2.1.1.tgz",
+      "integrity": "sha512-xasv76hl6nr1dEy3lPvy7Ej7K/Lx3O/FCvwge8PeVJpciPPoNCbaANcNiBug3IpdvTveZUcAV0DJzdnUDMesNQ==",
+      "requires": {
+        "inherits": "^2.0.1",
+        "readable-stream": "^2.0.5"
+      }
+    },
+    "mute-stream": {
+      "version": "0.0.5",
+      "resolved": "https://registry.npmjs.org/mute-stream/-/mute-stream-0.0.5.tgz",
+      "integrity": "sha1-j7+rsKmKJT0xhDMfno3rc3L6xsA="
+    },
+    "nan": {
+      "version": "2.13.2",
+      "resolved": "https://registry.npmjs.org/nan/-/nan-2.13.2.tgz",
+      "integrity": "sha512-TghvYc72wlMGMVMluVo9WRJc0mB8KxxF/gZ4YYFy7V2ZQX9l7rgbPg7vjS9mt6U5HXODVFVI2bOduCzwOMv/lw==",
+      "optional": true
+    },
+    "nanomatch": {
+      "version": "1.2.13",
+      "resolved": "https://registry.npmjs.org/nanomatch/-/nanomatch-1.2.13.tgz",
+      "integrity": "sha512-fpoe2T0RbHwBTBUOftAfBPaDEi06ufaUai0mE6Yn1kacc3SnTErfb/h+X94VXzI64rKFHYImXSvdwGGCmwOqCA==",
+      "requires": {
+        "arr-diff": "^4.0.0",
+        "array-unique": "^0.3.2",
+        "define-property": "^2.0.2",
+        "extend-shallow": "^3.0.2",
+        "fragment-cache": "^0.2.1",
+        "is-windows": "^1.0.2",
+        "kind-of": "^6.0.2",
+        "object.pick": "^1.3.0",
+        "regex-not": "^1.0.0",
+        "snapdragon": "^0.8.1",
+        "to-regex": "^3.0.1"
+      },
+      "dependencies": {
+        "arr-diff": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/arr-diff/-/arr-diff-4.0.0.tgz",
+          "integrity": "sha1-1kYQdP6/7HHn4VI1dhoyml3HxSA="
+        },
+        "array-unique": {
+          "version": "0.3.2",
+          "resolved": "https://registry.npmjs.org/array-unique/-/array-unique-0.3.2.tgz",
+          "integrity": "sha1-qJS3XUvE9s1nnvMkSp/Y9Gri1Cg="
+        },
+        "kind-of": {
+          "version": "6.0.2",
+          "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-6.0.2.tgz",
+          "integrity": "sha512-s5kLOcnH0XqDO+FvuaLX8DDjZ18CGFk7VygH40QoKPUQhW4e2rvM0rwUq0t8IQDOwYSeLK01U90OjzBTme2QqA=="
+        }
+      }
+    },
+    "natural-compare": {
+      "version": "1.4.0",
+      "resolved": "https://registry.npmjs.org/natural-compare/-/natural-compare-1.4.0.tgz",
+      "integrity": "sha1-Sr6/7tdUHywnrPspvbvRXI1bpPc=",
+      "dev": true
+    },
+    "nconf": {
+      "version": "0.10.0",
+      "resolved": "https://registry.npmjs.org/nconf/-/nconf-0.10.0.tgz",
+      "integrity": "sha512-fKiXMQrpP7CYWJQzKkPPx9hPgmq+YLDyxcG9N8RpiE9FoCkCbzD0NyW0YhE3xn3Aupe7nnDeIx4PFzYehpHT9Q==",
+      "requires": {
+        "async": "^1.4.0",
+        "ini": "^1.3.0",
+        "secure-keys": "^1.0.0",
+        "yargs": "^3.19.0"
+      },
+      "dependencies": {
+        "async": {
+          "version": "1.5.2",
+          "resolved": "https://registry.npmjs.org/async/-/async-1.5.2.tgz",
+          "integrity": "sha1-7GphrlZIDAw8skHJVhjiCJL5Zyo="
+        },
+        "camelcase": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-2.1.1.tgz",
+          "integrity": "sha1-fB0W1nmhu+WcoCys7PsBHiAfWh8="
+        },
+        "window-size": {
+          "version": "0.1.4",
+          "resolved": "https://registry.npmjs.org/window-size/-/window-size-0.1.4.tgz",
+          "integrity": "sha1-+OGqHuWlPsW/FR/6CXQqatdpeHY="
+        },
+        "yargs": {
+          "version": "3.32.0",
+          "resolved": "https://registry.npmjs.org/yargs/-/yargs-3.32.0.tgz",
+          "integrity": "sha1-AwiOnr+edWtpdRYR0qXvWRSCyZU=",
+          "requires": {
+            "camelcase": "^2.0.1",
+            "cliui": "^3.0.3",
+            "decamelize": "^1.1.1",
+            "os-locale": "^1.4.0",
+            "string-width": "^1.0.1",
+            "window-size": "^0.1.4",
+            "y18n": "^3.2.0"
+          }
+        }
+      }
+    },
+    "negotiator": {
+      "version": "0.6.1",
+      "resolved": "https://registry.npmjs.org/negotiator/-/negotiator-0.6.1.tgz",
+      "integrity": "sha1-KzJxhOiZIQEXeyhWP7XnECrNDKk="
+    },
+    "nice-try": {
+      "version": "1.0.5",
+      "resolved": "https://registry.npmjs.org/nice-try/-/nice-try-1.0.5.tgz",
+      "integrity": "sha512-1nh45deeb5olNY7eX82BkPO7SSxR5SSYJiPTrTdFUVYwAl8CKMA5N9PjTYkHiRjisVcxcQ1HXdLhx2qxxJzLNQ==",
+      "dev": true
+    },
+    "node-environment-flags": {
+      "version": "1.0.5",
+      "resolved": "https://registry.npmjs.org/node-environment-flags/-/node-environment-flags-1.0.5.tgz",
+      "integrity": "sha512-VNYPRfGfmZLx0Ye20jWzHUjyTW/c+6Wq+iLhDzUI4XmhrDd9l/FozXV3F2xOaXjvp0co0+v1YSR3CMP6g+VvLQ==",
+      "dev": true,
+      "requires": {
+        "object.getownpropertydescriptors": "^2.0.3",
+        "semver": "^5.7.0"
+      }
+    },
+    "nodemailer": {
+      "version": "6.1.1",
+      "resolved": "https://registry.npmjs.org/nodemailer/-/nodemailer-6.1.1.tgz",
+      "integrity": "sha512-/x5MRIh56VyuuhLfcz+DL2SlBARpZpgQIf2A4Ao4hMb69MHSgDIMPwYmFwesGT1lkRDZ0eBSoym5+JoIZ3N+cQ=="
+    },
+    "normalize-package-data": {
+      "version": "2.5.0",
+      "resolved": "https://registry.npmjs.org/normalize-package-data/-/normalize-package-data-2.5.0.tgz",
+      "integrity": "sha512-/5CMN3T0R4XTj4DcGaexo+roZSdSFW/0AOOTROrjxzCG1wrWXEsGbRKevjlIL+ZDE4sZlJr5ED4YW0yqmkK+eA==",
+      "requires": {
+        "hosted-git-info": "^2.1.4",
+        "resolve": "^1.10.0",
+        "semver": "2 || 3 || 4 || 5",
+        "validate-npm-package-license": "^3.0.1"
+      }
+    },
+    "normalize-path": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/normalize-path/-/normalize-path-2.1.1.tgz",
+      "integrity": "sha1-GrKLVW4Zg2Oowab35vogE3/mrtk=",
+      "requires": {
+        "remove-trailing-separator": "^1.0.1"
+      }
+    },
+    "npm-run-path": {
+      "version": "2.0.2",
+      "resolved": "https://registry.npmjs.org/npm-run-path/-/npm-run-path-2.0.2.tgz",
+      "integrity": "sha1-NakjLfo11wZ7TLLd8jV7GHFTbF8=",
+      "dev": true,
+      "requires": {
+        "path-key": "^2.0.0"
+      }
+    },
+    "number-is-nan": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/number-is-nan/-/number-is-nan-1.0.1.tgz",
+      "integrity": "sha1-CXtgK1NCKlIsGvuHkDGDNpQaAR0="
+    },
+    "oauth-sign": {
+      "version": "0.9.0",
+      "resolved": "https://registry.npmjs.org/oauth-sign/-/oauth-sign-0.9.0.tgz",
+      "integrity": "sha512-fexhUFFPTGV8ybAtSIGbV6gOkSv8UtRbDBnAyLQw4QPKkgNlsH2ByPGtMUqdWkos6YCRmAqViwgZrJc/mRDzZQ=="
+    },
+    "object-assign": {
+      "version": "4.1.1",
+      "resolved": "https://registry.npmjs.org/object-assign/-/object-assign-4.1.1.tgz",
+      "integrity": "sha1-IQmtx5ZYh8/AXLvUQsrIv7s2CGM="
+    },
+    "object-component": {
+      "version": "0.0.3",
+      "resolved": "https://registry.npmjs.org/object-component/-/object-component-0.0.3.tgz",
+      "integrity": "sha1-8MaapQ78lbhmwYb0AKM3acsvEpE="
+    },
+    "object-copy": {
+      "version": "0.1.0",
+      "resolved": "https://registry.npmjs.org/object-copy/-/object-copy-0.1.0.tgz",
+      "integrity": "sha1-fn2Fi3gb18mRpBupde04EnVOmYw=",
+      "requires": {
+        "copy-descriptor": "^0.1.0",
+        "define-property": "^0.2.5",
+        "kind-of": "^3.0.3"
+      },
+      "dependencies": {
+        "define-property": {
+          "version": "0.2.5",
+          "resolved": "https://registry.npmjs.org/define-property/-/define-property-0.2.5.tgz",
+          "integrity": "sha1-w1se+RjsPJkPmlvFe+BKrOxcgRY=",
+          "requires": {
+            "is-descriptor": "^0.1.0"
+          }
+        }
+      }
+    },
+    "object-keys": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/object-keys/-/object-keys-1.1.1.tgz",
+      "integrity": "sha512-NuAESUOUMrlIXOfHKzD6bpPu3tYt3xvjNdRIQ+FeT0lNb4K8WR70CaDxhuNguS2XG+GjkyMwOzsN5ZktImfhLA==",
+      "dev": true
+    },
+    "object-visit": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/object-visit/-/object-visit-1.0.1.tgz",
+      "integrity": "sha1-95xEk68MU3e1n+OdOV5BBC3QRbs=",
+      "requires": {
+        "isobject": "^3.0.0"
+      },
+      "dependencies": {
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        }
+      }
+    },
+    "object.assign": {
+      "version": "4.1.0",
+      "resolved": "https://registry.npmjs.org/object.assign/-/object.assign-4.1.0.tgz",
+      "integrity": "sha512-exHJeq6kBKj58mqGyTQ9DFvrZC/eR6OwxzoM9YRoGBqrXYonaFyGiFMuc9VZrXf7DarreEwMpurG3dd+CNyW5w==",
+      "dev": true,
+      "requires": {
+        "define-properties": "^1.1.2",
+        "function-bind": "^1.1.1",
+        "has-symbols": "^1.0.0",
+        "object-keys": "^1.0.11"
+      }
+    },
+    "object.getownpropertydescriptors": {
+      "version": "2.0.3",
+      "resolved": "https://registry.npmjs.org/object.getownpropertydescriptors/-/object.getownpropertydescriptors-2.0.3.tgz",
+      "integrity": "sha1-h1jIRvW0B62rDyNuCYbxSwUcqhY=",
+      "dev": true,
+      "requires": {
+        "define-properties": "^1.1.2",
+        "es-abstract": "^1.5.1"
+      }
+    },
+    "object.omit": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/object.omit/-/object.omit-2.0.1.tgz",
+      "integrity": "sha1-Gpx0SCnznbuFjHbKNXmuKlTr0fo=",
+      "optional": true,
+      "requires": {
+        "for-own": "^0.1.4",
+        "is-extendable": "^0.1.1"
+      }
+    },
+    "object.pick": {
+      "version": "1.3.0",
+      "resolved": "https://registry.npmjs.org/object.pick/-/object.pick-1.3.0.tgz",
+      "integrity": "sha1-h6EKxMFpS9Lhy/U1kaZhQftd10c=",
+      "requires": {
+        "isobject": "^3.0.1"
+      },
+      "dependencies": {
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        }
+      }
+    },
+    "on-finished": {
+      "version": "2.3.0",
+      "resolved": "https://registry.npmjs.org/on-finished/-/on-finished-2.3.0.tgz",
+      "integrity": "sha1-IPEzZIGwg811M3mSoWlxqi2QaUc=",
+      "requires": {
+        "ee-first": "1.1.1"
+      }
+    },
+    "on-headers": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/on-headers/-/on-headers-1.0.2.tgz",
+      "integrity": "sha512-pZAE+FJLoyITytdqK0U5s+FIpjN0JP3OzFi/u8Rx+EV5/W+JTWGXG8xFzevE7AjBfDqHv/8vL8qQsIhHnqRkrA=="
+    },
+    "once": {
+      "version": "1.4.0",
+      "resolved": "https://registry.npmjs.org/once/-/once-1.4.0.tgz",
+      "integrity": "sha1-WDsap3WWHUsROsF9nFC6753Xa9E=",
+      "requires": {
+        "wrappy": "1"
+      }
+    },
+    "onetime": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/onetime/-/onetime-1.1.0.tgz",
+      "integrity": "sha1-ofeDj4MUxRbwXs78vEzP4EtO14k="
+    },
+    "optionator": {
+      "version": "0.8.2",
+      "resolved": "https://registry.npmjs.org/optionator/-/optionator-0.8.2.tgz",
+      "integrity": "sha1-NkxeQJ0/TWMB1sC0wFu6UBgK62Q=",
+      "requires": {
+        "deep-is": "~0.1.3",
+        "fast-levenshtein": "~2.0.4",
+        "levn": "~0.3.0",
+        "prelude-ls": "~1.1.2",
+        "type-check": "~0.3.2",
+        "wordwrap": "~1.0.0"
+      }
+    },
+    "os-homedir": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/os-homedir/-/os-homedir-1.0.2.tgz",
+      "integrity": "sha1-/7xJiDNuDoM94MFox+8VISGqf7M="
+    },
+    "os-locale": {
+      "version": "1.4.0",
+      "resolved": "https://registry.npmjs.org/os-locale/-/os-locale-1.4.0.tgz",
+      "integrity": "sha1-IPnxeuKe00XoveWDsT0gCYA8FNk=",
+      "requires": {
+        "lcid": "^1.0.0"
+      }
+    },
+    "os-shim": {
+      "version": "0.1.3",
+      "resolved": "https://registry.npmjs.org/os-shim/-/os-shim-0.1.3.tgz",
+      "integrity": "sha1-a2LDeRz3kJ6jXtRuF2WLtBfLORc="
+    },
+    "os-tmpdir": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/os-tmpdir/-/os-tmpdir-1.0.2.tgz",
+      "integrity": "sha1-u+Z0BseaqFxc/sdm/lc0VV36EnQ="
+    },
+    "output-file-sync": {
+      "version": "1.1.2",
+      "resolved": "https://registry.npmjs.org/output-file-sync/-/output-file-sync-1.1.2.tgz",
+      "integrity": "sha1-0KM+7+YaIF+suQCS6CZZjVJFznY=",
+      "requires": {
+        "graceful-fs": "^4.1.4",
+        "mkdirp": "^0.5.1",
+        "object-assign": "^4.1.0"
+      }
+    },
+    "p-defer": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/p-defer/-/p-defer-1.0.0.tgz",
+      "integrity": "sha1-n26xgvbJqozXQwBKfU+WsZaw+ww=",
+      "dev": true
+    },
+    "p-finally": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/p-finally/-/p-finally-1.0.0.tgz",
+      "integrity": "sha1-P7z7FbiZpEEjs0ttzBi3JDNqLK4=",
+      "dev": true
+    },
+    "p-is-promise": {
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/p-is-promise/-/p-is-promise-2.1.0.tgz",
+      "integrity": "sha512-Y3W0wlRPK8ZMRbNq97l4M5otioeA5lm1z7bkNkxCka8HSPjR0xRWmpCmc9utiaLP9Jb1eD8BgeIxTW4AIF45Pg=="
+    },
+    "p-limit": {
+      "version": "2.2.0",
+      "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.2.0.tgz",
+      "integrity": "sha512-pZbTJpoUsCzV48Mc9Nh51VbwO0X9cuPFE8gYwx9BTCt9SF8/b7Zljd2fVgOxhIF/HDTKgpVzs+GPhyKfjLLFRQ==",
+      "dev": true,
+      "requires": {
+        "p-try": "^2.0.0"
+      }
+    },
+    "p-locate": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/p-locate/-/p-locate-3.0.0.tgz",
+      "integrity": "sha512-x+12w/To+4GFfgJhBEpiDcLozRJGegY+Ei7/z0tSLkMmxGZNybVMSfWj9aJn8Z5Fc7dBUNJOOVgPv2H7IwulSQ==",
+      "dev": true,
+      "requires": {
+        "p-limit": "^2.0.0"
+      }
+    },
+    "p-try": {
+      "version": "2.2.0",
+      "resolved": "https://registry.npmjs.org/p-try/-/p-try-2.2.0.tgz",
+      "integrity": "sha512-R4nPAVTAU0B9D35/Gk3uJf/7XYbQcyohSKdvAxIRSNghFl4e71hVoGnBNQz9cWaXxO2I10KTC+3jMdvvoKw6dQ==",
+      "dev": true
+    },
+    "pako": {
+      "version": "1.0.10",
+      "resolved": "https://registry.npmjs.org/pako/-/pako-1.0.10.tgz",
+      "integrity": "sha512-0DTvPVU3ed8+HNXOu5Bs+o//Mbdj9VNQMUOe9oKCwh8l0GNwpTDMKCWbRjgtD291AWnkAgkqA/LOnQS8AmS1tw=="
+    },
+    "parent-module": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/parent-module/-/parent-module-1.0.1.tgz",
+      "integrity": "sha512-GQ2EWRpQV8/o+Aw8YqtfZZPfNRWZYkbidE9k5rpl/hC3vtHHBfGm2Ifi6qWV+coDGkrUKZAxE3Lot5kcsRlh+g==",
+      "dev": true,
+      "requires": {
+        "callsites": "^3.0.0"
+      }
+    },
+    "parse-glob": {
+      "version": "3.0.4",
+      "resolved": "https://registry.npmjs.org/parse-glob/-/parse-glob-3.0.4.tgz",
+      "integrity": "sha1-ssN2z7EfNVE7rdFz7wu246OIORw=",
+      "optional": true,
+      "requires": {
+        "glob-base": "^0.3.0",
+        "is-dotfile": "^1.0.0",
+        "is-extglob": "^1.0.0",
+        "is-glob": "^2.0.0"
+      }
+    },
+    "parse-json": {
+      "version": "2.2.0",
+      "resolved": "https://registry.npmjs.org/parse-json/-/parse-json-2.2.0.tgz",
+      "integrity": "sha1-9ID0BDTvgHQfhGkJn43qGPVaTck=",
+      "requires": {
+        "error-ex": "^1.2.0"
+      }
+    },
+    "parseqs": {
+      "version": "0.0.5",
+      "resolved": "https://registry.npmjs.org/parseqs/-/parseqs-0.0.5.tgz",
+      "integrity": "sha1-1SCKNzjkZ2bikbouoXNoSSGouJ0=",
+      "requires": {
+        "better-assert": "~1.0.0"
+      }
+    },
+    "parseuri": {
+      "version": "0.0.5",
+      "resolved": "https://registry.npmjs.org/parseuri/-/parseuri-0.0.5.tgz",
+      "integrity": "sha1-gCBKUNTbt3m/3G6+J3jZDkvOMgo=",
+      "requires": {
+        "better-assert": "~1.0.0"
+      }
+    },
+    "parseurl": {
+      "version": "1.3.3",
+      "resolved": "https://registry.npmjs.org/parseurl/-/parseurl-1.3.3.tgz",
+      "integrity": "sha512-CiyeOxFT/JZyN5m0z9PfXw4SCBJ6Sygz1Dpl0wqjlhDEGGBP1GnsUVEL0p63hoG1fcj3fHynXi9NYO4nWOL+qQ=="
+    },
+    "pascalcase": {
+      "version": "0.1.1",
+      "resolved": "https://registry.npmjs.org/pascalcase/-/pascalcase-0.1.1.tgz",
+      "integrity": "sha1-s2PlXoAGym/iF4TS2yK9FdeRfxQ="
+    },
+    "passport": {
+      "version": "0.4.0",
+      "resolved": "https://registry.npmjs.org/passport/-/passport-0.4.0.tgz",
+      "integrity": "sha1-xQlWkTR71a07XhgCOMORTRbwWBE=",
+      "requires": {
+        "passport-strategy": "1.x.x",
+        "pause": "0.0.1"
+      }
+    },
+    "passport-local": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/passport-local/-/passport-local-1.0.0.tgz",
+      "integrity": "sha1-H+YyaMkudWBmJkN+O5BmYsFbpu4=",
+      "requires": {
+        "passport-strategy": "1.x.x"
+      }
+    },
+    "passport-local-mongoose": {
+      "version": "5.0.1",
+      "resolved": "https://registry.npmjs.org/passport-local-mongoose/-/passport-local-mongoose-5.0.1.tgz",
+      "integrity": "sha512-VUY5DgBdpjt1tjunJJ1EXV5b2nhMDkXJuhTjyiK660IgIp7kONMyWEe9tGHf8I9tZudXuTF+47JNQLIzU+Hjbw==",
+      "requires": {
+        "debug": "^3.1.0",
+        "generaterr": "^1.5.0",
+        "passport-local": "^1.0.0",
+        "scmp": "^2.0.0",
+        "semver": "^5.5.0"
+      },
+      "dependencies": {
+        "debug": {
+          "version": "3.2.6",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.2.6.tgz",
+          "integrity": "sha512-mel+jf7nrtEl5Pn1Qx46zARXKDpBbvzezse7p7LqINmdoIk8PYP5SySaxEmYv6TZ0JyEKA1hsCId6DIhgITtWQ==",
+          "requires": {
+            "ms": "^2.1.1"
+          }
+        },
+        "ms": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/ms/-/ms-2.1.1.tgz",
+          "integrity": "sha512-tgp+dl5cGk28utYktBsrFqA7HKgrhgPsg6Z/EfhWI4gl1Hwq8B/GmY/0oXZ6nF8hDVesS/FpnYaD/kOWhYQvyg=="
+        }
+      }
+    },
+    "passport-strategy": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/passport-strategy/-/passport-strategy-1.0.0.tgz",
+      "integrity": "sha1-tVOaqPwiWj0a0XlHbd8ja0QPUuQ="
+    },
+    "passport.socketio": {
+      "version": "3.7.0",
+      "resolved": "https://registry.npmjs.org/passport.socketio/-/passport.socketio-3.7.0.tgz",
+      "integrity": "sha1-LuX6/paV1CgcjN3T/pdezRjmcm4=",
+      "requires": {
+        "xtend": "^4.0.0"
+      }
+    },
+    "path-dirname": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/path-dirname/-/path-dirname-1.0.2.tgz",
+      "integrity": "sha1-zDPSTVJeCZpTiMAzbG4yuRYGCeA="
+    },
+    "path-exists": {
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/path-exists/-/path-exists-2.1.0.tgz",
+      "integrity": "sha1-D+tsZPD8UY2adU3V77YscCJ2H0s=",
+      "requires": {
+        "pinkie-promise": "^2.0.0"
+      }
+    },
+    "path-is-absolute": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/path-is-absolute/-/path-is-absolute-1.0.1.tgz",
+      "integrity": "sha1-F0uSaHNVNP+8es5r9TpanhtcX18="
+    },
+    "path-is-inside": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/path-is-inside/-/path-is-inside-1.0.2.tgz",
+      "integrity": "sha1-NlQX3t5EQw0cEa9hAn+s8HS9/FM=",
+      "dev": true
+    },
+    "path-key": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/path-key/-/path-key-2.0.1.tgz",
+      "integrity": "sha1-QRyttXTFoUDTpLGRDUDYDMn0C0A=",
+      "dev": true
+    },
+    "path-parse": {
+      "version": "1.0.6",
+      "resolved": "https://registry.npmjs.org/path-parse/-/path-parse-1.0.6.tgz",
+      "integrity": "sha512-GSmOT2EbHrINBf9SR7CDELwlJ8AENk3Qn7OikK4nFYAu3Ote2+JYNVvkpAEQm3/TLNEJFD/xZJjzyxg3KBWOzw=="
+    },
+    "path-to-regexp": {
+      "version": "0.1.7",
+      "resolved": "https://registry.npmjs.org/path-to-regexp/-/path-to-regexp-0.1.7.tgz",
+      "integrity": "sha1-32BBeABfUi8V60SQ5yR6G/qmf4w="
+    },
+    "path-type": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/path-type/-/path-type-1.1.0.tgz",
+      "integrity": "sha1-WcRPfuSR2nBNpBXaWkBwuk+P5EE=",
+      "requires": {
+        "graceful-fs": "^4.1.2",
+        "pify": "^2.0.0",
+        "pinkie-promise": "^2.0.0"
+      }
+    },
+    "pathval": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/pathval/-/pathval-1.1.0.tgz",
+      "integrity": "sha1-uULm1L3mUwBe9rcTYd74cn0GReA=",
+      "dev": true
+    },
+    "pause": {
+      "version": "0.0.1",
+      "resolved": "https://registry.npmjs.org/pause/-/pause-0.0.1.tgz",
+      "integrity": "sha1-HUCLP9t2kjuVQ9lvtMnf1TXZy10="
+    },
+    "pend": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/pend/-/pend-1.2.0.tgz",
+      "integrity": "sha1-elfrVQpng/kRUzH89GY9XI4AelA="
+    },
+    "performance-now": {
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/performance-now/-/performance-now-2.1.0.tgz",
+      "integrity": "sha1-Ywn04OX6kT7BxpMHrjZLSzd8nns="
+    },
+    "pify": {
+      "version": "2.3.0",
+      "resolved": "https://registry.npmjs.org/pify/-/pify-2.3.0.tgz",
+      "integrity": "sha1-7RQaasBDqEnqWISY59yosVMw6Qw="
+    },
+    "pinkie": {
+      "version": "2.0.4",
+      "resolved": "https://registry.npmjs.org/pinkie/-/pinkie-2.0.4.tgz",
+      "integrity": "sha1-clVrgM+g1IqXToDnckjoDtT3+HA="
+    },
+    "pinkie-promise": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/pinkie-promise/-/pinkie-promise-2.0.1.tgz",
+      "integrity": "sha1-ITXW36ejWMBprJsXh3YogihFD/o=",
+      "requires": {
+        "pinkie": "^2.0.0"
+      }
+    },
+    "pkg": {
+      "version": "4.3.7",
+      "resolved": "https://registry.npmjs.org/pkg/-/pkg-4.3.7.tgz",
+      "integrity": "sha512-/BvtFft1nKKtnTuOm/0es0sk1cOs7ZtWgJpqdtszJ4348jYJ8owVyCB/iuGhI3YJFX/ZFIv4Rmra9ETUgpnnfA==",
+      "requires": {
+        "@babel/parser": "7.2.3",
+        "babel-runtime": "6.26.0",
+        "chalk": "2.4.2",
+        "escodegen": "1.11.0",
+        "fs-extra": "7.0.1",
+        "globby": "8.0.2",
+        "into-stream": "4.0.0",
+        "minimist": "1.2.0",
+        "multistream": "2.1.1",
+        "pkg-fetch": "2.5.7",
+        "progress": "2.0.3",
+        "resolve": "1.6.0",
+        "stream-meter": "1.0.4"
+      },
+      "dependencies": {
+        "ansi-styles": {
+          "version": "3.2.1",
+          "resolved": "https://registry.npmjs.org/ansi-styles/-/ansi-styles-3.2.1.tgz",
+          "integrity": "sha512-VT0ZI6kZRdTh8YyJw3SMbYm/u+NqfsAxEpWO0Pf9sq8/e94WxxOpPKx9FR1FlyCtOVDNOQ+8ntlqFxiRc+r5qA==",
+          "requires": {
+            "color-convert": "^1.9.0"
+          }
+        },
+        "chalk": {
+          "version": "2.4.2",
+          "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.4.2.tgz",
+          "integrity": "sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==",
+          "requires": {
+            "ansi-styles": "^3.2.1",
+            "escape-string-regexp": "^1.0.5",
+            "supports-color": "^5.3.0"
+          }
+        },
+        "fs-extra": {
+          "version": "7.0.1",
+          "resolved": "https://registry.npmjs.org/fs-extra/-/fs-extra-7.0.1.tgz",
+          "integrity": "sha512-YJDaCJZEnBmcbw13fvdAM9AwNOJwOzrE4pqMqBq5nFiEqXUqHwlK4B+3pUw6JNvfSPtX05xFHtYy/1ni01eGCw==",
+          "requires": {
+            "graceful-fs": "^4.1.2",
+            "jsonfile": "^4.0.0",
+            "universalify": "^0.1.0"
+          }
+        },
+        "jsonfile": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/jsonfile/-/jsonfile-4.0.0.tgz",
+          "integrity": "sha1-h3Gq4HmbZAdrdmQPygWPnBDjPss=",
+          "requires": {
+            "graceful-fs": "^4.1.6"
+          }
+        },
+        "minimist": {
+          "version": "1.2.0",
+          "resolved": "https://registry.npmjs.org/minimist/-/minimist-1.2.0.tgz",
+          "integrity": "sha1-o1AIsg9BOD7sH7kU9M1d95omQoQ="
+        },
+        "resolve": {
+          "version": "1.6.0",
+          "resolved": "https://registry.npmjs.org/resolve/-/resolve-1.6.0.tgz",
+          "integrity": "sha512-mw7JQNu5ExIkcw4LPih0owX/TZXjD/ZUF/ZQ/pDnkw3ZKhDcZZw5klmBlj6gVMwjQ3Pz5Jgu7F3d0jcDVuEWdw==",
+          "requires": {
+            "path-parse": "^1.0.5"
+          }
+        },
+        "supports-color": {
+          "version": "5.5.0",
+          "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-5.5.0.tgz",
+          "integrity": "sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==",
+          "requires": {
+            "has-flag": "^3.0.0"
+          }
+        }
+      }
+    },
+    "pkg-dir": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/pkg-dir/-/pkg-dir-3.0.0.tgz",
+      "integrity": "sha512-/E57AYkoeQ25qkxMj5PBOVgF8Kiu/h7cYS30Z5+R7WaiCCBfLq58ZI/dSeaEKb9WVJV5n/03QwrN3IeWIFllvw==",
+      "dev": true,
+      "requires": {
+        "find-up": "^3.0.0"
+      },
+      "dependencies": {
+        "find-up": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/find-up/-/find-up-3.0.0.tgz",
+          "integrity": "sha512-1yD6RmLI1XBfxugvORwlck6f75tYL+iR0jqwsOrOxMZyGYqUuDhJ0l4AXdO1iX/FTs9cBAMEk1gWSEx1kSbylg==",
+          "dev": true,
+          "requires": {
+            "locate-path": "^3.0.0"
+          }
+        }
+      }
+    },
+    "pkg-fetch": {
+      "version": "2.5.7",
+      "resolved": "https://registry.npmjs.org/pkg-fetch/-/pkg-fetch-2.5.7.tgz",
+      "integrity": "sha512-fm9aVV3ZRdFYTyFYcSHuKMuxPCVQ0MD9tbVxbvQzFTg1gwvV0KqWrFoj5enVVha94yP83I50XEBa90X8L9fE8w==",
+      "requires": {
+        "babel-runtime": "~6.26.0",
+        "byline": "~5.0.0",
+        "chalk": "~2.4.1",
+        "expand-template": "~1.1.1",
+        "fs-extra": "~6.0.1",
+        "in-publish": "~2.0.0",
+        "minimist": "~1.2.0",
+        "progress": "~2.0.0",
+        "request": "~2.88.0",
+        "request-progress": "~3.0.0",
+        "semver": "~5.6.0",
+        "unique-temp-dir": "~1.0.0"
+      },
+      "dependencies": {
+        "ansi-styles": {
+          "version": "3.2.1",
+          "resolved": "https://registry.npmjs.org/ansi-styles/-/ansi-styles-3.2.1.tgz",
+          "integrity": "sha512-VT0ZI6kZRdTh8YyJw3SMbYm/u+NqfsAxEpWO0Pf9sq8/e94WxxOpPKx9FR1FlyCtOVDNOQ+8ntlqFxiRc+r5qA==",
+          "requires": {
+            "color-convert": "^1.9.0"
+          }
+        },
+        "chalk": {
+          "version": "2.4.2",
+          "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.4.2.tgz",
+          "integrity": "sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==",
+          "requires": {
+            "ansi-styles": "^3.2.1",
+            "escape-string-regexp": "^1.0.5",
+            "supports-color": "^5.3.0"
+          }
+        },
+        "fs-extra": {
+          "version": "6.0.1",
+          "resolved": "https://registry.npmjs.org/fs-extra/-/fs-extra-6.0.1.tgz",
+          "integrity": "sha512-GnyIkKhhzXZUWFCaJzvyDLEEgDkPfb4/TPvJCJVuS8MWZgoSsErf++QpiAlDnKFcqhRlm+tIOcencCjyJE6ZCA==",
+          "requires": {
+            "graceful-fs": "^4.1.2",
+            "jsonfile": "^4.0.0",
+            "universalify": "^0.1.0"
+          }
+        },
+        "jsonfile": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/jsonfile/-/jsonfile-4.0.0.tgz",
+          "integrity": "sha1-h3Gq4HmbZAdrdmQPygWPnBDjPss=",
+          "requires": {
+            "graceful-fs": "^4.1.6"
+          }
+        },
+        "minimist": {
+          "version": "1.2.0",
+          "resolved": "https://registry.npmjs.org/minimist/-/minimist-1.2.0.tgz",
+          "integrity": "sha1-o1AIsg9BOD7sH7kU9M1d95omQoQ="
+        },
+        "semver": {
+          "version": "5.6.0",
+          "resolved": "https://registry.npmjs.org/semver/-/semver-5.6.0.tgz",
+          "integrity": "sha512-RS9R6R35NYgQn++fkDWaOmqGoj4Ek9gGs+DPxNUZKuwE183xjJroKvyo1IzVFeXvUrvmALy6FWD5xrdJT25gMg=="
+        },
+        "supports-color": {
+          "version": "5.5.0",
+          "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-5.5.0.tgz",
+          "integrity": "sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==",
+          "requires": {
+            "has-flag": "^3.0.0"
+          }
+        }
+      }
+    },
+    "posix-character-classes": {
+      "version": "0.1.1",
+      "resolved": "https://registry.npmjs.org/posix-character-classes/-/posix-character-classes-0.1.1.tgz",
+      "integrity": "sha1-AerA/jta9xoqbAL+q7jB/vfgDqs="
+    },
+    "prelude-ls": {
+      "version": "1.1.2",
+      "resolved": "https://registry.npmjs.org/prelude-ls/-/prelude-ls-1.1.2.tgz",
+      "integrity": "sha1-IZMqVJ9eUv/ZqCf1cOBL5iqX2lQ="
+    },
+    "preserve": {
+      "version": "0.2.0",
+      "resolved": "https://registry.npmjs.org/preserve/-/preserve-0.2.0.tgz",
+      "integrity": "sha1-gV7R9uvGWSb4ZbMQwHE7yzMVzks=",
+      "optional": true
+    },
+    "private": {
+      "version": "0.1.8",
+      "resolved": "https://registry.npmjs.org/private/-/private-0.1.8.tgz",
+      "integrity": "sha512-VvivMrbvd2nKkiG38qjULzlc+4Vx4wm/whI9pQD35YrARNnhxeiRktSOhSukRLFNlzg6Br/cJPet5J/u19r/mg=="
+    },
+    "process-nextick-args": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/process-nextick-args/-/process-nextick-args-2.0.0.tgz",
+      "integrity": "sha512-MtEC1TqN0EU5nephaJ4rAtThHtC86dNN9qCuEhtshvpVBkAW5ZO7BASN9REnF9eoXGcRub+pFuKEpOHE+HbEMw=="
+    },
+    "progress": {
+      "version": "2.0.3",
+      "resolved": "https://registry.npmjs.org/progress/-/progress-2.0.3.tgz",
+      "integrity": "sha512-7PiHtLll5LdnKIMw100I+8xJXR5gW2QwWYkT6iJva0bXitZKa/XMrSbdmg3r2Xnaidz9Qumd0VPaMrZlF9V9sA=="
+    },
+    "proxy-addr": {
+      "version": "2.0.5",
+      "resolved": "https://registry.npmjs.org/proxy-addr/-/proxy-addr-2.0.5.tgz",
+      "integrity": "sha512-t/7RxHXPH6cJtP0pRG6smSr9QJidhB+3kXu0KgXnbGYMgzEnUxRQ4/LDdfOwZEMyIh3/xHb8PX3t+lfL9z+YVQ==",
+      "requires": {
+        "forwarded": "~0.1.2",
+        "ipaddr.js": "1.9.0"
+      }
+    },
+    "psl": {
+      "version": "1.1.31",
+      "resolved": "https://registry.npmjs.org/psl/-/psl-1.1.31.tgz",
+      "integrity": "sha512-/6pt4+C+T+wZUieKR620OpzN/LlnNKuWjy1iFLQ/UG35JqHlR/89MP1d96dUfkf6Dne3TuLQzOYEYshJ+Hx8mw=="
+    },
+    "pump": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/pump/-/pump-3.0.0.tgz",
+      "integrity": "sha512-LwZy+p3SFs1Pytd/jYct4wpv49HiYCqd9Rlc5ZVdk0V+8Yzv6jR5Blk3TRmPL1ft69TxP0IMZGJ+WPFU2BFhww==",
+      "dev": true,
+      "requires": {
+        "end-of-stream": "^1.1.0",
+        "once": "^1.3.1"
+      }
+    },
+    "punycode": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/punycode/-/punycode-2.1.1.tgz",
+      "integrity": "sha512-XRsRjdf+j5ml+y/6GKHPZbrF/8p2Yga0JPtdqTIY2Xe5ohJPD9saDJJLPvp9+NSBprVvevdXZybnj2cv8OEd0A=="
+    },
+    "qs": {
+      "version": "6.7.0",
+      "resolved": "https://registry.npmjs.org/qs/-/qs-6.7.0.tgz",
+      "integrity": "sha512-VCdBRNFTX1fyE7Nb6FYoURo/SPe62QCaAyzJvUjwRaIsc+NePBEniHlvxFmmX56+HZphIGtV0XeCirBtpDrTyQ=="
+    },
+    "random-bytes": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/random-bytes/-/random-bytes-1.0.0.tgz",
+      "integrity": "sha1-T2ih3Arli9P7lYSMMDJNt11kNgs="
+    },
+    "randomatic": {
+      "version": "3.1.1",
+      "resolved": "https://registry.npmjs.org/randomatic/-/randomatic-3.1.1.tgz",
+      "integrity": "sha512-TuDE5KxZ0J461RVjrJZCJc+J+zCkTb1MbH9AQUq68sMhOMcy9jLcb3BrZKgp9q9Ncltdg4QVqWrH02W2EFFVYw==",
+      "optional": true,
+      "requires": {
+        "is-number": "^4.0.0",
+        "kind-of": "^6.0.0",
+        "math-random": "^1.0.1"
+      },
+      "dependencies": {
+        "is-number": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/is-number/-/is-number-4.0.0.tgz",
+          "integrity": "sha512-rSklcAIlf1OmFdyAqbnWTLVelsQ58uvZ66S/ZyawjWqIviTWCjg2PzVGw8WUA+nNuPTqb4wgA+NszrJ+08LlgQ==",
+          "optional": true
+        },
+        "kind-of": {
+          "version": "6.0.2",
+          "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-6.0.2.tgz",
+          "integrity": "sha512-s5kLOcnH0XqDO+FvuaLX8DDjZ18CGFk7VygH40QoKPUQhW4e2rvM0rwUq0t8IQDOwYSeLK01U90OjzBTme2QqA==",
+          "optional": true
+        }
+      }
+    },
+    "range-parser": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/range-parser/-/range-parser-1.2.0.tgz",
+      "integrity": "sha1-9JvmtIeJTdxA3MlKMi9hEJLgDV4="
+    },
+    "raw-body": {
+      "version": "2.4.0",
+      "resolved": "https://registry.npmjs.org/raw-body/-/raw-body-2.4.0.tgz",
+      "integrity": "sha512-4Oz8DUIwdvoa5qMJelxipzi/iJIi40O5cGV1wNYp5hvZP8ZN0T+jiNkL0QepXs+EsQ9XJ8ipEDoiH70ySUJP3Q==",
+      "requires": {
+        "bytes": "3.1.0",
+        "http-errors": "1.7.2",
+        "iconv-lite": "0.4.24",
+        "unpipe": "1.0.0"
+      }
+    },
+    "read-pkg": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/read-pkg/-/read-pkg-1.1.0.tgz",
+      "integrity": "sha1-9f+qXs0pyzHAR0vKfXVra7KePyg=",
+      "requires": {
+        "load-json-file": "^1.0.0",
+        "normalize-package-data": "^2.3.2",
+        "path-type": "^1.0.0"
+      }
+    },
+    "read-pkg-up": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/read-pkg-up/-/read-pkg-up-1.0.1.tgz",
+      "integrity": "sha1-nWPBMnbAZZGNV/ACpX9AobZD+wI=",
+      "requires": {
+        "find-up": "^1.0.0",
+        "read-pkg": "^1.0.0"
+      }
+    },
+    "readable-stream": {
+      "version": "2.3.6",
+      "resolved": "https://registry.npmjs.org/readable-stream/-/readable-stream-2.3.6.tgz",
+      "integrity": "sha512-tQtKA9WIAhBF3+VLAseyMqZeBjW0AHJoxOtYqSUZNJxauErmLbVm2FW1y+J/YA9dUrAC39ITejlZWhVIwawkKw==",
+      "requires": {
+        "core-util-is": "~1.0.0",
+        "inherits": "~2.0.3",
+        "isarray": "~1.0.0",
+        "process-nextick-args": "~2.0.0",
+        "safe-buffer": "~5.1.1",
+        "string_decoder": "~1.1.1",
+        "util-deprecate": "~1.0.1"
+      }
+    },
+    "readdirp": {
+      "version": "2.2.1",
+      "resolved": "https://registry.npmjs.org/readdirp/-/readdirp-2.2.1.tgz",
+      "integrity": "sha512-1JU/8q+VgFZyxwrJ+SVIOsh+KywWGpds3NTqikiKpDMZWScmAYyKIgqkO+ARvNWJfXeXR1zxz7aHF4u4CyH6vQ==",
+      "optional": true,
+      "requires": {
+        "graceful-fs": "^4.1.11",
+        "micromatch": "^3.1.10",
+        "readable-stream": "^2.0.2"
+      },
+      "dependencies": {
+        "arr-diff": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/arr-diff/-/arr-diff-4.0.0.tgz",
+          "integrity": "sha1-1kYQdP6/7HHn4VI1dhoyml3HxSA=",
+          "optional": true
+        },
+        "array-unique": {
+          "version": "0.3.2",
+          "resolved": "https://registry.npmjs.org/array-unique/-/array-unique-0.3.2.tgz",
+          "integrity": "sha1-qJS3XUvE9s1nnvMkSp/Y9Gri1Cg="
+        },
+        "braces": {
+          "version": "2.3.2",
+          "resolved": "https://registry.npmjs.org/braces/-/braces-2.3.2.tgz",
+          "integrity": "sha512-aNdbnj9P8PjdXU4ybaWLK2IF3jc/EoDYbC7AazW6to3TRsfXxscC9UXOB5iDiEQrkyIbWp2SLQda4+QAa7nc3w==",
+          "optional": true,
+          "requires": {
+            "arr-flatten": "^1.1.0",
+            "array-unique": "^0.3.2",
+            "extend-shallow": "^2.0.1",
+            "fill-range": "^4.0.0",
+            "isobject": "^3.0.1",
+            "repeat-element": "^1.1.2",
+            "snapdragon": "^0.8.1",
+            "snapdragon-node": "^2.0.1",
+            "split-string": "^3.0.2",
+            "to-regex": "^3.0.1"
+          },
+          "dependencies": {
+            "extend-shallow": {
+              "version": "2.0.1",
+              "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+              "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+              "optional": true,
+              "requires": {
+                "is-extendable": "^0.1.0"
+              }
+            }
+          }
+        },
+        "expand-brackets": {
+          "version": "2.1.4",
+          "resolved": "https://registry.npmjs.org/expand-brackets/-/expand-brackets-2.1.4.tgz",
+          "integrity": "sha1-t3c14xXOMPa27/D4OwQVGiJEliI=",
+          "optional": true,
+          "requires": {
+            "debug": "^2.3.3",
+            "define-property": "^0.2.5",
+            "extend-shallow": "^2.0.1",
+            "posix-character-classes": "^0.1.0",
+            "regex-not": "^1.0.0",
+            "snapdragon": "^0.8.1",
+            "to-regex": "^3.0.1"
+          },
+          "dependencies": {
+            "define-property": {
+              "version": "0.2.5",
+              "resolved": "https://registry.npmjs.org/define-property/-/define-property-0.2.5.tgz",
+              "integrity": "sha1-w1se+RjsPJkPmlvFe+BKrOxcgRY=",
+              "optional": true,
+              "requires": {
+                "is-descriptor": "^0.1.0"
+              }
+            },
+            "extend-shallow": {
+              "version": "2.0.1",
+              "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+              "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+              "optional": true,
+              "requires": {
+                "is-extendable": "^0.1.0"
+              }
+            },
+            "is-accessor-descriptor": {
+              "version": "0.1.6",
+              "resolved": "https://registry.npmjs.org/is-accessor-descriptor/-/is-accessor-descriptor-0.1.6.tgz",
+              "integrity": "sha1-qeEss66Nh2cn7u84Q/igiXtcmNY=",
+              "optional": true,
+              "requires": {
+                "kind-of": "^3.0.2"
+              },
+              "dependencies": {
+                "kind-of": {
+                  "version": "3.2.2",
+                  "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-3.2.2.tgz",
+                  "integrity": "sha1-MeohpzS6ubuw8yRm2JOupR5KPGQ=",
+                  "optional": true,
+                  "requires": {
+                    "is-buffer": "^1.1.5"
+                  }
+                }
+              }
+            },
+            "is-data-descriptor": {
+              "version": "0.1.4",
+              "resolved": "https://registry.npmjs.org/is-data-descriptor/-/is-data-descriptor-0.1.4.tgz",
+              "integrity": "sha1-C17mSDiOLIYCgueT8YVv7D8wG1Y=",
+              "optional": true,
+              "requires": {
+                "kind-of": "^3.0.2"
+              },
+              "dependencies": {
+                "kind-of": {
+                  "version": "3.2.2",
+                  "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-3.2.2.tgz",
+                  "integrity": "sha1-MeohpzS6ubuw8yRm2JOupR5KPGQ=",
+                  "optional": true,
+                  "requires": {
+                    "is-buffer": "^1.1.5"
+                  }
+                }
+              }
+            },
+            "is-descriptor": {
+              "version": "0.1.6",
+              "resolved": "https://registry.npmjs.org/is-descriptor/-/is-descriptor-0.1.6.tgz",
+              "integrity": "sha512-avDYr0SB3DwO9zsMov0gKCESFYqCnE4hq/4z3TdUlukEy5t9C0YRq7HLrsN52NAcqXKaepeCD0n+B0arnVG3Hg==",
+              "optional": true,
+              "requires": {
+                "is-accessor-descriptor": "^0.1.6",
+                "is-data-descriptor": "^0.1.4",
+                "kind-of": "^5.0.0"
+              }
+            },
+            "kind-of": {
+              "version": "5.1.0",
+              "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-5.1.0.tgz",
+              "integrity": "sha512-NGEErnH6F2vUuXDh+OlbcKW7/wOcfdRHaZ7VWtqCztfHri/++YKmP51OdWeGPuqCOba6kk2OTe5d02VmTB80Pw==",
+              "optional": true
+            }
+          }
+        },
+        "extglob": {
+          "version": "2.0.4",
+          "resolved": "https://registry.npmjs.org/extglob/-/extglob-2.0.4.tgz",
+          "integrity": "sha512-Nmb6QXkELsuBr24CJSkilo6UHHgbekK5UiZgfE6UHD3Eb27YC6oD+bhcT+tJ6cl8dmsgdQxnWlcry8ksBIBLpw==",
+          "optional": true,
+          "requires": {
+            "array-unique": "^0.3.2",
+            "define-property": "^1.0.0",
+            "expand-brackets": "^2.1.4",
+            "extend-shallow": "^2.0.1",
+            "fragment-cache": "^0.2.1",
+            "regex-not": "^1.0.0",
+            "snapdragon": "^0.8.1",
+            "to-regex": "^3.0.1"
+          },
+          "dependencies": {
+            "define-property": {
+              "version": "1.0.0",
+              "resolved": "https://registry.npmjs.org/define-property/-/define-property-1.0.0.tgz",
+              "integrity": "sha1-dp66rz9KY6rTr56NMEybvnm/sOY=",
+              "optional": true,
+              "requires": {
+                "is-descriptor": "^1.0.0"
+              }
+            },
+            "extend-shallow": {
+              "version": "2.0.1",
+              "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+              "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+              "optional": true,
+              "requires": {
+                "is-extendable": "^0.1.0"
+              }
+            }
+          }
+        },
+        "fill-range": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/fill-range/-/fill-range-4.0.0.tgz",
+          "integrity": "sha1-1USBHUKPmOsGpj3EAtJAPDKMOPc=",
+          "optional": true,
+          "requires": {
+            "extend-shallow": "^2.0.1",
+            "is-number": "^3.0.0",
+            "repeat-string": "^1.6.1",
+            "to-regex-range": "^2.1.0"
+          },
+          "dependencies": {
+            "extend-shallow": {
+              "version": "2.0.1",
+              "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+              "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+              "optional": true,
+              "requires": {
+                "is-extendable": "^0.1.0"
+              }
+            }
+          }
+        },
+        "is-accessor-descriptor": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-accessor-descriptor/-/is-accessor-descriptor-1.0.0.tgz",
+          "integrity": "sha512-m5hnHTkcVsPfqx3AKlyttIPb7J+XykHvJP2B9bZDjlhLIoEq4XoK64Vg7boZlVWYK6LUY94dYPEE7Lh0ZkZKcQ==",
+          "optional": true,
+          "requires": {
+            "kind-of": "^6.0.0"
+          }
+        },
+        "is-data-descriptor": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-data-descriptor/-/is-data-descriptor-1.0.0.tgz",
+          "integrity": "sha512-jbRXy1FmtAoCjQkVmIVYwuuqDFUbaOeDjmed1tOGPrsMhtJA4rD9tkgA0F1qJ3gRFRXcHYVkdeaP50Q5rE/jLQ==",
+          "optional": true,
+          "requires": {
+            "kind-of": "^6.0.0"
+          }
+        },
+        "is-descriptor": {
+          "version": "1.0.2",
+          "resolved": "https://registry.npmjs.org/is-descriptor/-/is-descriptor-1.0.2.tgz",
+          "integrity": "sha512-2eis5WqQGV7peooDyLmNEPUrps9+SXX5c9pL3xEB+4e9HnGuDa7mB7kHxHw4CbqS9k1T2hOH3miL8n8WtiYVtg==",
+          "optional": true,
+          "requires": {
+            "is-accessor-descriptor": "^1.0.0",
+            "is-data-descriptor": "^1.0.0",
+            "kind-of": "^6.0.2"
+          }
+        },
+        "is-number": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/is-number/-/is-number-3.0.0.tgz",
+          "integrity": "sha1-JP1iAaR4LPUFYcgQJ2r8fRLXEZU=",
+          "optional": true,
+          "requires": {
+            "kind-of": "^3.0.2"
+          },
+          "dependencies": {
+            "kind-of": {
+              "version": "3.2.2",
+              "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-3.2.2.tgz",
+              "integrity": "sha1-MeohpzS6ubuw8yRm2JOupR5KPGQ=",
+              "optional": true,
+              "requires": {
+                "is-buffer": "^1.1.5"
+              }
+            }
+          }
+        },
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8=",
+          "optional": true
+        },
+        "kind-of": {
+          "version": "6.0.2",
+          "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-6.0.2.tgz",
+          "integrity": "sha512-s5kLOcnH0XqDO+FvuaLX8DDjZ18CGFk7VygH40QoKPUQhW4e2rvM0rwUq0t8IQDOwYSeLK01U90OjzBTme2QqA=="
+        },
+        "micromatch": {
+          "version": "3.1.10",
+          "resolved": "https://registry.npmjs.org/micromatch/-/micromatch-3.1.10.tgz",
+          "integrity": "sha512-MWikgl9n9M3w+bpsY3He8L+w9eF9338xRl8IAO5viDizwSzziFEyUzo2xrrloB64ADbTf8uA8vRqqttDTOmccg==",
+          "optional": true,
+          "requires": {
+            "arr-diff": "^4.0.0",
+            "array-unique": "^0.3.2",
+            "braces": "^2.3.1",
+            "define-property": "^2.0.2",
+            "extend-shallow": "^3.0.2",
+            "extglob": "^2.0.4",
+            "fragment-cache": "^0.2.1",
+            "kind-of": "^6.0.2",
+            "nanomatch": "^1.2.9",
+            "object.pick": "^1.3.0",
+            "regex-not": "^1.0.0",
+            "snapdragon": "^0.8.1",
+            "to-regex": "^3.0.2"
+          }
+        }
+      }
+    },
+    "readline2": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/readline2/-/readline2-1.0.1.tgz",
+      "integrity": "sha1-QQWWCP/BVHV7cV2ZidGZ/783LjU=",
+      "requires": {
+        "code-point-at": "^1.0.0",
+        "is-fullwidth-code-point": "^1.0.0",
+        "mute-stream": "0.0.5"
+      }
+    },
+    "regenerate": {
+      "version": "1.4.0",
+      "resolved": "https://registry.npmjs.org/regenerate/-/regenerate-1.4.0.tgz",
+      "integrity": "sha512-1G6jJVDWrt0rK99kBjvEtziZNCICAuvIPkSiUFIQxVP06RCVpq3dmDo2oi6ABpYaDYaTRr67BEhL8r1wgEZZKg=="
+    },
+    "regenerator-runtime": {
+      "version": "0.11.1",
+      "resolved": "https://registry.npmjs.org/regenerator-runtime/-/regenerator-runtime-0.11.1.tgz",
+      "integrity": "sha512-MguG95oij0fC3QV3URf4V2SDYGJhJnJGqvIIgdECeODCT98wSWDAJ94SSuVpYQUoTcGUIL6L4yNB7j1DFFHSBg=="
+    },
+    "regenerator-transform": {
+      "version": "0.10.1",
+      "resolved": "https://registry.npmjs.org/regenerator-transform/-/regenerator-transform-0.10.1.tgz",
+      "integrity": "sha512-PJepbvDbuK1xgIgnau7Y90cwaAmO/LCLMI2mPvaXq2heGMR3aWW5/BQvYrhJ8jgmQjXewXvBjzfqKcVOmhjZ6Q==",
+      "requires": {
+        "babel-runtime": "^6.18.0",
+        "babel-types": "^6.19.0",
+        "private": "^0.1.6"
+      }
+    },
+    "regex-cache": {
+      "version": "0.4.4",
+      "resolved": "https://registry.npmjs.org/regex-cache/-/regex-cache-0.4.4.tgz",
+      "integrity": "sha512-nVIZwtCjkC9YgvWkpM55B5rBhBYRZhAaJbgcFYXXsHnbZ9UZI9nnVWYZpBlCqv9ho2eZryPnWrZGsOdPwVWXWQ==",
+      "optional": true,
+      "requires": {
+        "is-equal-shallow": "^0.1.3"
+      }
+    },
+    "regex-not": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/regex-not/-/regex-not-1.0.2.tgz",
+      "integrity": "sha512-J6SDjUgDxQj5NusnOtdFxDwN/+HWykR8GELwctJ7mdqhcyy1xEc4SRFHUXvxTp661YaVKAjfRLZ9cCqS6tn32A==",
+      "requires": {
+        "extend-shallow": "^3.0.2",
+        "safe-regex": "^1.1.0"
+      }
+    },
+    "regexp-clone": {
+      "version": "0.0.1",
+      "resolved": "https://registry.npmjs.org/regexp-clone/-/regexp-clone-0.0.1.tgz",
+      "integrity": "sha1-p8LgmJH9vzj7sQ03b7cwA+aKxYk="
+    },
+    "regexpp": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/regexpp/-/regexpp-2.0.1.tgz",
+      "integrity": "sha512-lv0M6+TkDVniA3aD1Eg0DVpfU/booSu7Eev3TDO/mZKHBfVjgCGTV4t4buppESEYDtkArYFOxTJWv6S5C+iaNw==",
+      "dev": true
+    },
+    "regexpu-core": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/regexpu-core/-/regexpu-core-2.0.0.tgz",
+      "integrity": "sha1-SdA4g3uNz4v6W5pCE5k45uoq4kA=",
+      "requires": {
+        "regenerate": "^1.2.1",
+        "regjsgen": "^0.2.0",
+        "regjsparser": "^0.1.4"
+      }
+    },
+    "regjsgen": {
+      "version": "0.2.0",
+      "resolved": "https://registry.npmjs.org/regjsgen/-/regjsgen-0.2.0.tgz",
+      "integrity": "sha1-bAFq3qxVT3WCP+N6wFuS1aTtsfc="
+    },
+    "regjsparser": {
+      "version": "0.1.5",
+      "resolved": "https://registry.npmjs.org/regjsparser/-/regjsparser-0.1.5.tgz",
+      "integrity": "sha1-fuj4Tcb6eS0/0K4ijSS9lJ6tIFw=",
+      "requires": {
+        "jsesc": "~0.5.0"
+      },
+      "dependencies": {
+        "jsesc": {
+          "version": "0.5.0",
+          "resolved": "https://registry.npmjs.org/jsesc/-/jsesc-0.5.0.tgz",
+          "integrity": "sha1-597mbjXW/Bb3EP6R1c9p9w8IkR0="
+        }
+      }
+    },
+    "remove-trailing-separator": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/remove-trailing-separator/-/remove-trailing-separator-1.1.0.tgz",
+      "integrity": "sha1-wkvOKig62tW8P1jg1IJJuSN52O8="
+    },
+    "repeat-element": {
+      "version": "1.1.3",
+      "resolved": "https://registry.npmjs.org/repeat-element/-/repeat-element-1.1.3.tgz",
+      "integrity": "sha512-ahGq0ZnV5m5XtZLMb+vP76kcAM5nkLqk0lpqAuojSKGgQtn4eRi4ZZGm2olo2zKFH+sMsWaqOCW1dqAnOru72g=="
+    },
+    "repeat-string": {
+      "version": "1.6.1",
+      "resolved": "https://registry.npmjs.org/repeat-string/-/repeat-string-1.6.1.tgz",
+      "integrity": "sha1-jcrkcOHIirwtYA//Sndihtp15jc="
+    },
+    "repeating": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/repeating/-/repeating-2.0.1.tgz",
+      "integrity": "sha1-UhTFOpJtNVJwdSf7q0FdvAjQbdo=",
+      "requires": {
+        "is-finite": "^1.0.0"
+      }
+    },
+    "request": {
+      "version": "2.88.0",
+      "resolved": "https://registry.npmjs.org/request/-/request-2.88.0.tgz",
+      "integrity": "sha512-NAqBSrijGLZdM0WZNsInLJpkJokL72XYjUpnB0iwsRgxh7dB6COrHnTBNwN0E+lHDAJzu7kLAkDeY08z2/A0hg==",
+      "requires": {
+        "aws-sign2": "~0.7.0",
+        "aws4": "^1.8.0",
+        "caseless": "~0.12.0",
+        "combined-stream": "~1.0.6",
+        "extend": "~3.0.2",
+        "forever-agent": "~0.6.1",
+        "form-data": "~2.3.2",
+        "har-validator": "~5.1.0",
+        "http-signature": "~1.2.0",
+        "is-typedarray": "~1.0.0",
+        "isstream": "~0.1.2",
+        "json-stringify-safe": "~5.0.1",
+        "mime-types": "~2.1.19",
+        "oauth-sign": "~0.9.0",
+        "performance-now": "^2.1.0",
+        "qs": "~6.5.2",
+        "safe-buffer": "^5.1.2",
+        "tough-cookie": "~2.4.3",
+        "tunnel-agent": "^0.6.0",
+        "uuid": "^3.3.2"
+      },
+      "dependencies": {
+        "qs": {
+          "version": "6.5.2",
+          "resolved": "https://registry.npmjs.org/qs/-/qs-6.5.2.tgz",
+          "integrity": "sha512-N5ZAX4/LxJmF+7wN74pUD6qAh9/wnvdQcjq9TZjevvXzSUo7bfmw91saqMjzGS2xq91/odN2dW/WOl7qQHNDGA=="
+        }
+      }
+    },
+    "request-progress": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/request-progress/-/request-progress-3.0.0.tgz",
+      "integrity": "sha1-TKdUCBx/7GP1BeT6qCWqBs1mnb4=",
+      "requires": {
+        "throttleit": "^1.0.0"
+      }
+    },
+    "request-promise": {
+      "version": "4.2.4",
+      "resolved": "https://registry.npmjs.org/request-promise/-/request-promise-4.2.4.tgz",
+      "integrity": "sha512-8wgMrvE546PzbR5WbYxUQogUnUDfM0S7QIFZMID+J73vdFARkFy+HElj4T+MWYhpXwlLp0EQ8Zoj8xUA0he4Vg==",
+      "requires": {
+        "bluebird": "^3.5.0",
+        "request-promise-core": "1.1.2",
+        "stealthy-require": "^1.1.1",
+        "tough-cookie": "^2.3.3"
+      }
+    },
+    "request-promise-core": {
+      "version": "1.1.2",
+      "resolved": "https://registry.npmjs.org/request-promise-core/-/request-promise-core-1.1.2.tgz",
+      "integrity": "sha512-UHYyq1MO8GsefGEt7EprS8UrXsm1TxEvFUX1IMTuSLU2Rh7fTIdFtl8xD7JiEYiWU2dl+NYAjCTksTehQUxPag==",
+      "requires": {
+        "lodash": "^4.17.11"
+      }
+    },
+    "require-directory": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/require-directory/-/require-directory-2.1.1.tgz",
+      "integrity": "sha1-jGStX9MNqxyXbiNE/+f3kqam30I="
+    },
+    "require-main-filename": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-1.0.1.tgz",
+      "integrity": "sha1-l/cXtp1IeE9fUmpsWqj/3aBVpNE="
+    },
+    "require_optional": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/require_optional/-/require_optional-1.0.1.tgz",
+      "integrity": "sha512-qhM/y57enGWHAe3v/NcwML6a3/vfESLe/sGM2dII+gEO0BpKRUkWZow/tyloNqJyN6kXSl3RyyM8Ll5D/sJP8g==",
+      "requires": {
+        "resolve-from": "^2.0.0",
+        "semver": "^5.1.0"
+      }
+    },
+    "resolve": {
+      "version": "1.10.1",
+      "resolved": "https://registry.npmjs.org/resolve/-/resolve-1.10.1.tgz",
+      "integrity": "sha512-KuIe4mf++td/eFb6wkaPbMDnP6kObCaEtIDuHOUED6MNUo4K670KZUHuuvYPZDxNF0WVLw49n06M2m2dXphEzA==",
+      "requires": {
+        "path-parse": "^1.0.6"
+      }
+    },
+    "resolve-from": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/resolve-from/-/resolve-from-2.0.0.tgz",
+      "integrity": "sha1-lICrIOlP+h2egKgEx+oUdhGWa1c="
+    },
+    "resolve-url": {
+      "version": "0.2.1",
+      "resolved": "https://registry.npmjs.org/resolve-url/-/resolve-url-0.2.1.tgz",
+      "integrity": "sha1-LGN/53yJOv0qZj/iGqkIAGjiBSo="
+    },
+    "restore-cursor": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/restore-cursor/-/restore-cursor-1.0.1.tgz",
+      "integrity": "sha1-NGYfRohjJ/7SmRR5FSJS35LapUE=",
+      "requires": {
+        "exit-hook": "^1.0.0",
+        "onetime": "^1.0.0"
+      }
+    },
+    "ret": {
+      "version": "0.1.15",
+      "resolved": "https://registry.npmjs.org/ret/-/ret-0.1.15.tgz",
+      "integrity": "sha512-TTlYpa+OL+vMMNG24xSlQGEJ3B/RzEfUlLct7b5G/ytav+wPrplCpVMFuwzXbkecJrb6IYo1iFb0S9v37754mg=="
+    },
+    "rimraf": {
+      "version": "2.6.3",
+      "resolved": "https://registry.npmjs.org/rimraf/-/rimraf-2.6.3.tgz",
+      "integrity": "sha512-mwqeW5XsA2qAejG46gYdENaxXjx9onRNCfn7L0duuP4hCuTIi/QO7PDK07KJfp1d+izWPrzEJDcSqBa0OZQriA==",
+      "dev": true,
+      "requires": {
+        "glob": "^7.1.3"
+      }
+    },
+    "run-async": {
+      "version": "0.1.0",
+      "resolved": "https://registry.npmjs.org/run-async/-/run-async-0.1.0.tgz",
+      "integrity": "sha1-yK1KXhEGYeQCp9IbUw4AnyX444k=",
+      "requires": {
+        "once": "^1.3.0"
+      }
+    },
+    "rx-lite": {
+      "version": "3.1.2",
+      "resolved": "https://registry.npmjs.org/rx-lite/-/rx-lite-3.1.2.tgz",
+      "integrity": "sha1-Gc5QLKVyZl87ZHsQk5+X/RYV8QI="
+    },
+    "rxjs": {
+      "version": "6.5.1",
+      "resolved": "https://registry.npmjs.org/rxjs/-/rxjs-6.5.1.tgz",
+      "integrity": "sha512-y0j31WJc83wPu31vS1VlAFW5JGrnGC+j+TtGAa1fRQphy48+fDYiDmX8tjGloToEsMkxnouOg/1IzXGKkJnZMg==",
+      "dev": true,
+      "requires": {
+        "tslib": "^1.9.0"
+      }
+    },
+    "safe-buffer": {
+      "version": "5.1.2",
+      "resolved": "https://registry.npmjs.org/safe-buffer/-/safe-buffer-5.1.2.tgz",
+      "integrity": "sha512-Gd2UZBJDkXlY7GbJxfsE8/nvKkUEU1G38c1siN6QP6a9PT9MmHB8GnpscSmMJSoF8LOIrt8ud/wPtojys4G6+g=="
+    },
+    "safe-regex": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/safe-regex/-/safe-regex-1.1.0.tgz",
+      "integrity": "sha1-QKNmnzsHfR6UPURinhV91IAjvy4=",
+      "requires": {
+        "ret": "~0.1.10"
+      }
+    },
+    "safer-buffer": {
+      "version": "2.1.2",
+      "resolved": "https://registry.npmjs.org/safer-buffer/-/safer-buffer-2.1.2.tgz",
+      "integrity": "sha512-YZo3K82SD7Riyi0E1EQPojLz7kpepnSQI9IyPbHHg1XXXevb5dJI7tpyN2ADxGcQbHG7vcyRHk0cbwqcQriUtg=="
+    },
+    "saslprep": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/saslprep/-/saslprep-1.0.2.tgz",
+      "integrity": "sha512-4cDsYuAjXssUSjxHKRe4DTZC0agDwsCqcMqtJAQPzC74nJ7LfAJflAtC1Zed5hMzEQKj82d3tuzqdGNRsLJ4Gw==",
+      "optional": true,
+      "requires": {
+        "sparse-bitfield": "^3.0.3"
+      }
+    },
+    "scmp": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/scmp/-/scmp-2.0.0.tgz",
+      "integrity": "sha1-JHEQ7yLM+JexOj8KvdtSeCOTzWo="
+    },
+    "secure-keys": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/secure-keys/-/secure-keys-1.0.0.tgz",
+      "integrity": "sha1-8MgtmKOxOah3aogIBQuCRDEIf8o="
+    },
+    "seek-bzip": {
+      "version": "1.0.5",
+      "resolved": "https://registry.npmjs.org/seek-bzip/-/seek-bzip-1.0.5.tgz",
+      "integrity": "sha1-z+kXyz0nS8/6x5J1ivUxc+sfq9w=",
+      "requires": {
+        "commander": "~2.8.1"
+      },
+      "dependencies": {
+        "commander": {
+          "version": "2.8.1",
+          "resolved": "https://registry.npmjs.org/commander/-/commander-2.8.1.tgz",
+          "integrity": "sha1-Br42f+v9oMMwqh4qBy09yXYkJdQ=",
+          "requires": {
+            "graceful-readlink": ">= 1.0.0"
+          }
+        }
+      }
+    },
+    "semver": {
+      "version": "5.7.0",
+      "resolved": "https://registry.npmjs.org/semver/-/semver-5.7.0.tgz",
+      "integrity": "sha512-Ya52jSX2u7QKghxeoFGpLwCtGlt7j0oY9DYb5apt9nPlJ42ID+ulTXESnt/qAQcoSERyZ5sl3LDIOw0nAn/5DA=="
+    },
+    "send": {
+      "version": "0.16.2",
+      "resolved": "https://registry.npmjs.org/send/-/send-0.16.2.tgz",
+      "integrity": "sha512-E64YFPUssFHEFBvpbbjr44NCLtI1AohxQ8ZSiJjQLskAdKuriYEP6VyGEsRDH8ScozGpkaX1BGvhanqCwkcEZw==",
+      "requires": {
+        "debug": "2.6.9",
+        "depd": "~1.1.2",
+        "destroy": "~1.0.4",
+        "encodeurl": "~1.0.2",
+        "escape-html": "~1.0.3",
+        "etag": "~1.8.1",
+        "fresh": "0.5.2",
+        "http-errors": "~1.6.2",
+        "mime": "1.4.1",
+        "ms": "2.0.0",
+        "on-finished": "~2.3.0",
+        "range-parser": "~1.2.0",
+        "statuses": "~1.4.0"
+      },
+      "dependencies": {
+        "http-errors": {
+          "version": "1.6.3",
+          "resolved": "https://registry.npmjs.org/http-errors/-/http-errors-1.6.3.tgz",
+          "integrity": "sha1-i1VoC7S+KDoLW/TqLjhYC+HZMg0=",
+          "requires": {
+            "depd": "~1.1.2",
+            "inherits": "2.0.3",
+            "setprototypeof": "1.1.0",
+            "statuses": ">= 1.4.0 < 2"
+          }
+        },
+        "setprototypeof": {
+          "version": "1.1.0",
+          "resolved": "https://registry.npmjs.org/setprototypeof/-/setprototypeof-1.1.0.tgz",
+          "integrity": "sha512-BvE/TwpZX4FXExxOxZyRGQQv651MSwmWKZGqvmPcRIjDqWub67kTKuIMx43cZZrS/cBBzwBcNDWoFxt2XEFIpQ=="
+        },
+        "statuses": {
+          "version": "1.4.0",
+          "resolved": "https://registry.npmjs.org/statuses/-/statuses-1.4.0.tgz",
+          "integrity": "sha512-zhSCtt8v2NDrRlPQpCNtw/heZLtfUDqxBM1udqikb/Hbk52LK4nQSwr10u77iopCW5LsyHpuXS0GnEc48mLeew=="
+        }
+      }
+    },
+    "serve-static": {
+      "version": "1.13.2",
+      "resolved": "https://registry.npmjs.org/serve-static/-/serve-static-1.13.2.tgz",
+      "integrity": "sha512-p/tdJrO4U387R9oMjb1oj7qSMaMfmOyd4j9hOFoxZe2baQszgHcSWjuya/CiT5kgZZKRudHNOA0pYXOl8rQ5nw==",
+      "requires": {
+        "encodeurl": "~1.0.2",
+        "escape-html": "~1.0.3",
+        "parseurl": "~1.3.2",
+        "send": "0.16.2"
+      }
+    },
+    "set-blocking": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/set-blocking/-/set-blocking-2.0.0.tgz",
+      "integrity": "sha1-BF+XgtARrppoA93TgrJDkrPYkPc="
+    },
+    "set-immediate-shim": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/set-immediate-shim/-/set-immediate-shim-1.0.1.tgz",
+      "integrity": "sha1-SysbJ+uAip+NzEgaWOXlb1mfP2E="
+    },
+    "set-value": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/set-value/-/set-value-2.0.0.tgz",
+      "integrity": "sha512-hw0yxk9GT/Hr5yJEYnHNKYXkIA8mVJgd9ditYZCe16ZczcaELYYcfvaXesNACk2O8O0nTiPQcQhGUQj8JLzeeg==",
+      "requires": {
+        "extend-shallow": "^2.0.1",
+        "is-extendable": "^0.1.1",
+        "is-plain-object": "^2.0.3",
+        "split-string": "^3.0.1"
+      },
+      "dependencies": {
+        "extend-shallow": {
+          "version": "2.0.1",
+          "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+          "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+          "requires": {
+            "is-extendable": "^0.1.0"
+          }
+        }
+      }
+    },
+    "setprototypeof": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/setprototypeof/-/setprototypeof-1.1.1.tgz",
+      "integrity": "sha512-JvdAWfbXeIGaZ9cILp38HntZSFSo3mWg6xGcJJsd+d4aRMOqauag1C63dJfDw7OaMYwEbHMOxEZ1lqVRYP2OAw=="
+    },
+    "shebang-command": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/shebang-command/-/shebang-command-1.2.0.tgz",
+      "integrity": "sha1-RKrGW2lbAzmJaMOfNj/uXer98eo=",
+      "dev": true,
+      "requires": {
+        "shebang-regex": "^1.0.0"
+      }
+    },
+    "shebang-regex": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/shebang-regex/-/shebang-regex-1.0.0.tgz",
+      "integrity": "sha1-2kL0l0DAtC2yypcoVxyxkMmO/qM=",
+      "dev": true
+    },
+    "sift": {
+      "version": "7.0.1",
+      "resolved": "https://registry.npmjs.org/sift/-/sift-7.0.1.tgz",
+      "integrity": "sha512-oqD7PMJ+uO6jV9EQCl0LrRw1OwsiPsiFQR5AR30heR+4Dl7jBBbDLnNvWiak20tzZlSE1H7RB30SX/1j/YYT7g=="
+    },
+    "sigmund": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/sigmund/-/sigmund-1.0.1.tgz",
+      "integrity": "sha1-P/IfGYytIXX587eBhT/ZTQ0ZtZA="
+    },
+    "signal-exit": {
+      "version": "3.0.2",
+      "resolved": "https://registry.npmjs.org/signal-exit/-/signal-exit-3.0.2.tgz",
+      "integrity": "sha1-tf3AjxKH6hF4Yo5BXiUTK3NkbG0=",
+      "dev": true
+    },
+    "simple-glob": {
+      "version": "0.1.1",
+      "resolved": "https://registry.npmjs.org/simple-glob/-/simple-glob-0.1.1.tgz",
+      "integrity": "sha1-KCv6AS1yBmQ99h00xrueTOP9dxQ=",
+      "requires": {
+        "glob": "~3.2.8",
+        "lodash": "~2.4.1",
+        "minimatch": "~0.2.14"
+      },
+      "dependencies": {
+        "glob": {
+          "version": "3.2.11",
+          "resolved": "https://registry.npmjs.org/glob/-/glob-3.2.11.tgz",
+          "integrity": "sha1-Spc/Y1uRkPcV0QmH1cAP0oFevj0=",
+          "requires": {
+            "inherits": "2",
+            "minimatch": "0.3"
+          },
+          "dependencies": {
+            "minimatch": {
+              "version": "0.3.0",
+              "resolved": "https://registry.npmjs.org/minimatch/-/minimatch-0.3.0.tgz",
+              "integrity": "sha1-J12O2qxPG7MyZHIInnlJyDlGmd0=",
+              "requires": {
+                "lru-cache": "2",
+                "sigmund": "~1.0.0"
+              }
+            }
+          }
+        },
+        "lodash": {
+          "version": "2.4.2",
+          "resolved": "https://registry.npmjs.org/lodash/-/lodash-2.4.2.tgz",
+          "integrity": "sha1-+t2DS5aDBz2hebPq5tnA0VBT9z4="
+        }
+      }
+    },
+    "slash": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/slash/-/slash-1.0.0.tgz",
+      "integrity": "sha1-xB8vbDn8FtHNF61LXYlhFK5HDVU="
+    },
+    "slice-ansi": {
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/slice-ansi/-/slice-ansi-2.1.0.tgz",
+      "integrity": "sha512-Qu+VC3EwYLldKa1fCxuuvULvSJOKEgk9pi8dZeCVK7TqBfUNTH4sFkk4joj8afVSfAYgJoSOetjx9QWOJ5mYoQ==",
+      "dev": true,
+      "requires": {
+        "ansi-styles": "^3.2.0",
+        "astral-regex": "^1.0.0",
+        "is-fullwidth-code-point": "^2.0.0"
+      },
+      "dependencies": {
+        "ansi-styles": {
+          "version": "3.2.1",
+          "resolved": "https://registry.npmjs.org/ansi-styles/-/ansi-styles-3.2.1.tgz",
+          "integrity": "sha512-VT0ZI6kZRdTh8YyJw3SMbYm/u+NqfsAxEpWO0Pf9sq8/e94WxxOpPKx9FR1FlyCtOVDNOQ+8ntlqFxiRc+r5qA==",
+          "dev": true,
+          "requires": {
+            "color-convert": "^1.9.0"
+          }
+        },
+        "is-fullwidth-code-point": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-2.0.0.tgz",
+          "integrity": "sha1-o7MKXE8ZkYMWeqq5O+764937ZU8=",
+          "dev": true
+        }
+      }
+    },
+    "sliced": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/sliced/-/sliced-1.0.1.tgz",
+      "integrity": "sha1-CzpmK10Ewxd7GSa+qCsD+Dei70E="
+    },
+    "snapdragon": {
+      "version": "0.8.2",
+      "resolved": "https://registry.npmjs.org/snapdragon/-/snapdragon-0.8.2.tgz",
+      "integrity": "sha512-FtyOnWN/wCHTVXOMwvSv26d+ko5vWlIDD6zoUJ7LW8vh+ZBC8QdljveRP+crNrtBwioEUWy/4dMtbBjA4ioNlg==",
+      "requires": {
+        "base": "^0.11.1",
+        "debug": "^2.2.0",
+        "define-property": "^0.2.5",
+        "extend-shallow": "^2.0.1",
+        "map-cache": "^0.2.2",
+        "source-map": "^0.5.6",
+        "source-map-resolve": "^0.5.0",
+        "use": "^3.1.0"
+      },
+      "dependencies": {
+        "define-property": {
+          "version": "0.2.5",
+          "resolved": "https://registry.npmjs.org/define-property/-/define-property-0.2.5.tgz",
+          "integrity": "sha1-w1se+RjsPJkPmlvFe+BKrOxcgRY=",
+          "requires": {
+            "is-descriptor": "^0.1.0"
+          }
+        },
+        "extend-shallow": {
+          "version": "2.0.1",
+          "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+          "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+          "requires": {
+            "is-extendable": "^0.1.0"
+          }
+        }
+      }
+    },
+    "snapdragon-node": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/snapdragon-node/-/snapdragon-node-2.1.1.tgz",
+      "integrity": "sha512-O27l4xaMYt/RSQ5TR3vpWCAB5Kb/czIcqUFOM/C4fYcLnbZUc1PkjTAMjof2pBWaSTwOUd6qUHcFGVGj7aIwnw==",
+      "requires": {
+        "define-property": "^1.0.0",
+        "isobject": "^3.0.0",
+        "snapdragon-util": "^3.0.1"
+      },
+      "dependencies": {
+        "define-property": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/define-property/-/define-property-1.0.0.tgz",
+          "integrity": "sha1-dp66rz9KY6rTr56NMEybvnm/sOY=",
+          "requires": {
+            "is-descriptor": "^1.0.0"
+          }
+        },
+        "is-accessor-descriptor": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-accessor-descriptor/-/is-accessor-descriptor-1.0.0.tgz",
+          "integrity": "sha512-m5hnHTkcVsPfqx3AKlyttIPb7J+XykHvJP2B9bZDjlhLIoEq4XoK64Vg7boZlVWYK6LUY94dYPEE7Lh0ZkZKcQ==",
+          "requires": {
+            "kind-of": "^6.0.0"
+          }
+        },
+        "is-data-descriptor": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-data-descriptor/-/is-data-descriptor-1.0.0.tgz",
+          "integrity": "sha512-jbRXy1FmtAoCjQkVmIVYwuuqDFUbaOeDjmed1tOGPrsMhtJA4rD9tkgA0F1qJ3gRFRXcHYVkdeaP50Q5rE/jLQ==",
+          "requires": {
+            "kind-of": "^6.0.0"
+          }
+        },
+        "is-descriptor": {
+          "version": "1.0.2",
+          "resolved": "https://registry.npmjs.org/is-descriptor/-/is-descriptor-1.0.2.tgz",
+          "integrity": "sha512-2eis5WqQGV7peooDyLmNEPUrps9+SXX5c9pL3xEB+4e9HnGuDa7mB7kHxHw4CbqS9k1T2hOH3miL8n8WtiYVtg==",
+          "requires": {
+            "is-accessor-descriptor": "^1.0.0",
+            "is-data-descriptor": "^1.0.0",
+            "kind-of": "^6.0.2"
+          }
+        },
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        },
+        "kind-of": {
+          "version": "6.0.2",
+          "resolved": "https://registry.npmjs.org/kind-of/-/kind-of-6.0.2.tgz",
+          "integrity": "sha512-s5kLOcnH0XqDO+FvuaLX8DDjZ18CGFk7VygH40QoKPUQhW4e2rvM0rwUq0t8IQDOwYSeLK01U90OjzBTme2QqA=="
+        }
+      }
+    },
+    "snapdragon-util": {
+      "version": "3.0.1",
+      "resolved": "https://registry.npmjs.org/snapdragon-util/-/snapdragon-util-3.0.1.tgz",
+      "integrity": "sha512-mbKkMdQKsjX4BAL4bRYTj21edOf8cN7XHdYUJEe+Zn99hVEYcMvKPct1IqNe7+AZPirn8BCDOQBHQZknqmKlZQ==",
+      "requires": {
+        "kind-of": "^3.2.0"
+      }
+    },
+    "socket.io": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/socket.io/-/socket.io-2.1.1.tgz",
+      "integrity": "sha512-rORqq9c+7W0DAK3cleWNSyfv/qKXV99hV4tZe+gGLfBECw3XEhBy7x85F3wypA9688LKjtwO9pX9L33/xQI8yA==",
+      "requires": {
+        "debug": "~3.1.0",
+        "engine.io": "~3.2.0",
+        "has-binary2": "~1.0.2",
+        "socket.io-adapter": "~1.1.0",
+        "socket.io-client": "2.1.1",
+        "socket.io-parser": "~3.2.0"
+      },
+      "dependencies": {
+        "debug": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.1.0.tgz",
+          "integrity": "sha512-OX8XqP7/1a9cqkxYw2yXss15f26NKWBpDXQd0/uK/KPqdQhxbPa994hnzjcE2VqQpDslf55723cKPUOGSmMY3g==",
+          "requires": {
+            "ms": "2.0.0"
+          }
+        }
+      }
+    },
+    "socket.io-adapter": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/socket.io-adapter/-/socket.io-adapter-1.1.1.tgz",
+      "integrity": "sha1-KoBeihTWNyEk3ZFZrUUC+MsH8Gs="
+    },
+    "socket.io-client": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/socket.io-client/-/socket.io-client-2.1.1.tgz",
+      "integrity": "sha512-jxnFyhAuFxYfjqIgduQlhzqTcOEQSn+OHKVfAxWaNWa7ecP7xSNk2Dx/3UEsDcY7NcFafxvNvKPmmO7HTwTxGQ==",
+      "requires": {
+        "backo2": "1.0.2",
+        "base64-arraybuffer": "0.1.5",
+        "component-bind": "1.0.0",
+        "component-emitter": "1.2.1",
+        "debug": "~3.1.0",
+        "engine.io-client": "~3.2.0",
+        "has-binary2": "~1.0.2",
+        "has-cors": "1.1.0",
+        "indexof": "0.0.1",
+        "object-component": "0.0.3",
+        "parseqs": "0.0.5",
+        "parseuri": "0.0.5",
+        "socket.io-parser": "~3.2.0",
+        "to-array": "0.1.4"
+      },
+      "dependencies": {
+        "component-emitter": {
+          "version": "1.2.1",
+          "resolved": "https://registry.npmjs.org/component-emitter/-/component-emitter-1.2.1.tgz",
+          "integrity": "sha1-E3kY1teCg/ffemt8WmPhQOaUJeY="
+        },
+        "debug": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.1.0.tgz",
+          "integrity": "sha512-OX8XqP7/1a9cqkxYw2yXss15f26NKWBpDXQd0/uK/KPqdQhxbPa994hnzjcE2VqQpDslf55723cKPUOGSmMY3g==",
+          "requires": {
+            "ms": "2.0.0"
+          }
+        }
+      }
+    },
+    "socket.io-parser": {
+      "version": "3.2.0",
+      "resolved": "https://registry.npmjs.org/socket.io-parser/-/socket.io-parser-3.2.0.tgz",
+      "integrity": "sha512-FYiBx7rc/KORMJlgsXysflWx/RIvtqZbyGLlHZvjfmPTPeuD/I8MaW7cfFrj5tRltICJdgwflhfZ3NVVbVLFQA==",
+      "requires": {
+        "component-emitter": "1.2.1",
+        "debug": "~3.1.0",
+        "isarray": "2.0.1"
+      },
+      "dependencies": {
+        "component-emitter": {
+          "version": "1.2.1",
+          "resolved": "https://registry.npmjs.org/component-emitter/-/component-emitter-1.2.1.tgz",
+          "integrity": "sha1-E3kY1teCg/ffemt8WmPhQOaUJeY="
+        },
+        "debug": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.1.0.tgz",
+          "integrity": "sha512-OX8XqP7/1a9cqkxYw2yXss15f26NKWBpDXQd0/uK/KPqdQhxbPa994hnzjcE2VqQpDslf55723cKPUOGSmMY3g==",
+          "requires": {
+            "ms": "2.0.0"
+          }
+        },
+        "isarray": {
+          "version": "2.0.1",
+          "resolved": "https://registry.npmjs.org/isarray/-/isarray-2.0.1.tgz",
+          "integrity": "sha1-o32U7ZzaLVmGXJ92/llu4fM4dB4="
+        }
+      }
+    },
+    "source-map": {
+      "version": "0.5.7",
+      "resolved": "https://registry.npmjs.org/source-map/-/source-map-0.5.7.tgz",
+      "integrity": "sha1-igOdLRAh0i0eoUyA2OpGi6LvP8w="
+    },
+    "source-map-resolve": {
+      "version": "0.5.2",
+      "resolved": "https://registry.npmjs.org/source-map-resolve/-/source-map-resolve-0.5.2.tgz",
+      "integrity": "sha512-MjqsvNwyz1s0k81Goz/9vRBe9SZdB09Bdw+/zYyO+3CuPk6fouTaxscHkgtE8jKvf01kVfl8riHzERQ/kefaSA==",
+      "requires": {
+        "atob": "^2.1.1",
+        "decode-uri-component": "^0.2.0",
+        "resolve-url": "^0.2.1",
+        "source-map-url": "^0.4.0",
+        "urix": "^0.1.0"
+      }
+    },
+    "source-map-support": {
+      "version": "0.4.18",
+      "resolved": "https://registry.npmjs.org/source-map-support/-/source-map-support-0.4.18.tgz",
+      "integrity": "sha512-try0/JqxPLF9nOjvSta7tVondkP5dwgyLDjVoyMDlmjugT2lRZ1OfsrYTkCd2hkDnJTKRbO/Rl3orm8vlsUzbA==",
+      "requires": {
+        "source-map": "^0.5.6"
+      }
+    },
+    "source-map-url": {
+      "version": "0.4.0",
+      "resolved": "https://registry.npmjs.org/source-map-url/-/source-map-url-0.4.0.tgz",
+      "integrity": "sha1-PpNdfd1zYxuXZZlW1VEo6HtQhKM="
+    },
+    "sparse-bitfield": {
+      "version": "3.0.3",
+      "resolved": "https://registry.npmjs.org/sparse-bitfield/-/sparse-bitfield-3.0.3.tgz",
+      "integrity": "sha1-/0rm5oZWBWuks+eSqzM004JzyhE=",
+      "optional": true,
+      "requires": {
+        "memory-pager": "^1.0.2"
+      }
+    },
+    "spawn-sync": {
+      "version": "1.0.15",
+      "resolved": "https://registry.npmjs.org/spawn-sync/-/spawn-sync-1.0.15.tgz",
+      "integrity": "sha1-sAeZVX63+wyDdsKdROih6mfldHY=",
+      "requires": {
+        "concat-stream": "^1.4.7",
+        "os-shim": "^0.1.2"
+      }
+    },
+    "spdx-correct": {
+      "version": "3.1.0",
+      "resolved": "https://registry.npmjs.org/spdx-correct/-/spdx-correct-3.1.0.tgz",
+      "integrity": "sha512-lr2EZCctC2BNR7j7WzJ2FpDznxky1sjfxvvYEyzxNyb6lZXHODmEoJeFu4JupYlkfha1KZpJyoqiJ7pgA1qq8Q==",
+      "requires": {
+        "spdx-expression-parse": "^3.0.0",
+        "spdx-license-ids": "^3.0.0"
+      }
+    },
+    "spdx-exceptions": {
+      "version": "2.2.0",
+      "resolved": "https://registry.npmjs.org/spdx-exceptions/-/spdx-exceptions-2.2.0.tgz",
+      "integrity": "sha512-2XQACfElKi9SlVb1CYadKDXvoajPgBVPn/gOQLrTvHdElaVhr7ZEbqJaRnJLVNeaI4cMEAgVCeBMKF6MWRDCRA=="
+    },
+    "spdx-expression-parse": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/spdx-expression-parse/-/spdx-expression-parse-3.0.0.tgz",
+      "integrity": "sha512-Yg6D3XpRD4kkOmTpdgbUiEJFKghJH03fiC1OPll5h/0sO6neh2jqRDVHOQ4o/LMea0tgCkbMgea5ip/e+MkWyg==",
+      "requires": {
+        "spdx-exceptions": "^2.1.0",
+        "spdx-license-ids": "^3.0.0"
+      }
+    },
+    "spdx-license-ids": {
+      "version": "3.0.4",
+      "resolved": "https://registry.npmjs.org/spdx-license-ids/-/spdx-license-ids-3.0.4.tgz",
+      "integrity": "sha512-7j8LYJLeY/Yb6ACbQ7F76qy5jHkp0U6jgBfJsk97bwWlVUnUWsAgpyaCvo17h0/RQGnQ036tVDomiwoI4pDkQA=="
+    },
+    "split-string": {
+      "version": "3.1.0",
+      "resolved": "https://registry.npmjs.org/split-string/-/split-string-3.1.0.tgz",
+      "integrity": "sha512-NzNVhJDYpwceVVii8/Hu6DKfD2G+NrQHlS/V/qgv763EYudVwEcMQNxd2lh+0VrUByXN/oJkl5grOhYWvQUYiw==",
+      "requires": {
+        "extend-shallow": "^3.0.0"
+      }
+    },
+    "sprintf-js": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/sprintf-js/-/sprintf-js-1.0.3.tgz",
+      "integrity": "sha1-BOaSb2YolTVPPdAVIDYzuFcpfiw=",
+      "dev": true
+    },
+    "sshpk": {
+      "version": "1.16.1",
+      "resolved": "https://registry.npmjs.org/sshpk/-/sshpk-1.16.1.tgz",
+      "integrity": "sha512-HXXqVUq7+pcKeLqqZj6mHFUMvXtOJt1uoUx09pFW6011inTMxqI8BA8PM95myrIyyKwdnzjdFjLiE6KBPVtJIg==",
+      "requires": {
+        "asn1": "~0.2.3",
+        "assert-plus": "^1.0.0",
+        "bcrypt-pbkdf": "^1.0.0",
+        "dashdash": "^1.12.0",
+        "ecc-jsbn": "~0.1.1",
+        "getpass": "^0.1.1",
+        "jsbn": "~0.1.0",
+        "safer-buffer": "^2.0.2",
+        "tweetnacl": "~0.14.0"
+      }
+    },
+    "standard-error": {
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/standard-error/-/standard-error-1.1.0.tgz",
+      "integrity": "sha1-I+UWj6HAggGJ5YEnAaeQWFENDTQ="
+    },
+    "static-extend": {
+      "version": "0.1.2",
+      "resolved": "https://registry.npmjs.org/static-extend/-/static-extend-0.1.2.tgz",
+      "integrity": "sha1-YICcOcv/VTNyJv1eC1IPNB8ftcY=",
+      "requires": {
+        "define-property": "^0.2.5",
+        "object-copy": "^0.1.0"
+      },
+      "dependencies": {
+        "define-property": {
+          "version": "0.2.5",
+          "resolved": "https://registry.npmjs.org/define-property/-/define-property-0.2.5.tgz",
+          "integrity": "sha1-w1se+RjsPJkPmlvFe+BKrOxcgRY=",
+          "requires": {
+            "is-descriptor": "^0.1.0"
+          }
+        }
+      }
+    },
+    "statuses": {
+      "version": "1.5.0",
+      "resolved": "https://registry.npmjs.org/statuses/-/statuses-1.5.0.tgz",
+      "integrity": "sha1-Fhx9rBd2Wf2YEfQ3cfqZOBR4Yow="
+    },
+    "stealthy-require": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/stealthy-require/-/stealthy-require-1.1.1.tgz",
+      "integrity": "sha1-NbCYdbT/SfJqd35QmzCQoyJr8ks="
+    },
+    "stream-meter": {
+      "version": "1.0.4",
+      "resolved": "https://registry.npmjs.org/stream-meter/-/stream-meter-1.0.4.tgz",
+      "integrity": "sha1-Uq+Vql6nYKJJFxZwTb/5D3Ov3R0=",
+      "requires": {
+        "readable-stream": "^2.1.4"
+      }
+    },
+    "string-width": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/string-width/-/string-width-1.0.2.tgz",
+      "integrity": "sha1-EYvfW4zcUaKn5w0hHgfisLmxB9M=",
+      "requires": {
+        "code-point-at": "^1.0.0",
+        "is-fullwidth-code-point": "^1.0.0",
+        "strip-ansi": "^3.0.0"
+      }
+    },
+    "string_decoder": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/string_decoder/-/string_decoder-1.1.1.tgz",
+      "integrity": "sha512-n/ShnvDi6FHbbVfviro+WojiFzv+s8MPMHBczVePfUpDJLwoLT0ht1l4YwBCbi8pJAveEEdnkHyPyTP/mzRfwg==",
+      "requires": {
+        "safe-buffer": "~5.1.0"
+      }
+    },
+    "strip-ansi": {
+      "version": "3.0.1",
+      "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-3.0.1.tgz",
+      "integrity": "sha1-ajhfuIU9lS1f8F0Oiq+UJ43GPc8=",
+      "requires": {
+        "ansi-regex": "^2.0.0"
+      }
+    },
+    "strip-bom": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/strip-bom/-/strip-bom-2.0.0.tgz",
+      "integrity": "sha1-YhmoVhZSBJHzV4i9vxRHqZx+aw4=",
+      "requires": {
+        "is-utf8": "^0.2.0"
+      }
+    },
+    "strip-dirs": {
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/strip-dirs/-/strip-dirs-2.1.0.tgz",
+      "integrity": "sha512-JOCxOeKLm2CAS73y/U4ZeZPTkE+gNVCzKt7Eox84Iej1LT/2pTWYpZKJuxwQpvX1LiZb1xokNR7RLfuBAa7T3g==",
+      "requires": {
+        "is-natural-number": "^4.0.1"
+      }
+    },
+    "strip-eof": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/strip-eof/-/strip-eof-1.0.0.tgz",
+      "integrity": "sha1-u0P/VZim6wXYm1n80SnJgzE2Br8=",
+      "dev": true
+    },
+    "strip-json-comments": {
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/strip-json-comments/-/strip-json-comments-2.0.1.tgz",
+      "integrity": "sha1-PFMZQukIwml8DsNEhYwobHygpgo=",
+      "dev": true
+    },
+    "superagent": {
+      "version": "3.8.3",
+      "resolved": "https://registry.npmjs.org/superagent/-/superagent-3.8.3.tgz",
+      "integrity": "sha512-GLQtLMCoEIK4eDv6OGtkOoSMt3D+oq0y3dsxMuYuDvaNUvuT8eFBuLmfR0iYYzHC1e8hpzC6ZsxbuP6DIalMFA==",
+      "dev": true,
+      "requires": {
+        "component-emitter": "^1.2.0",
+        "cookiejar": "^2.1.0",
+        "debug": "^3.1.0",
+        "extend": "^3.0.0",
+        "form-data": "^2.3.1",
+        "formidable": "^1.2.0",
+        "methods": "^1.1.1",
+        "mime": "^1.4.1",
+        "qs": "^6.5.1",
+        "readable-stream": "^2.3.5"
+      },
+      "dependencies": {
+        "debug": {
+          "version": "3.2.6",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-3.2.6.tgz",
+          "integrity": "sha512-mel+jf7nrtEl5Pn1Qx46zARXKDpBbvzezse7p7LqINmdoIk8PYP5SySaxEmYv6TZ0JyEKA1hsCId6DIhgITtWQ==",
+          "dev": true,
+          "requires": {
+            "ms": "^2.1.1"
+          }
+        },
+        "ms": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/ms/-/ms-2.1.1.tgz",
+          "integrity": "sha512-tgp+dl5cGk28utYktBsrFqA7HKgrhgPsg6Z/EfhWI4gl1Hwq8B/GmY/0oXZ6nF8hDVesS/FpnYaD/kOWhYQvyg==",
+          "dev": true
+        }
+      }
+    },
+    "supertest": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/supertest/-/supertest-3.0.0.tgz",
+      "integrity": "sha1-jUu2j9GDDuBwM7HFpamkAhyWUpY=",
+      "dev": true,
+      "requires": {
+        "methods": "~1.1.2",
+        "superagent": "^3.0.0"
+      }
+    },
+    "supports-color": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-2.0.0.tgz",
+      "integrity": "sha1-U10EXOa2Nj+kARcIRimZXp3zJMc="
+    },
+    "table": {
+      "version": "5.2.3",
+      "resolved": "https://registry.npmjs.org/table/-/table-5.2.3.tgz",
+      "integrity": "sha512-N2RsDAMvDLvYwFcwbPyF3VmVSSkuF+G1e+8inhBLtHpvwXGw4QRPEZhihQNeEN0i1up6/f6ObCJXNdlRG3YVyQ==",
+      "dev": true,
+      "requires": {
+        "ajv": "^6.9.1",
+        "lodash": "^4.17.11",
+        "slice-ansi": "^2.1.0",
+        "string-width": "^3.0.0"
+      },
+      "dependencies": {
+        "ansi-regex": {
+          "version": "4.1.0",
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-4.1.0.tgz",
+          "integrity": "sha512-1apePfXM1UOSqw0o9IiFAovVz9M5S1Dg+4TrDwfMewQ6p/rmMueb7tWZjQ1rx4Loy1ArBggoqGpfqqdI4rondg==",
+          "dev": true
+        },
+        "is-fullwidth-code-point": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-2.0.0.tgz",
+          "integrity": "sha1-o7MKXE8ZkYMWeqq5O+764937ZU8=",
+          "dev": true
+        },
+        "string-width": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/string-width/-/string-width-3.1.0.tgz",
+          "integrity": "sha512-vafcv6KjVZKSgz06oM/H6GDBrAtz8vdhQakGjFIvNrHA6y3HCF1CInLy+QLq8dTJPQ1b+KDUqDFctkdRW44e1w==",
+          "dev": true,
+          "requires": {
+            "emoji-regex": "^7.0.1",
+            "is-fullwidth-code-point": "^2.0.0",
+            "strip-ansi": "^5.1.0"
+          }
+        },
+        "strip-ansi": {
+          "version": "5.2.0",
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-5.2.0.tgz",
+          "integrity": "sha512-DuRs1gKbBqsMKIZlrffwlug8MHkcnpjs5VPmL1PAh+mA30U0DTotfDZ0d2UUsXpPmPmMMJ6W773MaA3J+lbiWA==",
+          "dev": true,
+          "requires": {
+            "ansi-regex": "^4.1.0"
+          }
+        }
+      }
+    },
+    "tar-stream": {
+      "version": "1.6.2",
+      "resolved": "https://registry.npmjs.org/tar-stream/-/tar-stream-1.6.2.tgz",
+      "integrity": "sha512-rzS0heiNf8Xn7/mpdSVVSMAWAoy9bfb1WOTYC78Z0UQKeKa/CWS8FOq0lKGNa8DWKAn9gxjCvMLYc5PGXYlK2A==",
+      "requires": {
+        "bl": "^1.0.0",
+        "buffer-alloc": "^1.2.0",
+        "end-of-stream": "^1.0.0",
+        "fs-constants": "^1.0.0",
+        "readable-stream": "^2.3.0",
+        "to-buffer": "^1.1.1",
+        "xtend": "^4.0.0"
+      }
+    },
+    "text-table": {
+      "version": "0.2.0",
+      "resolved": "https://registry.npmjs.org/text-table/-/text-table-0.2.0.tgz",
+      "integrity": "sha1-f17oI66AUgfACvLfSoTsP8+lcLQ=",
+      "dev": true
+    },
+    "throttleit": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/throttleit/-/throttleit-1.0.0.tgz",
+      "integrity": "sha1-nnhYNtr0Z0MUWlmEtiaNgoUorGw="
+    },
+    "through": {
+      "version": "2.3.8",
+      "resolved": "https://registry.npmjs.org/through/-/through-2.3.8.tgz",
+      "integrity": "sha1-DdTJ/6q8NXlgsbckEV1+Doai4fU="
+    },
+    "tmp": {
+      "version": "0.0.33",
+      "resolved": "https://registry.npmjs.org/tmp/-/tmp-0.0.33.tgz",
+      "integrity": "sha512-jRCJlojKnZ3addtTOjdIqoRuPEKBvNXcGYqzO6zWZX8KfKEpnGY5jfggJQ3EjKuu8D4bJRr0y+cYJFmYbImXGw==",
+      "dev": true,
+      "requires": {
+        "os-tmpdir": "~1.0.2"
+      }
+    },
+    "to-array": {
+      "version": "0.1.4",
+      "resolved": "https://registry.npmjs.org/to-array/-/to-array-0.1.4.tgz",
+      "integrity": "sha1-F+bBH3PdTz10zaek/zI46a2b+JA="
+    },
+    "to-buffer": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/to-buffer/-/to-buffer-1.1.1.tgz",
+      "integrity": "sha512-lx9B5iv7msuFYE3dytT+KE5tap+rNYw+K4jVkb9R/asAb+pbBSM17jtunHplhBe6RRJdZx3Pn2Jph24O32mOVg=="
+    },
+    "to-fast-properties": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/to-fast-properties/-/to-fast-properties-1.0.3.tgz",
+      "integrity": "sha1-uDVx+k2MJbguIxsG46MFXeTKGkc="
+    },
+    "to-object-path": {
+      "version": "0.3.0",
+      "resolved": "https://registry.npmjs.org/to-object-path/-/to-object-path-0.3.0.tgz",
+      "integrity": "sha1-KXWIt7Dn4KwI4E5nL4XB9JmeF68=",
+      "requires": {
+        "kind-of": "^3.0.2"
+      }
+    },
+    "to-regex": {
+      "version": "3.0.2",
+      "resolved": "https://registry.npmjs.org/to-regex/-/to-regex-3.0.2.tgz",
+      "integrity": "sha512-FWtleNAtZ/Ki2qtqej2CXTOayOH9bHDQF+Q48VpWyDXjbYxA4Yz8iDB31zXOBUlOHHKidDbqGVrTUvQMPmBGBw==",
+      "requires": {
+        "define-property": "^2.0.2",
+        "extend-shallow": "^3.0.2",
+        "regex-not": "^1.0.2",
+        "safe-regex": "^1.1.0"
+      }
+    },
+    "to-regex-range": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/to-regex-range/-/to-regex-range-2.1.1.tgz",
+      "integrity": "sha1-fIDBe53+vlmeJzZ+DU3VWQFB2zg=",
+      "requires": {
+        "is-number": "^3.0.0",
+        "repeat-string": "^1.6.1"
+      },
+      "dependencies": {
+        "is-number": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/is-number/-/is-number-3.0.0.tgz",
+          "integrity": "sha1-JP1iAaR4LPUFYcgQJ2r8fRLXEZU=",
+          "requires": {
+            "kind-of": "^3.0.2"
+          }
+        }
+      }
+    },
+    "toidentifier": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/toidentifier/-/toidentifier-1.0.0.tgz",
+      "integrity": "sha512-yaOH/Pk/VEhBWWTlhI+qXxDFXlejDGcQipMlyxda9nthulaxLZUNcUqFxokp0vcYnvteJln5FNQDRrxj3YcbVw=="
+    },
+    "tough-cookie": {
+      "version": "2.4.3",
+      "resolved": "https://registry.npmjs.org/tough-cookie/-/tough-cookie-2.4.3.tgz",
+      "integrity": "sha512-Q5srk/4vDM54WJsJio3XNn6K2sCG+CQ8G5Wz6bZhRZoAe/+TxjWB/GlFAnYEbkYVlON9FMk/fE3h2RLpPXo4lQ==",
+      "requires": {
+        "psl": "^1.1.24",
+        "punycode": "^1.4.1"
+      },
+      "dependencies": {
+        "punycode": {
+          "version": "1.4.1",
+          "resolved": "https://registry.npmjs.org/punycode/-/punycode-1.4.1.tgz",
+          "integrity": "sha1-wNWmOycYgArY4esPpSachN1BhF4="
+        }
+      }
+    },
+    "trim-right": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/trim-right/-/trim-right-1.0.1.tgz",
+      "integrity": "sha1-yy4SAwZ+DI3h9hQJS5/kVwTqYAM="
+    },
+    "ts-node": {
+      "version": "6.2.0",
+      "resolved": "https://registry.npmjs.org/ts-node/-/ts-node-6.2.0.tgz",
+      "integrity": "sha512-ZNT+OEGfUNVMGkpIaDJJ44Zq3Yr0bkU/ugN1PHbU+/01Z7UV1fsELRiTx1KuQNvQ1A3pGh3y25iYF6jXgxV21A==",
+      "requires": {
+        "arrify": "^1.0.0",
+        "buffer-from": "^1.1.0",
+        "diff": "^3.1.0",
+        "make-error": "^1.1.1",
+        "minimist": "^1.2.0",
+        "mkdirp": "^0.5.1",
+        "source-map-support": "^0.5.6",
+        "yn": "^2.0.0"
+      },
+      "dependencies": {
+        "minimist": {
+          "version": "1.2.0",
+          "resolved": "https://registry.npmjs.org/minimist/-/minimist-1.2.0.tgz",
+          "integrity": "sha1-o1AIsg9BOD7sH7kU9M1d95omQoQ="
+        },
+        "source-map": {
+          "version": "0.6.1",
+          "resolved": "https://registry.npmjs.org/source-map/-/source-map-0.6.1.tgz",
+          "integrity": "sha512-UjgapumWlbMhkBgzT7Ykc5YXUT46F0iKu8SGXq0bcwP5dz/h0Plj6enJqjz1Zbq2l5WaqYnrVbwWOWMyF3F47g=="
+        },
+        "source-map-support": {
+          "version": "0.5.12",
+          "resolved": "https://registry.npmjs.org/source-map-support/-/source-map-support-0.5.12.tgz",
+          "integrity": "sha512-4h2Pbvyy15EE02G+JOZpUCmqWJuqrs+sEkzewTm++BPi7Hvn/HwcqLAcNxYAyI0x13CpPPn+kMjl+hplXMHITQ==",
+          "requires": {
+            "buffer-from": "^1.0.0",
+            "source-map": "^0.6.0"
+          }
+        }
+      }
+    },
+    "tslib": {
+      "version": "1.9.3",
+      "resolved": "https://registry.npmjs.org/tslib/-/tslib-1.9.3.tgz",
+      "integrity": "sha512-4krF8scpejhaOgqzBEcGM7yDIEfi0/8+8zDRZhNZZ2kjmHJ4hv3zCbQWxoJGz1iw5U0Jl0nma13xzHXcncMavQ==",
+      "dev": true
+    },
+    "tunnel-agent": {
+      "version": "0.6.0",
+      "resolved": "https://registry.npmjs.org/tunnel-agent/-/tunnel-agent-0.6.0.tgz",
+      "integrity": "sha1-J6XeoGs2sEoKmWZ3SykIaPD8QP0=",
+      "requires": {
+        "safe-buffer": "^5.0.1"
+      }
+    },
+    "tweetnacl": {
+      "version": "0.14.5",
+      "resolved": "https://registry.npmjs.org/tweetnacl/-/tweetnacl-0.14.5.tgz",
+      "integrity": "sha1-WuaBd/GS1EViadEIr6k/+HQ/T2Q="
+    },
+    "type-check": {
+      "version": "0.3.2",
+      "resolved": "https://registry.npmjs.org/type-check/-/type-check-0.3.2.tgz",
+      "integrity": "sha1-WITKtRLPHTVeP7eE8wgEsrUg23I=",
+      "requires": {
+        "prelude-ls": "~1.1.2"
+      }
+    },
+    "type-detect": {
+      "version": "4.0.8",
+      "resolved": "https://registry.npmjs.org/type-detect/-/type-detect-4.0.8.tgz",
+      "integrity": "sha512-0fr/mIH1dlO+x7TlcMy+bIDqKPsw/70tVyeHW787goQjhmqaZe10uwLujubK9q9Lg6Fiho1KUKDYz0Z7k7g5/g==",
+      "dev": true
+    },
+    "type-is": {
+      "version": "1.6.17",
+      "resolved": "https://registry.npmjs.org/type-is/-/type-is-1.6.17.tgz",
+      "integrity": "sha512-jYZzkOoAPVyQ9vlZ4xEJ4BBbHC4a7hbY1xqyCPe6AiQVVqfbZEulJm0VpqK4B+096O1VQi0l6OBGH210ejx/bA==",
+      "requires": {
+        "media-typer": "0.3.0",
+        "mime-types": "~2.1.24"
+      }
+    },
+    "typedarray": {
+      "version": "0.0.6",
+      "resolved": "https://registry.npmjs.org/typedarray/-/typedarray-0.0.6.tgz",
+      "integrity": "sha1-hnrHTjhkGHsdPUfZlqeOxciDB3c="
+    },
+    "uid-safe": {
+      "version": "2.1.5",
+      "resolved": "https://registry.npmjs.org/uid-safe/-/uid-safe-2.1.5.tgz",
+      "integrity": "sha512-KPHm4VL5dDXKz01UuEd88Df+KzynaohSL9fBh096KWAxSKZQDI2uBrVqtvRM4rwrIrRRKsdLNML/lnaaVSRioA==",
+      "requires": {
+        "random-bytes": "~1.0.0"
+      }
+    },
+    "uid2": {
+      "version": "0.0.3",
+      "resolved": "https://registry.npmjs.org/uid2/-/uid2-0.0.3.tgz",
+      "integrity": "sha1-SDEm4Rd03y9xuLY53NeZw3YWK4I="
+    },
+    "ultron": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/ultron/-/ultron-1.1.1.tgz",
+      "integrity": "sha512-UIEXBNeYmKptWH6z8ZnqTeS8fV74zG0/eRU9VGkpzz+LIJNs8W/zM/L+7ctCkRrgbNnnR0xxw4bKOr0cW0N0Og=="
+    },
+    "unbzip2-stream": {
+      "version": "1.3.3",
+      "resolved": "https://registry.npmjs.org/unbzip2-stream/-/unbzip2-stream-1.3.3.tgz",
+      "integrity": "sha512-fUlAF7U9Ah1Q6EieQ4x4zLNejrRvDWUYmxXUpN3uziFYCHapjWFaCAnreY9bGgxzaMCFAPPpYNng57CypwJVhg==",
+      "requires": {
+        "buffer": "^5.2.1",
+        "through": "^2.3.8"
+      }
+    },
+    "union-value": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/union-value/-/union-value-1.0.0.tgz",
+      "integrity": "sha1-XHHDTLW61dzr4+oM0IIHulqhrqQ=",
+      "requires": {
+        "arr-union": "^3.1.0",
+        "get-value": "^2.0.6",
+        "is-extendable": "^0.1.1",
+        "set-value": "^0.4.3"
+      },
+      "dependencies": {
+        "extend-shallow": {
+          "version": "2.0.1",
+          "resolved": "https://registry.npmjs.org/extend-shallow/-/extend-shallow-2.0.1.tgz",
+          "integrity": "sha1-Ua99YUrZqfYQ6huvu5idaxxWiQ8=",
+          "requires": {
+            "is-extendable": "^0.1.0"
+          }
+        },
+        "set-value": {
+          "version": "0.4.3",
+          "resolved": "https://registry.npmjs.org/set-value/-/set-value-0.4.3.tgz",
+          "integrity": "sha1-fbCPnT0i3H945Trzw79GZuzfzPE=",
+          "requires": {
+            "extend-shallow": "^2.0.1",
+            "is-extendable": "^0.1.1",
+            "is-plain-object": "^2.0.1",
+            "to-object-path": "^0.3.0"
+          }
+        }
+      }
+    },
+    "unique-temp-dir": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/unique-temp-dir/-/unique-temp-dir-1.0.0.tgz",
+      "integrity": "sha1-bc6VsmgcoAPuv7MEpBX5y6vMU4U=",
+      "requires": {
+        "mkdirp": "^0.5.1",
+        "os-tmpdir": "^1.0.1",
+        "uid2": "0.0.3"
+      }
+    },
+    "universalify": {
+      "version": "0.1.2",
+      "resolved": "https://registry.npmjs.org/universalify/-/universalify-0.1.2.tgz",
+      "integrity": "sha512-rBJeI5CXAlmy1pV+617WB9J63U6XcazHHF2f2dbJix4XzpUF0RS3Zbj0FGIOCAva5P/d/GBOYaACQ1w+0azUkg=="
+    },
+    "unpipe": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/unpipe/-/unpipe-1.0.0.tgz",
+      "integrity": "sha1-sr9O6FFKrmFltIF4KdIbLvSZBOw="
+    },
+    "unset-value": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/unset-value/-/unset-value-1.0.0.tgz",
+      "integrity": "sha1-g3aHP30jNRef+x5vw6jtDfyKtVk=",
+      "requires": {
+        "has-value": "^0.3.1",
+        "isobject": "^3.0.0"
+      },
+      "dependencies": {
+        "has-value": {
+          "version": "0.3.1",
+          "resolved": "https://registry.npmjs.org/has-value/-/has-value-0.3.1.tgz",
+          "integrity": "sha1-ex9YutpiyoJ+wKIHgCVlSEWZXh8=",
+          "requires": {
+            "get-value": "^2.0.3",
+            "has-values": "^0.1.4",
+            "isobject": "^2.0.0"
+          },
+          "dependencies": {
+            "isobject": {
+              "version": "2.1.0",
+              "resolved": "https://registry.npmjs.org/isobject/-/isobject-2.1.0.tgz",
+              "integrity": "sha1-8GVWEJaj8dou9GJy+BXIQNh+DIk=",
+              "requires": {
+                "isarray": "1.0.0"
+              }
+            }
+          }
+        },
+        "has-values": {
+          "version": "0.1.4",
+          "resolved": "https://registry.npmjs.org/has-values/-/has-values-0.1.4.tgz",
+          "integrity": "sha1-bWHeldkd/Km5oCCJrThL/49it3E="
+        },
+        "isobject": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/isobject/-/isobject-3.0.1.tgz",
+          "integrity": "sha1-TkMekrEalzFjaqH5yNHMvP2reN8="
+        }
+      }
+    },
+    "uri-js": {
+      "version": "4.2.2",
+      "resolved": "https://registry.npmjs.org/uri-js/-/uri-js-4.2.2.tgz",
+      "integrity": "sha512-KY9Frmirql91X2Qgjry0Wd4Y+YTdrdZheS8TFwvkbLWf/G5KNJDCh6pKL5OZctEW4+0Baa5idK2ZQuELRwPznQ==",
+      "requires": {
+        "punycode": "^2.1.0"
+      }
+    },
+    "urix": {
+      "version": "0.1.0",
+      "resolved": "https://registry.npmjs.org/urix/-/urix-0.1.0.tgz",
+      "integrity": "sha1-2pN/emLiH+wf0Y1Js1wpNQZ6bHI="
+    },
+    "use": {
+      "version": "3.1.1",
+      "resolved": "https://registry.npmjs.org/use/-/use-3.1.1.tgz",
+      "integrity": "sha512-cwESVXlO3url9YWlFW/TA9cshCEhtu7IKJ/p5soJ/gGpj7vbvFrAY/eIioQ6Dw23KjZhYgiIo8HOs1nQ2vr/oQ=="
+    },
+    "user-home": {
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/user-home/-/user-home-1.1.1.tgz",
+      "integrity": "sha1-K1viOjK2Onyd640PKNSFcko98ZA="
+    },
+    "util-deprecate": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/util-deprecate/-/util-deprecate-1.0.2.tgz",
+      "integrity": "sha1-RQ1Nyfpw3nMnYvvS1KKJgUGaDM8="
+    },
+    "utils-merge": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/utils-merge/-/utils-merge-1.0.1.tgz",
+      "integrity": "sha1-n5VxD1CiZ5R7LMwSR0HBAoQn5xM="
+    },
+    "uuid": {
+      "version": "3.3.2",
+      "resolved": "https://registry.npmjs.org/uuid/-/uuid-3.3.2.tgz",
+      "integrity": "sha512-yXJmeNaw3DnnKAOKJE51sL/ZaYfWJRl1pK9dr19YFCu0ObS231AB1/LbqTKRAQ5kw8A90rA6fr4riOUpTZvQZA=="
+    },
+    "v8flags": {
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/v8flags/-/v8flags-2.1.1.tgz",
+      "integrity": "sha1-qrGh+jDUX4jdMhFIh1rALAtV5bQ=",
+      "requires": {
+        "user-home": "^1.1.1"
+      }
+    },
+    "validate-npm-package-license": {
+      "version": "3.0.4",
+      "resolved": "https://registry.npmjs.org/validate-npm-package-license/-/validate-npm-package-license-3.0.4.tgz",
+      "integrity": "sha512-DpKm2Ui/xN7/HQKCtpZxoRWBhZ9Z0kqtygG8XCgNQ8ZlDnxuQmWhj566j8fN4Cu3/JmbhsDo7fcAJq4s9h27Ew==",
+      "requires": {
+        "spdx-correct": "^3.0.0",
+        "spdx-expression-parse": "^3.0.0"
+      }
+    },
+    "vary": {
+      "version": "1.1.2",
+      "resolved": "https://registry.npmjs.org/vary/-/vary-1.1.2.tgz",
+      "integrity": "sha1-IpnwLG3tMNSllhsLn3RSShj2NPw="
+    },
+    "verror": {
+      "version": "1.10.0",
+      "resolved": "https://registry.npmjs.org/verror/-/verror-1.10.0.tgz",
+      "integrity": "sha1-OhBcoXBTr1XW4nDB+CiGguGNpAA=",
+      "requires": {
+        "assert-plus": "^1.0.0",
+        "core-util-is": "1.0.2",
+        "extsprintf": "^1.2.0"
+      }
+    },
+    "which": {
+      "version": "1.3.1",
+      "resolved": "https://registry.npmjs.org/which/-/which-1.3.1.tgz",
+      "integrity": "sha512-HxJdYWq1MTIQbJ3nw0cqssHoTNU267KlrDuGZ1WYlxDStUtKUhOaJmh112/TZmHxxUfuJqPXSOm7tDyas0OSIQ==",
+      "dev": true,
+      "requires": {
+        "isexe": "^2.0.0"
+      }
+    },
+    "which-module": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/which-module/-/which-module-1.0.0.tgz",
+      "integrity": "sha1-u6Y8qGGUiZT/MHc2CJ47lgJsKk8="
+    },
+    "wide-align": {
+      "version": "1.1.3",
+      "resolved": "https://registry.npmjs.org/wide-align/-/wide-align-1.1.3.tgz",
+      "integrity": "sha512-QGkOQc8XL6Bt5PwnsExKBPuMKBxnGxWWW3fU55Xt4feHozMUhdUMaBCk290qpm/wG5u/RSKzwdAC4i51YigihA==",
+      "dev": true,
+      "requires": {
+        "string-width": "^1.0.2 || 2"
+      }
+    },
+    "window-size": {
+      "version": "0.2.0",
+      "resolved": "https://registry.npmjs.org/window-size/-/window-size-0.2.0.tgz",
+      "integrity": "sha1-tDFbtCFKPXBY6+7okuE/ok2YsHU="
+    },
+    "wordwrap": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/wordwrap/-/wordwrap-1.0.0.tgz",
+      "integrity": "sha1-J1hIEIkUVqQXHI0CJkQa3pDLyus="
+    },
+    "wrap-ansi": {
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/wrap-ansi/-/wrap-ansi-2.1.0.tgz",
+      "integrity": "sha1-2Pw9KE3QV5T+hJc8rs3Rz4JP3YU=",
+      "requires": {
+        "string-width": "^1.0.1",
+        "strip-ansi": "^3.0.1"
+      }
+    },
+    "wrappy": {
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/wrappy/-/wrappy-1.0.2.tgz",
+      "integrity": "sha1-tSQ9jz7BqjXxNkYFvA0QNuMKtp8="
+    },
+    "write": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/write/-/write-1.0.3.tgz",
+      "integrity": "sha512-/lg70HAjtkUgWPVZhZcm+T4hkL8Zbtp1nFNOn3lRrxnlv50SRBv7cR7RqR+GMsd3hUXy9hWBo4CHTbFTcOYwig==",
+      "dev": true,
+      "requires": {
+        "mkdirp": "^0.5.1"
+      }
+    },
+    "ws": {
+      "version": "3.3.3",
+      "resolved": "https://registry.npmjs.org/ws/-/ws-3.3.3.tgz",
+      "integrity": "sha512-nnWLa/NwZSt4KQJu51MYlCcSQ5g7INpOrOMt4XV8j4dqTXdmlUmSHQ8/oLC069ckre0fRsgfvsKwbTdtKLCDkA==",
+      "requires": {
+        "async-limiter": "~1.0.0",
+        "safe-buffer": "~5.1.0",
+        "ultron": "~1.1.0"
+      }
+    },
+    "xmlhttprequest-ssl": {
+      "version": "1.5.5",
+      "resolved": "https://registry.npmjs.org/xmlhttprequest-ssl/-/xmlhttprequest-ssl-1.5.5.tgz",
+      "integrity": "sha1-wodrBhaKrcQOV9l+gRkayPQ5iz4="
+    },
+    "xtend": {
+      "version": "4.0.1",
+      "resolved": "https://registry.npmjs.org/xtend/-/xtend-4.0.1.tgz",
+      "integrity": "sha1-pcbVMr5lbiPbgg77lDofBJmNY68="
+    },
+    "y18n": {
+      "version": "3.2.1",
+      "resolved": "https://registry.npmjs.org/y18n/-/y18n-3.2.1.tgz",
+      "integrity": "sha1-bRX7qITAhnnA136I53WegR4H+kE="
+    },
+    "yargs": {
+      "version": "4.8.1",
+      "resolved": "https://registry.npmjs.org/yargs/-/yargs-4.8.1.tgz",
+      "integrity": "sha1-wMQpJMpKqmsObaFznfshZDn53cA=",
+      "requires": {
+        "cliui": "^3.2.0",
+        "decamelize": "^1.1.1",
+        "get-caller-file": "^1.0.1",
+        "lodash.assign": "^4.0.3",
+        "os-locale": "^1.4.0",
+        "read-pkg-up": "^1.0.1",
+        "require-directory": "^2.1.1",
+        "require-main-filename": "^1.0.1",
+        "set-blocking": "^2.0.0",
+        "string-width": "^1.0.1",
+        "which-module": "^1.0.0",
+        "window-size": "^0.2.0",
+        "y18n": "^3.2.1",
+        "yargs-parser": "^2.4.1"
+      }
+    },
+    "yargs-parser": {
+      "version": "2.4.1",
+      "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-2.4.1.tgz",
+      "integrity": "sha1-hVaN488VD/SfpRgl8DqMiA3cxcQ=",
+      "requires": {
+        "camelcase": "^3.0.0",
+        "lodash.assign": "^4.0.6"
+      }
+    },
+    "yargs-unparser": {
+      "version": "1.5.0",
+      "resolved": "https://registry.npmjs.org/yargs-unparser/-/yargs-unparser-1.5.0.tgz",
+      "integrity": "sha512-HK25qidFTCVuj/D1VfNiEndpLIeJN78aqgR23nL3y4N0U/91cOAzqfHlF8n2BvoNDcZmJKin3ddNSvOxSr8flw==",
+      "dev": true,
+      "requires": {
+        "flat": "^4.1.0",
+        "lodash": "^4.17.11",
+        "yargs": "^12.0.5"
+      },
+      "dependencies": {
+        "ansi-regex": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-3.0.0.tgz",
+          "integrity": "sha1-7QMXwyIGT3lGbAKWa922Bas32Zg=",
+          "dev": true
+        },
+        "camelcase": {
+          "version": "5.3.1",
+          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.3.1.tgz",
+          "integrity": "sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==",
+          "dev": true
+        },
+        "cliui": {
+          "version": "4.1.0",
+          "resolved": "https://registry.npmjs.org/cliui/-/cliui-4.1.0.tgz",
+          "integrity": "sha512-4FG+RSG9DL7uEwRUZXZn3SS34DiDPfzP0VOiEwtUWlE+AR2EIg+hSyvrIgUUfhdgR/UkAeW2QHgeP+hWrXs7jQ==",
+          "dev": true,
+          "requires": {
+            "string-width": "^2.1.1",
+            "strip-ansi": "^4.0.0",
+            "wrap-ansi": "^2.0.0"
+          }
+        },
+        "find-up": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/find-up/-/find-up-3.0.0.tgz",
+          "integrity": "sha512-1yD6RmLI1XBfxugvORwlck6f75tYL+iR0jqwsOrOxMZyGYqUuDhJ0l4AXdO1iX/FTs9cBAMEk1gWSEx1kSbylg==",
+          "dev": true,
+          "requires": {
+            "locate-path": "^3.0.0"
+          }
+        },
+        "invert-kv": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-2.0.0.tgz",
+          "integrity": "sha512-wPVv/y/QQ/Uiirj/vh3oP+1Ww+AWehmi1g5fFWGPF6IpCBCDVrhgHRMvrLfdYcwDh3QJbGXDW4JAuzxElLSqKA==",
+          "dev": true
+        },
+        "is-fullwidth-code-point": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-2.0.0.tgz",
+          "integrity": "sha1-o7MKXE8ZkYMWeqq5O+764937ZU8=",
+          "dev": true
+        },
+        "lcid": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/lcid/-/lcid-2.0.0.tgz",
+          "integrity": "sha512-avPEb8P8EGnwXKClwsNUgryVjllcRqtMYa49NTsbQagYuT1DcXnl1915oxWjoyGrXR6zH/Y0Zc96xWsPcoDKeA==",
+          "dev": true,
+          "requires": {
+            "invert-kv": "^2.0.0"
+          }
+        },
+        "os-locale": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/os-locale/-/os-locale-3.1.0.tgz",
+          "integrity": "sha512-Z8l3R4wYWM40/52Z+S265okfFj8Kt2cC2MKY+xNi3kFs+XGI7WXu/I309QQQYbRW4ijiZ+yxs9pqEhJh0DqW3Q==",
+          "dev": true,
+          "requires": {
+            "execa": "^1.0.0",
+            "lcid": "^2.0.0",
+            "mem": "^4.0.0"
+          }
+        },
+        "string-width": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/string-width/-/string-width-2.1.1.tgz",
+          "integrity": "sha512-nOqH59deCq9SRHlxq1Aw85Jnt4w6KvLKqWVik6oA9ZklXLNIOlqg4F2yrT1MVaTjAqvVwdfeZ7w7aCvJD7ugkw==",
+          "dev": true,
+          "requires": {
+            "is-fullwidth-code-point": "^2.0.0",
+            "strip-ansi": "^4.0.0"
+          }
+        },
+        "strip-ansi": {
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
+          "integrity": "sha1-qEeQIusaw2iocTibY1JixQXuNo8=",
+          "dev": true,
+          "requires": {
+            "ansi-regex": "^3.0.0"
+          }
+        },
+        "which-module": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/which-module/-/which-module-2.0.0.tgz",
+          "integrity": "sha1-2e8H3Od7mQK4o6j6SzHD4/fm6Ho=",
+          "dev": true
+        },
+        "yargs": {
+          "version": "12.0.5",
+          "resolved": "https://registry.npmjs.org/yargs/-/yargs-12.0.5.tgz",
+          "integrity": "sha512-Lhz8TLaYnxq/2ObqHDql8dX8CJi97oHxrjUcYtzKbbykPtVW9WB+poxI+NM2UIzsMgNCZTIf0AQwsjK5yMAqZw==",
+          "dev": true,
+          "requires": {
+            "cliui": "^4.0.0",
+            "decamelize": "^1.2.0",
+            "find-up": "^3.0.0",
+            "get-caller-file": "^1.0.1",
+            "os-locale": "^3.0.0",
+            "require-directory": "^2.1.1",
+            "require-main-filename": "^1.0.1",
+            "set-blocking": "^2.0.0",
+            "string-width": "^2.0.0",
+            "which-module": "^2.0.0",
+            "y18n": "^3.2.1 || ^4.0.0",
+            "yargs-parser": "^11.1.1"
+          }
+        },
+        "yargs-parser": {
+          "version": "11.1.1",
+          "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-11.1.1.tgz",
+          "integrity": "sha512-C6kB/WJDiaxONLJQnF8ccx9SEeoTTLek8RVbaOIsrAUS8VrBEXfmeSnCZxygc+XC2sNMBIwOOnfcxiynjHsVSQ==",
+          "dev": true,
+          "requires": {
+            "camelcase": "^5.0.0",
+            "decamelize": "^1.2.0"
+          }
+        }
+      }
+    },
+    "yauzl": {
+      "version": "2.10.0",
+      "resolved": "https://registry.npmjs.org/yauzl/-/yauzl-2.10.0.tgz",
+      "integrity": "sha1-x+sXyT4RLLEIb6bY5R+wZnt5pfk=",
+      "requires": {
+        "buffer-crc32": "~0.2.3",
+        "fd-slicer": "~1.1.0"
+      }
+    },
+    "yeast": {
+      "version": "0.1.2",
+      "resolved": "https://registry.npmjs.org/yeast/-/yeast-0.1.2.tgz",
+      "integrity": "sha1-AI4G2AlDIMNy28L47XagymyKxBk="
+    },
+    "yn": {
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/yn/-/yn-2.0.0.tgz",
+      "integrity": "sha1-5a2ryKz0CPY4X8dklWhMiOavaJo="
+    }
+  }
+}
diff --git a/modules/web-console/backend/package.json b/modules/web-console/backend/package.json
index 5f15a55..f074c71 100644
--- a/modules/web-console/backend/package.json
+++ b/modules/web-console/backend/package.json
@@ -1,13 +1,13 @@
 {
   "name": "ignite-web-console",
-  "version": "2.7.0",
+  "version": "8.7.0",
   "description": "Interactive Web console for configuration, executing SQL queries and monitoring of Apache Ignite Cluster",
   "private": true,
   "main": "index.js",
   "scripts": {
     "ci-test": "cross-env NODE_ENV=test MOCHA_REPORTER=mocha-teamcity-reporter node ./test/index.js",
     "test": "cross-env NODE_ENV=test CONFIG_PATH='./test/config/settings.json' node ./test/index.js",
-    "eslint": "eslint --env node --format node_modules/eslint-friendly-formatter ./ -- --eff-by-issue",
+    "eslint": "eslint --env node --format friendly ./",
     "start": "node ./index.js",
     "build": "pkg . --out-path build"
   },
@@ -49,38 +49,38 @@
   },
   "dependencies": {
     "app-module-path": "2.2.0",
-    "body-parser": "1.17.2",
-    "connect-mongo": "1.3.2",
-    "cookie-parser": "1.4.3",
-    "express": "4.15.3",
+    "body-parser": "^1.18.3",
+    "connect-mongodb-session": "^2.1.1",
+    "cookie-parser": "^1.4.4",
+    "express": "^4.16.4",
     "express-mongo-sanitize": "1.3.2",
-    "express-session": "1.15.4",
+    "express-session": "^1.16.1",
     "fire-up": "1.0.0",
-    "glob": "7.1.2",
-    "jszip": "3.1.3",
-    "lodash": "4.17.10",
-    "migrate-mongoose": "3.2.2",
-    "mongodb-prebuilt": "6.3.3",
-    "mongoose": "4.11.4",
-    "morgan": "1.8.2",
-    "nconf": "0.8.4",
-    "nodemailer": "^5.1.1",
-    "passport": "0.3.2",
+    "glob": "7.1.3",
+    "jszip": "^3.2.1",
+    "lodash": "4.17.11",
+    "migrate-mongoose-typescript": "^3.3.4",
+    "mongodb-prebuilt": "6.5.0",
+    "mongoose": "^5.5.1",
+    "morgan": "^1.9.1",
+    "nconf": "^0.10.0",
+    "nodemailer": "^6.1.0",
+    "passport": "^0.4.0",
     "passport-local": "1.0.0",
-    "passport-local-mongoose": "4.0.0",
+    "passport-local-mongoose": "^5.0.1",
     "passport.socketio": "3.7.0",
-    "pkg": "4.3.7",
+    "pkg": "^4.3.7",
     "socket.io": "2.1.1",
-    "uuid": "3.1.0"
+    "uuid": "^3.3.2"
   },
   "devDependencies": {
-    "chai": "4.1.0",
-    "cross-env": "5.1.6",
-    "eslint": "4.3.0",
-    "eslint-friendly-formatter": "3.0.0",
-    "mocha": "3.4.2",
-    "mocha-teamcity-reporter": "1.1.1",
-    "mockgoose": "6.0.8",
+    "chai": "4.2.0",
+    "cross-env": "5.2.0",
+    "eslint": "^5.16.0",
+    "eslint-formatter-friendly": "^6.0.0",
+    "mocha": "^6.1.4",
+    "mocha-teamcity-reporter": "^2.5.2",
+    "mongodb-memory-server": "^5.0.4",
     "supertest": "3.0.0"
   }
 }
diff --git a/modules/web-console/backend/services/auth.js b/modules/web-console/backend/services/auth.js
index df25523..d4fe76e 100644
--- a/modules/web-console/backend/services/auth.js
+++ b/modules/web-console/backend/services/auth.js
@@ -56,7 +56,8 @@ module.exports.factory = (mongo, settings, errors, utilsService, mailsService) =
 
                     return user.save();
                 })
-                .then((user) => mailsService.sendResetLink(host, user));
+                .then((user) => mailsService.sendResetLink(host, user)
+                    .then(() => user));
         }
 
         /**
@@ -87,7 +88,8 @@ module.exports.factory = (mongo, settings, errors, utilsService, mailsService) =
                         });
                     });
                 })
-                .then((user) => mailsService.sendPasswordChanged(host, user));
+                .then((user) => mailsService.sendPasswordChanged(host, user)
+                    .then(() => user));
         }
 
         /**
@@ -167,7 +169,7 @@ module.exports.factory = (mongo, settings, errors, utilsService, mailsService) =
 
                     return user.save();
                 })
-                .then((user) =>  mailsService.sendActivationLink(host, user));
+                .then((user) => mailsService.sendActivationLink(host, user));
         }
     }
 
diff --git a/modules/web-console/backend/services/caches.js b/modules/web-console/backend/services/caches.js
index 2232ebc..6ef8032 100644
--- a/modules/web-console/backend/services/caches.js
+++ b/modules/web-console/backend/services/caches.js
@@ -37,7 +37,7 @@ module.exports.factory = (mongo, spacesService, errors) => {
      *
      * @param {RemoveResult} result - The results of remove operation.
      */
-    const convertRemoveStatus = ({result}) => ({rowsAffected: result.n});
+    const convertRemoveStatus = (result) => ({rowsAffected: result.n});
 
     /**
      * Update existing cache.
@@ -48,11 +48,11 @@ module.exports.factory = (mongo, spacesService, errors) => {
     const update = (cache) => {
         const cacheId = cache._id;
 
-        return mongo.Cache.update({_id: cacheId}, cache, {upsert: true}).exec()
-            .then(() => mongo.Cluster.update({_id: {$in: cache.clusters}}, {$addToSet: {caches: cacheId}}, {multi: true}).exec())
-            .then(() => mongo.Cluster.update({_id: {$nin: cache.clusters}}, {$pull: {caches: cacheId}}, {multi: true}).exec())
-            .then(() => mongo.DomainModel.update({_id: {$in: cache.domains}}, {$addToSet: {caches: cacheId}}, {multi: true}).exec())
-            .then(() => mongo.DomainModel.update({_id: {$nin: cache.domains}}, {$pull: {caches: cacheId}}, {multi: true}).exec())
+        return mongo.Cache.updateOne({_id: cacheId}, cache, {upsert: true}).exec()
+            .then(() => mongo.Cluster.updateMany({_id: {$in: cache.clusters}}, {$addToSet: {caches: cacheId}}).exec())
+            .then(() => mongo.Cluster.updateMany({_id: {$nin: cache.clusters}}, {$pull: {caches: cacheId}}).exec())
+            .then(() => mongo.DomainModel.updateMany({_id: {$in: cache.domains}}, {$addToSet: {caches: cacheId}}).exec())
+            .then(() => mongo.DomainModel.updateMany({_id: {$nin: cache.domains}}, {$pull: {caches: cacheId}}).exec())
             .then(() => cache)
             .catch((err) => {
                 if (err.code === mongo.errCodes.DUPLICATE_KEY_UPDATE_ERROR || err.code === mongo.errCodes.DUPLICATE_KEY_ERROR)
@@ -71,8 +71,8 @@ module.exports.factory = (mongo, spacesService, errors) => {
     const create = (cache) => {
         return mongo.Cache.create(cache)
             .then((savedCache) =>
-                mongo.Cluster.update({_id: {$in: savedCache.clusters}}, {$addToSet: {caches: savedCache._id}}, {multi: true}).exec()
-                    .then(() => mongo.DomainModel.update({_id: {$in: savedCache.domains}}, {$addToSet: {caches: savedCache._id}}, {multi: true}).exec())
+                mongo.Cluster.updateMany({_id: {$in: savedCache.clusters}}, {$addToSet: {caches: savedCache._id}}).exec()
+                    .then(() => mongo.DomainModel.updateMany({_id: {$in: savedCache.domains}}, {$addToSet: {caches: savedCache._id}}).exec())
                     .then(() => savedCache)
             )
             .catch((err) => {
@@ -90,10 +90,10 @@ module.exports.factory = (mongo, spacesService, errors) => {
      * @returns {Promise.<RemoveResult>} - that resolves results of remove operation.
      */
     const removeAllBySpaces = (spaceIds) => {
-        return mongo.Cluster.update({space: {$in: spaceIds}}, {caches: []}, {multi: true}).exec()
-            .then(() => mongo.Cluster.update({space: {$in: spaceIds}}, {$pull: {checkpointSpi: {kind: 'Cache'}}}, {multi: true}).exec())
-            .then(() => mongo.DomainModel.update({space: {$in: spaceIds}}, {caches: []}, {multi: true}).exec())
-            .then(() => mongo.Cache.remove({space: {$in: spaceIds}}).exec());
+        return mongo.Cluster.updateMany({space: {$in: spaceIds}}, {caches: []}).exec()
+            .then(() => mongo.Cluster.updateMany({space: {$in: spaceIds}}, {$pull: {checkpointSpi: {kind: 'Cache'}}}).exec())
+            .then(() => mongo.DomainModel.updateMany({space: {$in: spaceIds}}, {caches: []}).exec())
+            .then(() => mongo.Cache.deleteMany({space: {$in: spaceIds}}).exec());
     };
 
     /**
@@ -117,7 +117,7 @@ module.exports.factory = (mongo, spacesService, errors) => {
             const query = _.pick(cache, ['space', '_id']);
             const newDoc = _.pick(cache, ['space', '_id', 'name', 'cacheMode', 'atomicityMode', 'backups', 'clusters']);
 
-            return mongo.Cache.update(query, {$set: newDoc}, {upsert: true}).exec()
+            return mongo.Cache.updateOne(query, {$set: newDoc}, {upsert: true}).exec()
                 .catch((err) => {
                     if (err.code === mongo.errCodes.DUPLICATE_KEY_ERROR)
                         throw new errors.DuplicateKeyException(`Cache with name: "${cache.name}" already exist.`);
@@ -126,7 +126,7 @@ module.exports.factory = (mongo, spacesService, errors) => {
                 })
                 .then((updated) => {
                     if (updated.nModified === 0)
-                        return mongo.Cache.update(query, {$set: cache}, {upsert: true}).exec();
+                        return mongo.Cache.updateOne(query, {$set: cache}, {upsert: true}).exec();
 
                     return updated;
                 });
@@ -138,9 +138,9 @@ module.exports.factory = (mongo, spacesService, errors) => {
 
             const query = _.pick(cache, ['space', '_id']);
 
-            return mongo.Cache.update(query, {$set: cache}, {upsert: true}).exec()
-                .then(() => mongo.DomainModel.update({_id: {$in: cache.domains}}, {$addToSet: {caches: cache._id}}, {multi: true}).exec())
-                .then(() => mongo.DomainModel.update({_id: {$nin: cache.domains}}, {$pull: {caches: cache._id}}, {multi: true}).exec())
+            return mongo.Cache.updateOne(query, {$set: cache}, {upsert: true}).exec()
+                .then(() => mongo.DomainModel.updateMany({_id: {$in: cache.domains}}, {$addToSet: {caches: cache._id}}).exec())
+                .then(() => mongo.DomainModel.updateMany({_id: {$nin: cache.domains}}, {$pull: {caches: cache._id}}).exec())
                 .catch((err) => {
                     if (err.code === mongo.errCodes.DUPLICATE_KEY_ERROR)
                         throw new errors.DuplicateKeyException(`Cache with name: "${cache.name}" already exist.`);
@@ -187,12 +187,12 @@ module.exports.factory = (mongo, spacesService, errors) => {
             if (_.isEmpty(ids))
                 return Promise.resolve({rowsAffected: 0});
 
-            return mongo.Cluster.update({caches: {$in: ids}}, {$pull: {caches: {$in: ids}}}, {multi: true}).exec()
-                .then(() => mongo.Cluster.update({}, {$pull: {checkpointSpi: {kind: 'Cache', Cache: {cache: {$in: ids}}}}}, {multi: true}).exec())
+            return mongo.Cluster.updateMany({caches: {$in: ids}}, {$pull: {caches: {$in: ids}}}).exec()
+                .then(() => mongo.Cluster.updateMany({}, {$pull: {checkpointSpi: {kind: 'Cache', Cache: {cache: {$in: ids}}}}}).exec())
                 // TODO WC-201 fix cleanup of cache on deletion for cluster service configuration.
-                // .then(() => mongo.Cluster.update({'serviceConfigurations.cache': cacheId}, {$unset: {'serviceConfigurations.$.cache': ''}}, {multi: true}).exec())
-                .then(() => mongo.DomainModel.update({caches: {$in: ids}}, {$pull: {caches: {$in: ids}}}, {multi: true}).exec())
-                .then(() => mongo.Cache.remove({_id: {$in: ids}}).exec())
+                // .then(() => mongo.Cluster.updateMany({'serviceConfigurations.cache': cacheId}, {$unset: {'serviceConfigurations.$.cache': ''}}).exec())
+                .then(() => mongo.DomainModel.updateMany({caches: {$in: ids}}, {$pull: {caches: {$in: ids}}}).exec())
+                .then(() => mongo.Cache.deleteMany({_id: {$in: ids}}).exec())
                 .then(convertRemoveStatus);
         }
 
diff --git a/modules/web-console/backend/services/clusters.js b/modules/web-console/backend/services/clusters.js
index ee7b2f8..7b9da00 100644
--- a/modules/web-console/backend/services/clusters.js
+++ b/modules/web-console/backend/services/clusters.js
@@ -40,7 +40,7 @@ module.exports.factory = (mongo, spacesService, cachesService, modelsService, ig
      *
      * @param {RemoveResult} result - The results of remove operation.
      */
-    const convertRemoveStatus = ({result}) => ({rowsAffected: result.n});
+    const convertRemoveStatus = (result) => ({rowsAffected: result.n});
 
     /**
      * Update existing cluster.
@@ -51,11 +51,11 @@ module.exports.factory = (mongo, spacesService, cachesService, modelsService, ig
     const update = (cluster) => {
         const clusterId = cluster._id;
 
-        return mongo.Cluster.update({_id: clusterId}, cluster, {upsert: true}).exec()
-            .then(() => mongo.Cache.update({_id: {$in: cluster.caches}}, {$addToSet: {clusters: clusterId}}, {multi: true}).exec())
-            .then(() => mongo.Cache.update({_id: {$nin: cluster.caches}}, {$pull: {clusters: clusterId}}, {multi: true}).exec())
-            .then(() => mongo.Igfs.update({_id: {$in: cluster.igfss}}, {$addToSet: {clusters: clusterId}}, {multi: true}).exec())
-            .then(() => mongo.Igfs.update({_id: {$nin: cluster.igfss}}, {$pull: {clusters: clusterId}}, {multi: true}).exec())
+        return mongo.Cluster.updateOne({_id: clusterId}, cluster, {upsert: true}).exec()
+            .then(() => mongo.Cache.updateMany({_id: {$in: cluster.caches}}, {$addToSet: {clusters: clusterId}}).exec())
+            .then(() => mongo.Cache.updateMany({_id: {$nin: cluster.caches}}, {$pull: {clusters: clusterId}}).exec())
+            .then(() => mongo.Igfs.updateMany({_id: {$in: cluster.igfss}}, {$addToSet: {clusters: clusterId}}).exec())
+            .then(() => mongo.Igfs.updateMany({_id: {$nin: cluster.igfss}}, {$pull: {clusters: clusterId}}).exec())
             .then(() => cluster)
             .catch((err) => {
                 if (err.code === mongo.errCodes.DUPLICATE_KEY_UPDATE_ERROR || err.code === mongo.errCodes.DUPLICATE_KEY_ERROR)
@@ -80,8 +80,8 @@ module.exports.factory = (mongo, spacesService, cachesService, modelsService, ig
                     throw err;
             })
             .then((savedCluster) =>
-                mongo.Cache.update({_id: {$in: savedCluster.caches}}, {$addToSet: {clusters: savedCluster._id}}, {multi: true}).exec()
-                    .then(() => mongo.Igfs.update({_id: {$in: savedCluster.igfss}}, {$addToSet: {clusters: savedCluster._id}}, {multi: true}).exec())
+                mongo.Cache.updateMany({_id: {$in: savedCluster.caches}}, {$addToSet: {clusters: savedCluster._id}}).exec()
+                    .then(() => mongo.Igfs.updateMany({_id: {$in: savedCluster.igfss}}, {$addToSet: {clusters: savedCluster._id}}).exec())
                     .then(() => savedCluster)
             );
     };
@@ -94,11 +94,11 @@ module.exports.factory = (mongo, spacesService, cachesService, modelsService, ig
      */
     const removeAllBySpaces = (spaceIds) => {
         return Promise.all([
-            mongo.DomainModel.remove({space: {$in: spaceIds}}).exec(),
-            mongo.Cache.remove({space: {$in: spaceIds}}).exec(),
-            mongo.Igfs.remove({space: {$in: spaceIds}}).exec()
+            mongo.DomainModel.deleteMany({space: {$in: spaceIds}}).exec(),
+            mongo.Cache.deleteMany({space: {$in: spaceIds}}).exec(),
+            mongo.Igfs.deleteMany({space: {$in: spaceIds}}).exec()
         ])
-            .then(() => mongo.Cluster.remove({space: {$in: spaceIds}}).exec());
+            .then(() => mongo.Cluster.deleteMany({space: {$in: spaceIds}}).exec());
     };
 
     class ClustersService {
@@ -170,7 +170,7 @@ module.exports.factory = (mongo, spacesService, cachesService, modelsService, ig
 
                             cluster.caches = _.map(caches, '_id');
 
-                            return mongo.Cluster.update(query, {$set: cluster, new: true}, {upsert: true}).exec();
+                            return mongo.Cluster.updateOne(query, {$set: cluster, new: true}, {upsert: true}).exec();
                         });
                 })
                 .then(() => _.map(caches, cachesService.upsertBasic))
@@ -251,9 +251,9 @@ module.exports.factory = (mongo, spacesService, cachesService, modelsService, ig
                             return 0;
 
                         return Promise.all([
-                            mongo.DomainModel.remove({_id: {$in: cluster.models}}).exec(),
-                            mongo.Cache.remove({_id: {$in: cluster.caches}}).exec(),
-                            mongo.Igfs.remove({_id: {$in: cluster.igfss}}).exec()
+                            mongo.DomainModel.deleteMany({_id: {$in: cluster.models}}).exec(),
+                            mongo.Cache.deleteMany({_id: {$in: cluster.caches}}).exec(),
+                            mongo.Igfs.deleteMany({_id: {$in: cluster.igfss}}).exec()
                         ])
                             .then(() => 1);
                     });
diff --git a/modules/web-console/backend/services/domains.js b/modules/web-console/backend/services/domains.js
index bd59555..d345576 100644
--- a/modules/web-console/backend/services/domains.js
+++ b/modules/web-console/backend/services/domains.js
@@ -38,10 +38,10 @@ module.exports.factory = (mongo, spacesService, cachesService, errors) => {
      *
      * @param {RemoveResult} result - The results of remove operation.
      */
-    const convertRemoveStatus = ({result}) => ({rowsAffected: result.n});
+    const convertRemoveStatus = (result) => ({rowsAffected: result.n});
 
     const _updateCacheStore = (cacheStoreChanges) =>
-        Promise.all(_.map(cacheStoreChanges, (change) => mongo.Cache.update({_id: {$eq: change.cacheId}}, change.change, {}).exec()));
+        Promise.all(_.map(cacheStoreChanges, (change) => mongo.Cache.updateOne({_id: {$eq: change.cacheId}}, change.change, {}).exec()));
 
     /**
      * Update existing domain.
@@ -53,9 +53,9 @@ module.exports.factory = (mongo, spacesService, cachesService, errors) => {
     const update = (domain, savedDomains) => {
         const domainId = domain._id;
 
-        return mongo.DomainModel.update({_id: domainId}, domain, {upsert: true}).exec()
-            .then(() => mongo.Cache.update({_id: {$in: domain.caches}}, {$addToSet: {domains: domainId}}, {multi: true}).exec())
-            .then(() => mongo.Cache.update({_id: {$nin: domain.caches}}, {$pull: {domains: domainId}}, {multi: true}).exec())
+        return mongo.DomainModel.updateOne({_id: domainId}, domain, {upsert: true}).exec()
+            .then(() => mongo.Cache.updateMany({_id: {$in: domain.caches}}, {$addToSet: {domains: domainId}}).exec())
+            .then(() => mongo.Cache.updateMany({_id: {$nin: domain.caches}}, {$pull: {domains: domainId}}).exec())
             .then(() => {
                 savedDomains.push(domain);
 
@@ -81,7 +81,7 @@ module.exports.factory = (mongo, spacesService, cachesService, errors) => {
             .then((createdDomain) => {
                 savedDomains.push(createdDomain);
 
-                return mongo.Cache.update({_id: {$in: domain.caches}}, {$addToSet: {domains: createdDomain._id}}, {multi: true}).exec()
+                return mongo.Cache.updateMany({_id: {$in: domain.caches}}, {$addToSet: {domains: createdDomain._id}}).exec()
                     .then(() => _updateCacheStore(domain.cacheStoreChanges));
             })
             .catch((err) => {
@@ -143,8 +143,8 @@ module.exports.factory = (mongo, spacesService, cachesService, errors) => {
      * @returns {Promise.<RemoveResult>} - that resolves results of remove operation.
      */
     const removeAllBySpaces = (spaceIds) => {
-        return mongo.Cache.update({space: {$in: spaceIds}}, {domains: []}, {multi: true}).exec()
-            .then(() => mongo.DomainModel.remove({space: {$in: spaceIds}}).exec());
+        return mongo.Cache.updateMany({space: {$in: spaceIds}}, {domains: []}).exec()
+            .then(() => mongo.DomainModel.deleteMany({space: {$in: spaceIds}}).exec());
     };
 
     class DomainsService {
@@ -196,9 +196,9 @@ module.exports.factory = (mongo, spacesService, cachesService, errors) => {
 
             const query = _.pick(model, ['space', '_id']);
 
-            return mongo.DomainModel.update(query, {$set: model}, {upsert: true}).exec()
-                .then(() => mongo.Cache.update({_id: {$in: model.caches}}, {$addToSet: {domains: model._id}}, {multi: true}).exec())
-                .then(() => mongo.Cache.update({_id: {$nin: model.caches}}, {$pull: {domains: model._id}}, {multi: true}).exec())
+            return mongo.DomainModel.updateOne(query, {$set: model}, {upsert: true}).exec()
+                .then(() => mongo.Cache.updateMany({_id: {$in: model.caches}}, {$addToSet: {domains: model._id}}).exec())
+                .then(() => mongo.Cache.updateMany({_id: {$nin: model.caches}}, {$pull: {domains: model._id}}).exec())
                 .then(() => _updateCacheStore(model.cacheStoreChanges))
                 .catch((err) => {
                     if (err.code === mongo.errCodes.DUPLICATE_KEY_ERROR)
@@ -223,9 +223,9 @@ module.exports.factory = (mongo, spacesService, cachesService, errors) => {
             if (_.isEmpty(ids))
                 return Promise.resolve({rowsAffected: 0});
 
-            return mongo.Cache.update({domains: {$in: ids}}, {$pull: {domains: ids}}, {multi: true}).exec()
-                .then(() => mongo.Cluster.update({models: {$in: ids}}, {$pull: {models: ids}}, {multi: true}).exec())
-                .then(() => mongo.DomainModel.remove({_id: {$in: ids}}).exec())
+            return mongo.Cache.updateMany({domains: {$in: ids}}, {$pull: {domains: ids}}).exec()
+                .then(() => mongo.Cluster.updateMany({models: {$in: ids}}, {$pull: {models: ids}}).exec())
+                .then(() => mongo.DomainModel.deleteMany({_id: {$in: ids}}).exec())
                 .then(convertRemoveStatus);
         }
 
diff --git a/modules/web-console/backend/services/igfss.js b/modules/web-console/backend/services/igfss.js
index 29d6724..fb60fd5 100644
--- a/modules/web-console/backend/services/igfss.js
+++ b/modules/web-console/backend/services/igfss.js
@@ -37,7 +37,7 @@ module.exports.factory = (mongo, spacesService, errors) => {
      *
      * @param {RemoveResult} result - The results of remove operation.
      */
-    const convertRemoveStatus = ({result}) => ({rowsAffected: result.n});
+    const convertRemoveStatus = (result) => ({rowsAffected: result.n});
 
     /**
      * Update existing IGFS.
@@ -48,9 +48,9 @@ module.exports.factory = (mongo, spacesService, errors) => {
     const update = (igfs) => {
         const igfsId = igfs._id;
 
-        return mongo.Igfs.update({_id: igfsId}, igfs, {upsert: true}).exec()
-            .then(() => mongo.Cluster.update({_id: {$in: igfs.clusters}}, {$addToSet: {igfss: igfsId}}, {multi: true}).exec())
-            .then(() => mongo.Cluster.update({_id: {$nin: igfs.clusters}}, {$pull: {igfss: igfsId}}, {multi: true}).exec())
+        return mongo.Igfs.updateOne({_id: igfsId}, igfs, {upsert: true}).exec()
+            .then(() => mongo.Cluster.updateMany({_id: {$in: igfs.clusters}}, {$addToSet: {igfss: igfsId}}).exec())
+            .then(() => mongo.Cluster.updateMany({_id: {$nin: igfs.clusters}}, {$pull: {igfss: igfsId}}).exec())
             .then(() => igfs)
             .catch((err) => {
                 if (err.code === mongo.errCodes.DUPLICATE_KEY_UPDATE_ERROR || err.code === mongo.errCodes.DUPLICATE_KEY_ERROR)
@@ -69,7 +69,7 @@ module.exports.factory = (mongo, spacesService, errors) => {
     const create = (igfs) => {
         return mongo.Igfs.create(igfs)
             .then((savedIgfs) =>
-                mongo.Cluster.update({_id: {$in: savedIgfs.clusters}}, {$addToSet: {igfss: savedIgfs._id}}, {multi: true}).exec()
+                mongo.Cluster.updateMany({_id: {$in: savedIgfs.clusters}}, {$addToSet: {igfss: savedIgfs._id}}).exec()
                     .then(() => savedIgfs)
             )
             .catch((err) => {
@@ -87,8 +87,8 @@ module.exports.factory = (mongo, spacesService, errors) => {
      * @returns {Promise.<RemoveResult>} - that resolves results of remove operation.
      */
     const removeAllBySpaces = (spaceIds) => {
-        return mongo.Cluster.update({space: {$in: spaceIds}}, {igfss: []}, {multi: true}).exec()
-            .then(() => mongo.Igfs.remove({space: {$in: spaceIds}}).exec());
+        return mongo.Cluster.updateMany({space: {$in: spaceIds}}, {igfss: []}).exec()
+            .then(() => mongo.Igfs.deleteMany({space: {$in: spaceIds}}).exec());
     };
 
     class IgfssService {
@@ -108,7 +108,7 @@ module.exports.factory = (mongo, spacesService, errors) => {
 
             const query = _.pick(igfs, ['space', '_id']);
 
-            return mongo.Igfs.update(query, {$set: igfs}, {upsert: true}).exec()
+            return mongo.Igfs.updateOne(query, {$set: igfs}, {upsert: true}).exec()
                 .catch((err) => {
                     if (err.code === mongo.errCodes.DUPLICATE_KEY_ERROR)
                         throw new errors.DuplicateKeyException(`IGFS with name: "${igfs.name}" already exist.`);
@@ -155,13 +155,13 @@ module.exports.factory = (mongo, spacesService, errors) => {
             if (_.isEmpty(ids))
                 return Promise.resolve({rowsAffected: 0});
 
-            return mongo.Cluster.update({igfss: {$in: ids}}, {$pull: {igfss: {$in: ids}}}, {multi: true}).exec()
+            return mongo.Cluster.updateMany({igfss: {$in: ids}}, {$pull: {igfss: {$in: ids}}}).exec()
                 // TODO WC-201 fix cleanup on node filter on deletion for cluster serviceConfigurations and caches.
-                // .then(() => mongo.Cluster.update({ 'serviceConfigurations.$.nodeFilter.kind': { $ne: 'IGFS' }, 'serviceConfigurations.nodeFilter.IGFS.igfs': igfsId},
-                //     {$unset: {'serviceConfigurations.$.nodeFilter.IGFS.igfs': ''}}, {multi: true}).exec())
-                // .then(() => mongo.Cluster.update({ 'serviceConfigurations.nodeFilter.kind': 'IGFS', 'serviceConfigurations.nodeFilter.IGFS.igfs': igfsId},
-                //     {$unset: {'serviceConfigurations.$.nodeFilter': ''}}, {multi: true}).exec())
-                .then(() => mongo.Igfs.remove({_id: {$in: ids}}).exec())
+                // .then(() => mongo.Cluster.updateMany({ 'serviceConfigurations.$.nodeFilter.kind': { $ne: 'IGFS' }, 'serviceConfigurations.nodeFilter.IGFS.igfs': igfsId},
+                //     {$unset: {'serviceConfigurations.$.nodeFilter.IGFS.igfs': ''}}).exec())
+                // .then(() => mongo.Cluster.updateMany({ 'serviceConfigurations.nodeFilter.kind': 'IGFS', 'serviceConfigurations.nodeFilter.IGFS.igfs': igfsId},
+                //     {$unset: {'serviceConfigurations.$.nodeFilter': ''}}).exec())
+                .then(() => mongo.Igfs.deleteMany({_id: {$in: ids}}).exec())
                 .then(convertRemoveStatus);
         }
 
diff --git a/modules/web-console/backend/services/mails.js b/modules/web-console/backend/services/mails.js
index f39cc98..6428ff4 100644
--- a/modules/web-console/backend/services/mails.js
+++ b/modules/web-console/backend/services/mails.js
@@ -56,7 +56,7 @@ module.exports.factory = (settings) => {
          * @throws IOException If failed to prepare template.
          */
         getMessage(template, ctx) {
-            _.forIn(ctx, (value, key) => template = template.replace(new RegExp(`\\$\\{${key}\\}`, 'g'), value || 'n/a'));
+            _.forIn(ctx, (value, key) => template = template.replace(new RegExp(`\\$\\{${key}\\}`, 'g'), value || 'n/a'));
 
             return template;
         }
@@ -113,7 +113,7 @@ module.exports.factory = (settings) => {
                 })
                 .then((transporter) => {
                     const context = this.buildContext(host, user, message, customCtx);
-                    
+
                     context.subject = this.getMessage(subject, context);
 
                     return transporter.sendMail({
diff --git a/modules/web-console/backend/services/notebooks.js b/modules/web-console/backend/services/notebooks.js
index be447ae..518ab81 100644
--- a/modules/web-console/backend/services/notebooks.js
+++ b/modules/web-console/backend/services/notebooks.js
@@ -37,7 +37,7 @@ module.exports.factory = (mongo, spacesService, errors) => {
      *
      * @param {RemoveResult} result - The results of remove operation.
      */
-    const convertRemoveStatus = ({result}) => ({rowsAffected: result.n});
+    const convertRemoveStatus = (result) => ({rowsAffected: result.n});
 
     /**
      * Update existing notebook.
@@ -105,7 +105,7 @@ module.exports.factory = (mongo, spacesService, errors) => {
             if (_.isNil(notebookId))
                 return Promise.reject(new errors.IllegalArgumentException('Notebook id can not be undefined or null'));
 
-            return mongo.Notebook.remove({_id: notebookId}).exec()
+            return mongo.Notebook.deleteOne({_id: notebookId}).exec()
                 .then(convertRemoveStatus);
         }
     }
diff --git a/modules/web-console/backend/services/spaces.js b/modules/web-console/backend/services/spaces.js
index bdec30d..98c1394 100644
--- a/modules/web-console/backend/services/spaces.js
+++ b/modules/web-console/backend/services/spaces.js
@@ -76,10 +76,10 @@ module.exports.factory = (mongo, errors) => {
          */
         static cleanUp(spaceIds) {
             return Promise.all([
-                mongo.Cluster.remove({space: {$in: spaceIds}}).exec(),
-                mongo.Cache.remove({space: {$in: spaceIds}}).exec(),
-                mongo.DomainModel.remove({space: {$in: spaceIds}}).exec(),
-                mongo.Igfs.remove({space: {$in: spaceIds}}).exec()
+                mongo.Cluster.deleteMany({space: {$in: spaceIds}}).exec(),
+                mongo.Cache.deleteMany({space: {$in: spaceIds}}).exec(),
+                mongo.DomainModel.deleteMany({space: {$in: spaceIds}}).exec(),
+                mongo.Igfs.deleteMany({space: {$in: spaceIds}}).exec()
             ]);
         }
     }
diff --git a/modules/web-console/backend/services/users.js b/modules/web-console/backend/services/users.js
index 741b283..cd95a56 100644
--- a/modules/web-console/backend/services/users.js
+++ b/modules/web-console/backend/services/users.js
@@ -233,12 +233,12 @@ module.exports.factory = (errors, settings, mongo, spacesService, mailsService,
                 .then((user) => {
                     return spacesService.spaceIds(userId)
                         .then((spaceIds) => Promise.all([
-                            mongo.Cluster.remove({space: {$in: spaceIds}}).exec(),
-                            mongo.Cache.remove({space: {$in: spaceIds}}).exec(),
-                            mongo.DomainModel.remove({space: {$in: spaceIds}}).exec(),
-                            mongo.Igfs.remove({space: {$in: spaceIds}}).exec(),
-                            mongo.Notebook.remove({space: {$in: spaceIds}}).exec(),
-                            mongo.Space.remove({owner: userId}).exec()
+                            mongo.Cluster.deleteMany({space: {$in: spaceIds}}).exec(),
+                            mongo.Cache.deleteMany({space: {$in: spaceIds}}).exec(),
+                            mongo.DomainModel.deleteMany({space: {$in: spaceIds}}).exec(),
+                            mongo.Igfs.deleteMany({space: {$in: spaceIds}}).exec(),
+                            mongo.Notebook.deleteMany({space: {$in: spaceIds}}).exec(),
+                            mongo.Space.deleteOne({owner: userId}).exec()
                         ]))
                         .catch((err) => console.error(`Failed to cleanup spaces [user=${user.username}, err=${err}`))
                         .then(() => user);
diff --git a/modules/web-console/backend/test/app/db.js b/modules/web-console/backend/test/app/db.js
index 10dfb8f..e207509 100644
--- a/modules/web-console/backend/test/app/db.js
+++ b/modules/web-console/backend/test/app/db.js
@@ -19,6 +19,7 @@
 // Fire me up!
 
 const _ = require('lodash');
+const mongoose = require('mongoose');
 
 const testAccounts = require('../data/accounts.json');
 const testClusters = require('../data/clusters.json');
@@ -29,10 +30,10 @@ const testSpaces = require('../data/spaces.json');
 
 module.exports = {
     implements: 'dbHelper',
-    inject: ['mongo', 'mongoose']
+    inject: ['mongo']
 };
 
-module.exports.factory = (mongo, mongoose) => {
+module.exports.factory = (mongo) => {
     const prepareUserSpaces = () => Promise.all([mongo.Account.create(testAccounts), mongo.Space.create(testSpaces)]);
     const prepareClusters = () => mongo.Cluster.create(testClusters);
     const prepareDomains = () => mongo.DomainModel.create(testDomains);
@@ -40,7 +41,7 @@ module.exports.factory = (mongo, mongoose) => {
     const prepareIgfss = () => mongo.Igfs.create(testIgfss);
 
     const drop = () => {
-        return Promise.all(_.map(mongoose.connection.collections, (collection) => collection.remove()));
+        return Promise.all(_.map(mongoose.connection.collections, (collection) => collection.deleteMany()));
     };
 
     const init = () => {
diff --git a/modules/web-console/backend/app/mongoose.js b/modules/web-console/backend/test/app/mail.js
similarity index 80%
rename from modules/web-console/backend/app/mongoose.js
rename to modules/web-console/backend/test/app/mail.js
index b9375b8..edd063d 100644
--- a/modules/web-console/backend/app/mongoose.js
+++ b/modules/web-console/backend/test/app/mail.js
@@ -16,11 +16,15 @@
 
 'use strict';
 
-const mongoose = require('mongoose');
-
 // Fire me up!
 
 module.exports = {
-    implements: 'mongoose',
-    factory: () => mongoose
+    implements: 'services/mails:mock',
+    inject: ['services/mails']
+};
+
+module.exports.factory = (mails) => {
+    mails.send = () => Promise.resolve(true);
+
+    return mails;
 };
diff --git a/modules/web-console/backend/test/app/mockgoose.js b/modules/web-console/backend/test/app/settings.js
similarity index 66%
rename from modules/web-console/backend/test/app/mockgoose.js
rename to modules/web-console/backend/test/app/settings.js
index 7350b9c..ef8ef0a 100644
--- a/modules/web-console/backend/test/app/mockgoose.js
+++ b/modules/web-console/backend/test/app/settings.js
@@ -16,14 +16,22 @@
 
 'use strict';
 
+const MongoMemoryServer = require('mongodb-memory-server').default;
+
 // Fire me up!
 
 module.exports = {
-    implements: 'mongoose:mock',
-    inject: ['require(mongoose)', 'require(mockgoose)']
+    implements: 'settings:mock',
+    inject: ['settings']
 };
 
-module.exports.factory = (mongoose, mockgoose) => {
-    return mockgoose(mongoose)
-            .then(() => mongoose);
+module.exports.factory = (settings) => {
+    const mongoServer = new MongoMemoryServer();
+
+    return mongoServer.getConnectionString()
+        .then((mongoUrl) => {
+            settings.mongoUrl = mongoUrl;
+
+            return settings;
+        });
 };
diff --git a/modules/web-console/backend/test/config/settings.json b/modules/web-console/backend/test/config/settings.json
index a17a777..5796260 100644
--- a/modules/web-console/backend/test/config/settings.json
+++ b/modules/web-console/backend/test/config/settings.json
@@ -3,9 +3,6 @@
     "port": 3000,
     "ssl": false
   },
-  "mongodb": {
-    "url": "mongodb://localhost/console-test"
-  },
   "agentServer": {
     "port": 3001,
     "ssl": false
diff --git a/modules/web-console/backend/test/injector.js b/modules/web-console/backend/test/injector.js
index 169285d..0112567 100644
--- a/modules/web-console/backend/test/injector.js
+++ b/modules/web-console/backend/test/injector.js
@@ -28,5 +28,8 @@ module.exports = fireUp.newInjector({
         './services/**/*.js',
         './test/app/*.js'
     ],
-    use: ['mongoose:mock']
+    use: [
+        'settings:mock',
+        'services/mails:mock'
+    ]
 });
diff --git a/modules/web-console/backend/test/unit/ActivitiesService.test.js b/modules/web-console/backend/test/unit/ActivitiesService.test.js
index 304cf3f..155c9c0 100644
--- a/modules/web-console/backend/test/unit/ActivitiesService.test.js
+++ b/modules/web-console/backend/test/unit/ActivitiesService.test.js
@@ -22,7 +22,8 @@ let activitiesService;
 let mongo;
 let db;
 
-const owner = testAccounts[0]._id;
+const testAccount = testAccounts[0];
+const owner = testAccount._id;
 const group = 'test';
 const action1 = '/test/activity1';
 const action2 = '/test/activity2';
@@ -44,7 +45,7 @@ suite('ActivitiesServiceTestsSuite', () => {
     setup(() => db.init());
 
     test('Activities creation and update', (done) => {
-        activitiesService.merge(owner, { group, action: action1 })
+        activitiesService.merge(testAccount, { group, action: action1 })
             .then((activity) => {
                 assert.isNotNull(activity);
                 assert.equal(activity.amount, 1);
@@ -55,7 +56,7 @@ suite('ActivitiesServiceTestsSuite', () => {
                 assert.isNotNull(activityDoc);
                 assert.equal(activityDoc.amount, 1);
             })
-            .then(() => activitiesService.merge(owner, { group, action: action1 }))
+            .then(() => activitiesService.merge(testAccount, { group, action: action1 }))
             .then((activity) => {
                 assert.isNotNull(activity);
                 assert.equal(activity.amount, 2);
@@ -80,8 +81,8 @@ suite('ActivitiesServiceTestsSuite', () => {
         endDate.setMonth(endDate.getMonth() + 1);
 
         Promise.all([
-            activitiesService.merge(owner, {group, action: action1}),
-            activitiesService.merge(owner, {group, action: action2})
+            activitiesService.merge(testAccount, {group, action: action1}),
+            activitiesService.merge(testAccount, {group, action: action2})
         ])
             .then(() => activitiesService.total(owner, {startDate, endDate}))
             .then((activities) =>
@@ -114,8 +115,8 @@ suite('ActivitiesServiceTestsSuite', () => {
         const borderDate = nextMonth(startDate);
         const endDate = nextMonth(borderDate);
 
-        activitiesService.merge(owner, { group, action: action1 })
-            .then(() => activitiesService.merge(owner, { group, action: action1 }, borderDate))
+        activitiesService.merge(testAccount, { group, action: action1 })
+            .then(() => activitiesService.merge(testAccount, { group, action: action1 }, borderDate))
             .then(() => activitiesService.total({ startDate, endDate: borderDate }))
             .then((activities) =>
                 assert.equal(activities[owner].test, 1)
diff --git a/modules/web-console/backend/test/unit/AuthService.test.js b/modules/web-console/backend/test/unit/AuthService.test.js
index 36ce454..2bf409d 100644
--- a/modules/web-console/backend/test/unit/AuthService.test.js
+++ b/modules/web-console/backend/test/unit/AuthService.test.js
@@ -45,7 +45,7 @@ suite('AuthServiceTestsSuite', () => {
     });
 
     test('Reset password token for existing user', (done) => {
-        authService.resetPasswordToken(testAccounts[0].email)
+        authService.resetPasswordToken(null, testAccounts[0].email)
             .then((account) => {
                 assert.notEqual(account.resetPasswordToken.length, 0);
                 assert.notEqual(account.resetPasswordToken, testAccounts[0].resetPasswordToken);
@@ -63,7 +63,7 @@ suite('AuthServiceTestsSuite', () => {
     });
 
     test('Reset password by token for existing user', (done) => {
-        authService.resetPasswordByToken(testAccounts[0].resetPasswordToken, 'NewUniquePassword$1')
+        authService.resetPasswordByToken(null, testAccounts[0].resetPasswordToken, 'NewUniquePassword$1')
             .then((account) => {
                 assert.isUndefined(account.resetPasswordToken);
                 assert.notEqual(account.hash, 0);
diff --git a/modules/web-console/docker/compose/docker-compose.yml b/modules/web-console/docker/compose/docker-compose.yml
index 6e1a6de..11df74f 100644
--- a/modules/web-console/docker/compose/docker-compose.yml
+++ b/modules/web-console/docker/compose/docker-compose.yml
@@ -17,7 +17,7 @@ version: '3'
 
 services:
   mongodb:
-    image: mongo:3.4
+    image: mongo:4.0
     container_name: 'mongodb'
     volumes:
       # External volume for persisting data. (HOST_PATH:CONTAINER_PATH).
diff --git a/modules/web-console/e2e/docker-compose.yml b/modules/web-console/e2e/docker-compose.yml
index 5ab63c3..95ec0c6 100644
--- a/modules/web-console/e2e/docker-compose.yml
+++ b/modules/web-console/e2e/docker-compose.yml
@@ -13,10 +13,10 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 #
-version: '2'
+version: '3'
 services:
   mongodb:
-    image: 'mongo:3.4'
+    image: mongo:4.0
     container_name: 'mongodb'
 
   testenv:


[ignite] 17/17: GG-18539: Remove useless code.

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 6175879bd69b83aaa79a714146914b356d787b08
Author: Andrey V. Mashenkov <an...@gmail.com>
AuthorDate: Tue Apr 30 13:13:31 2019 +0300

    GG-18539: Remove useless code.
---
 modules/h2/pom.xml                                 |     7 -
 modules/h2/src/docsrc/html/advanced.html           |  1968 ---
 modules/h2/src/docsrc/html/architecture.html       |   154 -
 modules/h2/src/docsrc/html/build.html              |   325 -
 modules/h2/src/docsrc/html/changelog.html          |  1487 ---
 modules/h2/src/docsrc/html/cheatSheet.html         |   216 -
 modules/h2/src/docsrc/html/commands.html           |   179 -
 modules/h2/src/docsrc/html/datatypes.html          |    99 -
 modules/h2/src/docsrc/html/download.html           |    76 -
 modules/h2/src/docsrc/html/faq.html                |   288 -
 modules/h2/src/docsrc/html/features.html           |  1719 ---
 modules/h2/src/docsrc/html/fragments.html          |   130 -
 modules/h2/src/docsrc/html/frame.html              |    40 -
 modules/h2/src/docsrc/html/functions.html          |   324 -
 modules/h2/src/docsrc/html/grammar.html            |   178 -
 modules/h2/src/docsrc/html/history.html            |   182 -
 .../html/images/connection-mode-embedded-2.png     |   Bin 48466 -> 0 bytes
 .../html/images/connection-mode-embedded.png       |   Bin 20407 -> 0 bytes
 .../docsrc/html/images/connection-mode-mixed-2.png |   Bin 70685 -> 0 bytes
 .../docsrc/html/images/connection-mode-mixed.png   |   Bin 31588 -> 0 bytes
 .../html/images/connection-mode-remote-2.png       |   Bin 58248 -> 0 bytes
 .../docsrc/html/images/connection-mode-remote.png  |   Bin 25020 -> 0 bytes
 modules/h2/src/docsrc/html/images/console-2.png    |   Bin 68604 -> 0 bytes
 modules/h2/src/docsrc/html/images/console.png      |   Bin 29569 -> 0 bytes
 modules/h2/src/docsrc/html/images/db-16.png        |   Bin 547 -> 0 bytes
 modules/h2/src/docsrc/html/images/db-64-t.png      |   Bin 11867 -> 0 bytes
 modules/h2/src/docsrc/html/images/download-2.png   |   Bin 2673 -> 0 bytes
 modules/h2/src/docsrc/html/images/download.png     |   Bin 745 -> 0 bytes
 modules/h2/src/docsrc/html/images/h2-logo-2.png    |   Bin 4810 -> 0 bytes
 modules/h2/src/docsrc/html/images/h2-logo.png      |   Bin 3361 -> 0 bytes
 .../h2/src/docsrc/html/images/h2-logo_square.png   |   Bin 2330 -> 0 bytes
 .../h2/src/docsrc/html/images/icon_disconnect.gif  |   Bin 114 -> 0 bytes
 modules/h2/src/docsrc/html/images/language_de.png  |   Bin 240 -> 0 bytes
 modules/h2/src/docsrc/html/images/language_en.gif  |   Bin 268 -> 0 bytes
 modules/h2/src/docsrc/html/images/language_ja.gif  |   Bin 685 -> 0 bytes
 modules/h2/src/docsrc/html/images/mail-support.png |   Bin 756 -> 0 bytes
 .../h2/src/docsrc/html/images/paypal-donate.png    |   Bin 6172 -> 0 bytes
 modules/h2/src/docsrc/html/images/performance.png  |   Bin 2343 -> 0 bytes
 modules/h2/src/docsrc/html/images/quickstart-1.png |   Bin 13911 -> 0 bytes
 modules/h2/src/docsrc/html/images/quickstart-2.png |   Bin 3765 -> 0 bytes
 modules/h2/src/docsrc/html/images/quickstart-3.png |   Bin 11783 -> 0 bytes
 modules/h2/src/docsrc/html/images/quickstart-4.png |   Bin 30387 -> 0 bytes
 modules/h2/src/docsrc/html/images/quickstart-5.png |   Bin 36043 -> 0 bytes
 modules/h2/src/docsrc/html/images/quickstart-6.png |   Bin 31108 -> 0 bytes
 modules/h2/src/docsrc/html/images/screenshot.png   |   Bin 16894 -> 0 bytes
 modules/h2/src/docsrc/html/installation.html       |   122 -
 modules/h2/src/docsrc/html/license.html            |   404 -
 modules/h2/src/docsrc/html/links.html              |   708 --
 modules/h2/src/docsrc/html/main.html               |    46 -
 modules/h2/src/docsrc/html/mainWeb.html            |   195 -
 modules/h2/src/docsrc/html/mvstore.html            |   749 --
 modules/h2/src/docsrc/html/navigation.js           |   195 -
 modules/h2/src/docsrc/html/performance.html        |   893 --
 modules/h2/src/docsrc/html/quickstart.html         |   105 -
 modules/h2/src/docsrc/html/roadmap.html            |   532 -
 modules/h2/src/docsrc/html/search.js               |   273 -
 modules/h2/src/docsrc/html/source.html             |    52 -
 modules/h2/src/docsrc/html/sourceError.html        |   252 -
 modules/h2/src/docsrc/html/stylesheet.css          |   379 -
 modules/h2/src/docsrc/html/stylesheetPdf.css       |   154 -
 modules/h2/src/docsrc/html/systemtables.html       |    63 -
 modules/h2/src/docsrc/html/tutorial.html           |  1502 ---
 .../docsrc/images/connection-mode-embedded-2.png   |   Bin 48466 -> 0 bytes
 .../src/docsrc/images/connection-mode-mixed-2.png  |   Bin 70685 -> 0 bytes
 .../src/docsrc/images/connection-mode-remote-2.png |   Bin 58248 -> 0 bytes
 modules/h2/src/docsrc/images/connection-modes.svg  |  1118 --
 modules/h2/src/docsrc/images/console-2.png         |   Bin 68604 -> 0 bytes
 modules/h2/src/docsrc/images/console.png           |   Bin 29569 -> 0 bytes
 modules/h2/src/docsrc/images/console.svg           |   515 -
 modules/h2/src/docsrc/images/db-16.png             |   Bin 547 -> 0 bytes
 modules/h2/src/docsrc/images/db-22.png             |   Bin 1239 -> 0 bytes
 modules/h2/src/docsrc/images/db-24.png             |   Bin 574 -> 0 bytes
 modules/h2/src/docsrc/images/db-32.png             |   Bin 1399 -> 0 bytes
 modules/h2/src/docsrc/images/db-64-t.png           |   Bin 11867 -> 0 bytes
 modules/h2/src/docsrc/images/db.svg                |   308 -
 modules/h2/src/docsrc/images/download-2.png        |   Bin 2673 -> 0 bytes
 modules/h2/src/docsrc/images/download.png          |   Bin 745 -> 0 bytes
 modules/h2/src/docsrc/images/download.svg          |   125 -
 modules/h2/src/docsrc/images/favicon.ico           |   Bin 4286 -> 0 bytes
 modules/h2/src/docsrc/images/h2-16.png             |   Bin 675 -> 0 bytes
 modules/h2/src/docsrc/images/h2-24.png             |   Bin 995 -> 0 bytes
 modules/h2/src/docsrc/images/h2-32.png             |   Bin 1362 -> 0 bytes
 modules/h2/src/docsrc/images/h2-64.png             |   Bin 2718 -> 0 bytes
 modules/h2/src/docsrc/images/h2-logo-2.png         |   Bin 6617 -> 0 bytes
 modules/h2/src/docsrc/images/h2-logo.png           |   Bin 12780 -> 0 bytes
 modules/h2/src/docsrc/images/h2-logo.svg           |    61 -
 modules/h2/src/docsrc/images/h2_v2_3_7.svg         |    61 -
 modules/h2/src/docsrc/images/paypal-donate.png     |   Bin 6172 -> 0 bytes
 modules/h2/src/docsrc/images/screenshot.png        |   Bin 113875 -> 0 bytes
 modules/h2/src/docsrc/index.html                   |    44 -
 modules/h2/src/docsrc/javadoc/animate.js           |    51 -
 modules/h2/src/docsrc/javadoc/classes.html         |    98 -
 modules/h2/src/docsrc/javadoc/index.html           |    24 -
 modules/h2/src/docsrc/javadoc/overview.html        |    38 -
 modules/h2/src/docsrc/javadoc/stylesheet.css       |   171 -
 modules/h2/src/docsrc/text/_docs_ja.utf8.txt       | 12512 -------------------
 modules/h2/src/test/tools/WEB-INF/console.html     |    15 -
 modules/h2/src/test/tools/WEB-INF/web.xml          |    67 -
 modules/h2/src/test/tools/org/h2/build/Build.java  |  1192 --
 .../test/tools/org/h2/build/code/AbbaDetect.java   |   101 -
 .../test/tools/org/h2/build/code/CheckJavadoc.java |   130 -
 .../tools/org/h2/build/code/CheckTextFiles.java    |   313 -
 .../src/test/tools/org/h2/build/code/package.html  |    14 -
 .../test/tools/org/h2/build/doc/FileConverter.java |    65 -
 .../test/tools/org/h2/build/doc/GenerateDoc.java   |   298 -
 .../test/tools/org/h2/build/doc/LinkChecker.java   |   276 -
 .../src/test/tools/org/h2/build/doc/MergeDocs.java |   130 -
 .../tools/org/h2/build/doc/RailroadImages.java     |   130 -
 .../test/tools/org/h2/build/doc/SpellChecker.java  |   305 -
 .../test/tools/org/h2/build/doc/UploadBuild.java   |   261 -
 .../src/test/tools/org/h2/build/doc/WebSite.java   |   168 -
 .../test/tools/org/h2/build/doc/XMLChecker.java    |   149 -
 .../src/test/tools/org/h2/build/doc/XMLParser.java |   511 -
 .../src/test/tools/org/h2/build/doc/dictionary.txt |   813 --
 .../src/test/tools/org/h2/build/doclet/Doclet.java |   590 -
 .../tools/org/h2/build/doclet/ResourceDoclet.java  |   132 -
 .../test/tools/org/h2/build/doclet/package.html    |    14 -
 .../org/h2/build/i18n/PrepareTranslation.java      |   542 -
 .../tools/org/h2/build/i18n/PropertiesToUTF8.java  |   158 -
 .../src/test/tools/org/h2/build/i18n/package.html  |    14 -
 .../tools/org/h2/build/indexer/HtmlConverter.java  |   190 -
 .../test/tools/org/h2/build/indexer/Indexer.java   |   369 -
 .../src/test/tools/org/h2/build/indexer/Page.java  |    49 -
 .../test/tools/org/h2/build/indexer/Weight.java    |    43 -
 .../src/test/tools/org/h2/build/indexer/Word.java  |    82 -
 .../test/tools/org/h2/build/indexer/package.html   |    14 -
 .../h2/src/test/tools/org/h2/jcr/Railroads.java    |   129 -
 modules/h2/src/test/tools/org/h2/jcr/help.csv      |    99 -
 modules/h2/src/test/tools/org/h2/jcr/jcr-sql2.html |    72 -
 modules/h2/src/test/tools/org/h2/jcr/package.html  |    14 -
 .../h2/src/test/tools/org/h2/jcr/stylesheet.css    |   340 -
 131 files changed, 36911 deletions(-)

diff --git a/modules/h2/pom.xml b/modules/h2/pom.xml
index 5ba7a15..903e454 100644
--- a/modules/h2/pom.xml
+++ b/modules/h2/pom.xml
@@ -80,12 +80,6 @@
             <version>${slf4j16.version}</version>
             <scope>test</scope>
         </dependency>
-       <!-- <dependency>
-            <groupId>org.postgresql</groupId>
-            <artifactId>postgresql</artifactId>
-            <version>42.2.5.jre7</version>
-            <scope>test</scope>
-        </dependency>-->
         <dependency>
             <groupId>org.ow2.asm</groupId>
             <artifactId>asm</artifactId>
@@ -124,7 +118,6 @@
                     <include>**/*.js</include>
                     <include>org/h2/res/help.csv</include>
                     <include>org/h2/res/javadoc.properties</include>
-                    <include>org/h2/server/pg/pg_catalog.sql</include>
                     <include>META-INF/**</include>
                 </includes>
             </resource>
diff --git a/modules/h2/src/docsrc/html/advanced.html b/modules/h2/src/docsrc/html/advanced.html
deleted file mode 100644
index c1d0501..0000000
--- a/modules/h2/src/docsrc/html/advanced.html
+++ /dev/null
@@ -1,1968 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head>
-<meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Advanced
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>Advanced</h1>
-<a href="#result_sets">
-    Result Sets</a><br />
-<a href="#large_objects">
-    Large Objects</a><br />
-<a href="#linked_tables">
-    Linked Tables</a><br />
-<a href="#spatial_features">
-    Spatial Features</a><br />
-<a href="#recursive_queries">
-    Recursive Queries</a><br />
-<a href="#updatable_views">
-    Updatable Views</a><br />
-<a href="#transaction_isolation">
-    Transaction Isolation</a><br />
-<a href="#mvcc">
-    Multi-Version Concurrency Control (MVCC)</a><br />
-<a href="#clustering">
-    Clustering / High Availability</a><br />
-<a href="#two_phase_commit">
-    Two Phase Commit</a><br />
-<a href="#compatibility">
-    Compatibility</a><br />
-<a href="#keywords">
-    Keywords / Reserved Words</a><br />
-<a href="#standards_compliance">
-    Standards Compliance</a><br />
-<a href="#windows_service">
-    Run as Windows Service</a><br />
-<a href="#odbc_driver">
-    ODBC Driver</a><br />
-<a href="#microsoft_dot_net">
-    Using H2 in Microsoft .NET</a><br />
-<a href="#acid">
-    ACID</a><br />
-<a href="#durability_problems">
-    Durability Problems</a><br />
-<a href="#using_recover_tool">
-    Using the Recover Tool</a><br />
-<a href="#file_locking_protocols">
-    File Locking Protocols</a><br />
-<a href="#passwords">
-    Using Passwords</a><br />
-<a href="#password_hash">
-    Password Hash</a><br />
-<a href="#sql_injection">
-    Protection against SQL Injection</a><br />
-<a href="#remote_access">
-    Protection against Remote Access</a><br />
-<a href="#restricting_classes">
-    Restricting Class Loading and Usage</a><br />
-<a href="#security_protocols">
-    Security Protocols</a><br />
-<a href="#tls_connections">
-    TLS Connections</a><br />
-<a href="#uuid">
-    Universally Unique Identifiers (UUID)</a><br />
-<a href="#system_properties">
-    Settings Read from System Properties</a><br />
-<a href="#server_bind_address">
-    Setting the Server Bind Address</a><br />
-<a href="#file_system">
-    Pluggable File System</a><br />
-<a href="#file_system_split">
-    Split File System</a><br />
-<a href="#database_upgrade">
-    Database Upgrade</a><br />
-<a href="#java_objects_serialization">
-    Java Objects Serialization</a><br />
-<a href="#custom_data_types_handler_api">
-    Custom Data Types Handler API</a><br />
-<a href="#limits_limitations">
-    Limits and Limitations</a><br />
-<a href="#glossary_links">
-    Glossary and Links</a><br />
-
-<h2 id="result_sets">Result Sets</h2>
-
-<h3>Statements that Return a Result Set</h3>
-<p>
-The following statements return a result set: <code>SELECT, EXPLAIN, CALL, SCRIPT, SHOW, HELP</code>.
-All other statements return an update count.
-</p>
-
-<h3>Limiting the Number of Rows</h3>
-<p>
-Before the result is returned to the application, all rows are read by the database.
-Server side cursors are not supported currently.
-If only the first few rows are interesting for the application, then the
-result set size should be limited to improve the performance.
-This can be done using <code>FETCH</code> in a query
-(example: <code>SELECT * FROM TEST FETCH FIRST 100 ROWS ONLY</code>),
-or by using <code>Statement.setMaxRows(max)</code>.
-</p>
-
-<h3>Large Result Sets and External Sorting</h3>
-<p>
-For large result set, the result is buffered to disk. The threshold can be defined using the statement
-<code>SET MAX_MEMORY_ROWS</code>.
-If <code>ORDER BY</code> is used, the sorting is done using an
-external sort algorithm.
-In this case, each block of rows is sorted using quick sort, then written to disk;
-when reading the data, the blocks are merged together.
-</p>
-
-<h2 id="large_objects">Large Objects</h2>
-
-<h3>Storing and Reading Large Objects</h3>
-<p>
-If it is possible that the objects don't fit into memory, then the data type
-CLOB (for textual data) or BLOB (for binary data) should be used.
-For these data types, the objects are not fully read into memory, by using streams.
-To store a BLOB, use <code>PreparedStatement.setBinaryStream</code>. To store a CLOB, use
-<code>PreparedStatement.setCharacterStream</code>. To read a BLOB, use <code>ResultSet.getBinaryStream</code>,
-and to read a CLOB, use <code>ResultSet.getCharacterStream</code>.
-When using the client/server mode, large BLOB and CLOB data is stored in a temporary file
-on the client side.
-</p>
-
-<h3>When to use CLOB/BLOB</h3>
-<p>
-By default, this database stores large LOB (CLOB and BLOB) objects separate from the main table data.
-Small LOB objects are stored in-place, the threshold can be set using
-<a href="commands.html#set_max_length_inplace_lob" class="notranslate" >MAX_LENGTH_INPLACE_LOB</a>,
-but there is still an overhead to use CLOB/BLOB. Because of this, BLOB and CLOB
-should never be used for columns with a maximum size below about 200 bytes.
-The best threshold depends on the use case; reading in-place objects is faster
-than reading from separate files, but slows down the performance of operations
-that don't involve this column.
-</p>
-
-<h3>Large Object Compression</h3>
-<p>
-The following feature is only available for the PageStore storage engine.
-For the MVStore engine (the default for H2 version 1.4.x),
-append <code>;COMPRESS=TRUE</code> to the database URL instead.
-CLOB and BLOB values can be compressed by using
-<a href="commands.html#set_compress_lob" class="notranslate" >SET COMPRESS_LOB</a>.
-The LZF algorithm is faster but needs more disk space. By default compression is disabled, which usually speeds up write
-operations. If you store many large compressible values such as XML, HTML, text, and uncompressed binary files,
-then compressing can save a lot of disk space (sometimes more than 50%), and read operations may even be faster.
-</p>
-
-<h2 id="linked_tables">Linked Tables</h2>
-<p>
-This database supports linked tables, which means tables that don't exist in the current database but
-are just links to another database. To create such a link, use the
-<code>CREATE LINKED TABLE</code> statement:
-</p>
-<pre>
-CREATE LINKED TABLE LINK('org.postgresql.Driver', 'jdbc:postgresql:test', 'sa', 'sa', 'TEST');
-</pre>
-<p>
-You can then access the table in the usual way.
-Whenever the linked table is accessed, the database issues specific queries over JDBC.
-Using the example above, if you issue the query <code>SELECT * FROM LINK WHERE ID=1</code>,
-then the following query is run against the PostgreSQL database: <code>SELECT * FROM TEST WHERE ID=?</code>.
-The same happens for insert and update statements.
-Only simple statements are executed against the target database, that means no joins
-(queries that contain joins are converted to simple queries).
-Prepared statements are used where possible.
-</p>
-<p>
-To view the statements that are executed against the target table, set the trace level to 3.
-</p>
-<p>
-If multiple linked tables point to the same database (using the same database URL), the connection
-is shared. To disable this, set the system property <code>h2.shareLinkedConnections=false</code>.
-</p>
-<p>
-The statement <a href="commands.html#create_linked_table" class="notranslate" >CREATE LINKED TABLE</a>
-supports an optional schema name parameter.
-</p>
-<p>
-The following are not supported because they may result in a deadlock:
-creating a linked table to the same database,
-and creating a linked table to another database using the server mode if the other database is open in the same server
-(use the embedded mode instead).
-</p>
-<p>
-Data types that are not supported in H2 are also not supported for linked tables,
-for example unsigned data types if the value is outside the range of the signed type.
-In such cases, the columns needs to be cast to a supported type.
-</p>
-
-<h2 id="updatable_views">Updatable Views</h2>
-<p>
-By default, views are not updatable.
-To make a view updatable, use an "instead of" trigger as follows:
-</p>
-<pre>
-CREATE TRIGGER TRIGGER_NAME
-INSTEAD OF INSERT, UPDATE, DELETE
-ON VIEW_NAME
-FOR EACH ROW CALL "com.acme.TriggerClassName";
-</pre>
-<p>
-Update the base table(s) within the trigger as required.
-For details, see the sample application <code>org.h2.samples.UpdatableView</code>.
-</p>
-
-<h2 id="transaction_isolation">Transaction Isolation</h2>
-<p>
-Please note that most data definition language (DDL) statements,
-such as "create table", commit the current transaction.
-See the <a href="commands.html">Commands</a> for details.
-</p>
-<p>
-Transaction isolation is provided for all data manipulation language (DML) statements.
-</p>
-<p>
-Please note that with default MVStore storage engine table level locking is not used.
-Instead, rows are locked for update, and read committed is used in all cases
-except for explicitly selected read uncommitted transaction isolation level.
-</p>
-<p>
-This database supports the following transaction isolation levels:
-</p>
-<ul>
-<li><b>Read Committed</b><br />
-    This is the default level.
-    Read locks are released immediately after executing the statement, but write locks are kept until the transaction commits.
-    Higher concurrency is possible when using this level.<br />
-    To enable, execute the SQL statement <code>SET LOCK_MODE 3</code><br />
-    or append <code>;LOCK_MODE=3</code> to the database URL: <code>jdbc:h2:~/test;LOCK_MODE=3</code>
-</li><li>
-<b>Serializable</b><br />
-    Both read locks and write locks are kept until the transaction commits.
-    To enable, execute the SQL statement <code>SET LOCK_MODE 1</code><br />
-    or append <code>;LOCK_MODE=1</code> to the database URL: <code>jdbc:h2:~/test;LOCK_MODE=1</code>
-</li><li><b>Read Uncommitted</b><br />
-    This level means that transaction isolation is disabled.
-    This level is not supported by PageStore engine if multi-threaded mode is enabled.
-    <br />
-    To enable, execute the SQL statement <code>SET LOCK_MODE 0</code><br />
-    or append <code>;LOCK_MODE=0</code> to the database URL: <code>jdbc:h2:~/test;LOCK_MODE=0</code>
-</li>
-</ul>
-<p>
-When using the isolation level 'serializable', dirty reads, non-repeatable reads, and phantom reads are prohibited.
-</p>
-<ul>
-<li><b>Dirty Reads</b><br />
-    Means a connection can read uncommitted changes made by another connection.<br />
-    Possible with: read uncommitted
-</li><li><b>Non-Repeatable Reads</b><br />
-    A connection reads a row, another connection changes a row and commits,
-    and the first connection re-reads the same row and gets the new result.<br />
-    Possible with: read uncommitted, read committed
-</li><li><b>Phantom Reads</b><br />
-    A connection reads a set of rows using a condition, another connection
-    inserts a row that falls in this condition and commits, then the first connection
-    re-reads using the same condition and gets the new row.<br />
-    Possible with: read uncommitted, read committed
-</li>
-</ul>
-
-<h3 id="mvcc">Multi-Version Concurrency Control (MVCC)</h3>
-<p>
-With default MVStore engine delete, insert and update operations only issue a shared lock on the table.
-An exclusive lock is still used when adding or removing columns or when dropping the table.
-Connections only 'see' committed data, and own changes. That means, if connection A updates
-a row but doesn't commit this change yet, connection B will see the old value.
-Only when the change is committed, the new value is visible by other connections
-(read committed). If multiple connections concurrently try to lock or update the same row, the
-database waits until it can apply the change, but at most until the lock timeout expires.
-</p>
-
-<h3>Table Level Locking (PageStore engine)</h3>
-<p>
-With PageStore engine to make sure all connections only see consistent data, table level locking is used.
-This mechanism does not allow high concurrency, but is very fast.
-Shared locks and exclusive locks are supported.
-Before reading from a table, the database tries to add a shared lock to the table
-(this is only possible if there is no exclusive lock on the object by another connection).
-If the shared lock is added successfully, the table can be read. It is allowed that
-other connections also have a shared lock on the same object. If a connection wants
-to write to a table (update or delete a row), an exclusive lock is required. To get the
-exclusive lock, other connection must not have any locks on the object. After the
-connection commits, all locks are released.
-This database keeps all locks in memory.
-When a lock is released, and multiple connections are waiting for it, one of them is picked at random.
-</p>
-
-<h3>Lock Timeout</h3>
-<p>
-If a connection cannot get a lock on an object, the connection waits for some amount
-of time (the lock timeout). During this time, hopefully the connection holding the
-lock commits and it is then possible to get the lock. If this is not possible because
-the other connection does not release the lock for some time, the unsuccessful
-connection will get a lock timeout exception. The lock timeout can be set individually
-for each connection.
-</p>
-
-<h2 id="clustering">Clustering / High Availability</h2>
-<p>
-This database supports a simple clustering / high availability mechanism. The architecture is:
-two database servers run on two different computers, and on both computers is a copy of the
-same database. If both servers run, each database operation is executed on both computers.
-If one server fails (power, hardware or network failure), the other server can still continue to work.
-From this point on, the operations will be executed only on one server until the other server
-is back up.
-</p><p>
-Clustering can only be used in the server mode (the embedded mode does not support clustering).
-The cluster can be re-created using the <code>CreateCluster</code> tool without stopping
-the remaining server. Applications that are still connected are automatically disconnected,
-however when appending <code>;AUTO_RECONNECT=TRUE</code>, they will recover from that.
-</p><p>
-To initialize the cluster, use the following steps:
-</p>
-<ul>
-<li>Create a database
-</li><li>Use the <code>CreateCluster</code> tool to copy the database to
-    another location and initialize the clustering.
-    Afterwards, you have two databases containing the same data.
-</li><li>Start two servers (one for each copy of the database)
-</li><li>You are now ready to connect to the databases with the client application(s)
-</li></ul>
-
-<h3>Using the CreateCluster Tool</h3>
-<p>
-To understand how clustering works, please try out the following example.
-In this example, the two databases reside on the same computer, but usually, the
-databases will be on different servers.
-</p>
-<ul>
-<li>Create two directories: <code>server1, server2</code>.
-    Each directory will simulate a directory on a computer.
-</li><li>Start a TCP server pointing to the first directory.
-    You can do this using the command line:
-<pre>
-java org.h2.tools.Server
-    -tcp -tcpPort 9101
-    -baseDir server1
-</pre>
-</li><li>Start a second TCP server pointing to the second directory.
-    This will simulate a server running on a second (redundant) computer.
-    You can do this using the command line:
-<pre>
-java org.h2.tools.Server
-    -tcp -tcpPort 9102
-    -baseDir server2
-</pre>
-</li><li>Use the <code>CreateCluster</code> tool to initialize clustering.
-    This will automatically create a new, empty database if it does not exist.
-    Run the tool on the command line:
-<pre>
-java org.h2.tools.CreateCluster
-    -urlSource jdbc:h2:tcp://localhost:9101/~/test
-    -urlTarget jdbc:h2:tcp://localhost:9102/~/test
-    -user sa
-    -serverList localhost:9101,localhost:9102
-</pre>
-</li><li>You can now connect to the databases using
-an application or the H2 Console using the JDBC URL
-<code>jdbc:h2:tcp://localhost:9101,localhost:9102/~/test</code>
-</li><li>If you stop a server (by killing the process),
-you will notice that the other machine continues to work,
-and therefore the database is still accessible.
-</li><li>To restore the cluster, you first need to delete the
-database that failed, then restart the server that was stopped,
-and re-run the <code>CreateCluster</code> tool.
-</li></ul>
-
-<h3>Detect Which Cluster Instances are Running</h3>
-<p>
-To find out which cluster nodes are currently running, execute the following SQL statement:
-</p>
-<pre>
-SELECT VALUE FROM INFORMATION_SCHEMA.SETTINGS WHERE NAME='CLUSTER'
-</pre>
-<p>
-If the result is <code>''</code> (two single quotes), then the cluster mode is disabled. Otherwise, the list of
-servers is returned, enclosed in single quote. Example: <code>'server1:9191,server2:9191'</code>.
-</p>
-
-<p>
-It is also possible to get the list of servers by using Connection.getClientInfo().
-</p>
-
-<p>
-The property list returned from <code>getClientInfo()</code> contains a <code>numServers</code> property that returns the
-number of servers that are in the connection list. To get the actual servers, <code>getClientInfo()</code> also has
-properties <code>server0</code>..<code>serverX</code>, where serverX is the number of servers minus 1.
-</p>
-
-<p>
-Example: To get the 2nd server in the connection list one uses <code>getClientInfo('server1')</code>.
-<b>Note:</b> The <code>serverX</code> property only returns IP addresses and ports and not hostnames.
-</p>
-
-<h3>Clustering Algorithm and Limitations</h3>
-<p>
-Read-only queries are only executed against the first cluster node, but all other statements are
-executed against all nodes. There is currently no load balancing made to avoid problems with
-transactions. The following functions may yield different results on different cluster nodes and must be
-executed with care: <code>UUID(), RANDOM_UUID(), SECURE_RAND(), SESSION_ID(),
-MEMORY_FREE(), MEMORY_USED(), CSVREAD(), CSVWRITE(), RAND()</code> [when not using a seed].
-Those functions should not be used directly in modifying statements
-(for example <code>INSERT, UPDATE, MERGE</code>). However, they can be used
-in read-only statements and the result can then be used for modifying statements.
-Using auto-increment and identity columns is currently not supported.
-Instead, sequence values need to be manually requested and then used to insert data (using two statements).
-</p>
-<p>
-When using the cluster modes, result sets are read fully in memory by the client, so that
-there is no problem if the server dies that executed the query. Result sets must fit in memory
-on the client side.
-</p>
-<p>
-The SQL statement <code>SET AUTOCOMMIT FALSE</code> is not supported in the cluster mode.
-To disable autocommit, the method <code>Connection.setAutoCommit(false)</code> needs to be called.
-</p>
-<p>
-It is possible that a transaction from one connection overtakes a transaction from a different connection.
-Depending on the operations, this might result in different results, for example when
-conditionally incrementing a value in a row.
-</p>
-
-<h2 id="two_phase_commit">Two Phase Commit</h2>
-<p>
-The two phase commit protocol is supported. 2-phase-commit works as follows:
-</p>
-<ul>
-<li>Autocommit needs to be switched off
-</li><li>A transaction is started, for example by inserting a row
-</li><li>The transaction is marked 'prepared' by executing the SQL statement
-    <code>PREPARE COMMIT transactionName</code>
-</li><li>The transaction can now be committed or rolled back
-</li><li>If a problem occurs before the transaction was successfully committed or rolled back
-    (for example because a network problem occurred), the transaction is in the state 'in-doubt'
-</li><li>When re-connecting to the database, the in-doubt transactions can be listed
-    with <code>SELECT * FROM INFORMATION_SCHEMA.IN_DOUBT</code>
-</li><li>Each transaction in this list must now be committed or rolled back by executing
-    <code>COMMIT TRANSACTION transactionName</code> or
-    <code>ROLLBACK TRANSACTION transactionName</code>
-</li><li>The database needs to be closed and re-opened to apply the changes
-</li></ul>
-
-<h2 id="compatibility">Compatibility</h2>
-<p>
-This database is (up to a certain point) compatible to other databases such as HSQLDB, MySQL and PostgreSQL.
-There are certain areas where H2 is incompatible.
-</p>
-
-<h3>Transaction Commit when Autocommit is On</h3>
-<p>
-At this time, this database engine commits a transaction (if autocommit is switched on) just before returning the result.
-For a query, this means the transaction is committed even before the application scans through the result set, and before the result set is closed.
-Other database engines may commit the transaction in this case when the result set is closed.
-</p>
-
-<h2 id="keywords">Keywords / Reserved Words</h2>
-<p>
-There is a list of keywords that can't be used as identifiers (table names, column names and so on),
-unless they are quoted (surrounded with double quotes).
-The following tokens are keywords in H2:
-</p>
-<table class="main">
-<thead>
-<tr>
-<th>Keyword</th>
-<th>H2</th>
-<th>SQL:&#8203;2011</th>
-<th>SQL:&#8203;2008</th>
-<th>SQL:&#8203;2003</th>
-<th>SQL:&#8203;1999</th>
-<th>SQL-92</th>
-</tr>
-</thead>
-<tbody>
-<tr><td>ALL</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>AND</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>ARRAY</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td></td></tr>
-<tr><td>AS</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>BETWEEN</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>NR</td><td>+</td></tr>
-<tr><td>BOTH</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>CASE</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>CHECK</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>CONSTRAINT</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>CROSS</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>CURRENT_DATE</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>CURRENT_TIME</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>CURRENT_TIMESTAMP</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>CURRENT_USER</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>DISTINCT</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>EXCEPT</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>EXISTS</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>NR</td><td>+</td></tr>
-<tr><td>FALSE</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>FETCH</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>FILTER</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td></td><td></td></tr>
-<tr><td>FOR</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>FOREIGN</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>FROM</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>FULL</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>GROUP</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>GROUPS</td>
-<td>CS</td><td>+</td><td></td><td></td><td></td><td></td></tr>
-<tr><td>HAVING</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>IF</td>
-<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>ILIKE</td>
-<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>IN</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>INNER</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>INTERSECT</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>INTERSECTS</td>
-<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>INTERVAL</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>IS</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>JOIN</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>LEADING</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>LEFT</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>LIKE</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>LIMIT</td>
-<td>+</td><td></td><td></td><td></td><td>+</td><td></td></tr>
-<tr><td>LOCALTIME</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td></td></tr>
-<tr><td>LOCALTIMESTAMP</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td></td></tr>
-<tr><td>MINUS</td>
-<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>NATURAL</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>NOT</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>NULL</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>OFFSET</td>
-<td>+</td><td>+</td><td>+</td><td></td><td></td><td></td></tr>
-<tr><td>ON</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>OR</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>ORDER</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>OVER</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td></td><td></td></tr>
-<tr><td>PARTITION</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td></td><td></td></tr>
-<tr><td>PRIMARY</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>QUALIFY</td>
-<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>RANGE</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td></td><td></td></tr>
-<tr><td>REGEXP</td>
-<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>RIGHT</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>ROW</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td></td></tr>
-<tr><td>_ROWID_</td>
-<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>ROWNUM</td>
-<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>ROWS</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>SELECT</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>SYSDATE</td>
-<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>SYSTIME</td>
-<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>SYSTIMESTAMP</td>
-<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>TABLE</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>TODAY</td>
-<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>TOP</td>
-<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
-<tr><td>TRAILING</td>
-<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>TRUE</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>UNION</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>UNIQUE</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>VALUES</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>WHERE</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-<tr><td>WINDOW</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td></td><td></td></tr>
-<tr><td>WITH</td>
-<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
-</tbody>
-</table>
-<p>
-Some keywords in H2 are context-sensitive (CS), such keywords may be used as identifiers in some places,
-but cannot be used as identifiers in others.
-Most keywords in H2 are also reserved (+) or non-reserved (NR) words in the SQL Standard.
-Newer versions of H2 may have more keywords than older ones.
-</p>
-
-<h2 id="standards_compliance">Standards Compliance</h2>
-<p>
-This database tries to be as much standard compliant as possible. For the SQL language, ANSI/ISO is the main
-standard. There are several versions that refer to the release date: SQL-92, SQL:1999, and SQL:2003.
-Unfortunately, the standard documentation is not freely available. Another problem is that important features
-are not standardized. Whenever this is the case, this database tries to be compatible to other databases.
-</p>
-
-<h3>Supported Character Sets, Character Encoding, and Unicode</h3>
-<p>
-H2 internally uses Unicode, and supports all character encoding systems and character sets supported by the virtual machine you use.
-</p>
-
-<h2 id="windows_service">Run as Windows Service</h2>
-<p>
-Using a native wrapper / adapter, Java applications can be run as a Windows Service.
-There are various tools available to do that. The Java Service Wrapper from
-<a href="https://wrapper.tanukisoftware.org">Tanuki Software, Inc.</a>
-is included in the installation. Batch files are provided to install, start, stop and uninstall the
-H2 Database Engine Service. This service contains the TCP Server and the H2 Console web application.
-The batch files are located in the directory <code>h2/service</code>.
-</p>
-<p>
-The service wrapper bundled with H2 is a 32-bit version.
-To use a 64-bit version of Windows (x64), you need to use a 64-bit version of the wrapper,
-for example the one from
-<a href="https://www.krenger.ch/blog/java-service-wrapper-3-5-14-for-windows-x64/">
-Simon Krenger</a>.
-</p>
-<p>
-When running the database as a service, absolute path should be used.
-Using <code>~</code> in the database URL is problematic in this case,
-because it means to use the home directory of the current user.
-The service might run without or with the wrong user, so that
-the database files might end up in an unexpected place.
-</p>
-
-<h3>Install the Service</h3>
-<p>
-The service needs to be registered as a Windows Service first.
-To do that, double click on <code>1_install_service.bat</code>.
-If successful, a command prompt window will pop up and disappear immediately. If not, a message will appear.
-</p>
-
-<h3>Start the Service</h3>
-<p>
-You can start the H2 Database Engine Service using the service manager of Windows,
-or by double clicking on <code>2_start_service.bat</code>.
-Please note that the batch file does not print an error message if the service is not installed.
-</p>
-
-<h3>Connect to the H2 Console</h3>
-<p>
-After installing and starting the service, you can connect to the H2 Console application using a browser.
-Double clicking on <code>3_start_browser.bat</code> to do that. The
-default port (8082) is hard coded in the batch file.
-</p>
-
-<h3>Stop the Service</h3>
-<p>
-To stop the service, double click on <code>4_stop_service.bat</code>.
-Please note that the batch file does not print an error message if the service is not installed or started.
-</p>
-
-<h3>Uninstall the Service</h3>
-<p>
-To uninstall the service, double click on <code>5_uninstall_service.bat</code>.
-If successful, a command prompt window will pop up and disappear immediately. If not, a message will appear.
-</p>
-
-<h3>Additional JDBC drivers</h3>
-<p>
-To use other databases (for example MySQL), the location of the JDBC drivers of those databases need to be
-added to the environment variables <code>H2DRIVERS</code>  or <code>CLASSPATH</code> before
-installing the service. Multiple drivers can be set; each entry needs to be separated with a <code>;</code>
-(Windows) or <code>:</code>  (other operating systems). Spaces in the path names are supported.
-The settings must not be quoted.
-</p>
-
-<h2 id="odbc_driver">ODBC Driver</h2>
-<p>
-This database does not come with its own ODBC driver at this time,
-but it supports the PostgreSQL network protocol.
-Therefore, the PostgreSQL ODBC driver can be used.
-Support for the PostgreSQL network protocol is quite new and should be viewed
-as experimental. It should not be used for production applications.
-</p>
-<p>
-To use the PostgreSQL ODBC driver on 64 bit versions of Windows,
-first run <code>c:/windows/syswow64/odbcad32.exe</code>.
-At this point you set up your DSN just like you would on any other system.
-See also:
-<a href="https://www.postgresql.org/message-id/dg76q0$khn$1@sea.gmane.org">Re: ODBC Driver on Windows 64 bit</a>
-</p>
-
-<h3>ODBC Installation</h3>
-<p>
-First, the ODBC driver must be installed.
-Any recent PostgreSQL ODBC driver should work, however version 8.2 (<code>psqlodbc-08_02*</code>) or newer is recommended.
-The Windows version of the PostgreSQL ODBC driver is available at
-<a href="https://www.postgresql.org/ftp/odbc/versions/msi/">https://www.postgresql.org/ftp/odbc/versions/msi/</a>.
-</p>
-
-<h3>Starting the Server</h3>
-<p>
-After installing the ODBC driver, start the H2 Server using the command line:
-</p>
-<pre>
-java -cp h2*.jar org.h2.tools.Server
-</pre>
-<p>
-The PG Server (PG for PostgreSQL protocol) is started as well.
-By default, databases are stored in the current working directory where the server is started.
-Use <code>-baseDir</code> to save databases in another directory, for example the user home directory:
-</p>
-<pre>
-java -cp h2*.jar org.h2.tools.Server -baseDir ~
-</pre>
-<p>
-The PG server can be started and stopped from within a Java application as follows:
-</p>
-<pre>
-Server server = Server.createPgServer("-baseDir", "~");
-server.start();
-...
-server.stop();
-</pre>
-<p>
-By default, only connections from localhost are allowed. To allow remote connections, use
-<code>-pgAllowOthers</code> when starting the server.
-</p>
-<p>
-To map an ODBC database name to a different JDBC database name,
-use the option <code>-key</code> when starting the server.
-Please note only one mapping is allowed. The following will map the ODBC database named
-<code>TEST</code> to the database URL <code>jdbc:h2:~/data/test;cipher=aes</code>:
-</p>
-<pre>
-java org.h2.tools.Server -pg -key TEST "~/data/test;cipher=aes"
-</pre>
-
-<h3>ODBC Configuration</h3>
-<p>
-After installing the driver, a new Data Source must be added. In Windows,
-run <code>odbcad32.exe</code> to open the Data Source Administrator. Then click on 'Add...'
-and select the PostgreSQL Unicode driver. Then click 'Finish'.
-You will be able to change the connection properties.
-The property column represents the property key in the <code>odbc.ini</code> file
-(which may be different from the GUI).
-</p>
-<table class="main">
-<tr><th>Property</th><th>Example</th><th>Remarks</th></tr>
-<tr><td>Data Source</td><td>H2 Test</td><td>The name of the ODBC Data Source</td></tr>
-<tr><td>Database</td><td>~/test;ifexists=true</td>
-    <td>
-        The database name. This can include connections settings.
-        By default, the database is stored in the current working directory
-        where the Server is started except when the -baseDir setting is used.
-        The name must be at least 3 characters.
-    </td></tr>
-<tr><td>Servername</td><td>localhost</td><td>The server name or IP address.<br />By default, only remote connections are allowed</td></tr>
-<tr><td>Username</td><td>sa</td><td>The database user name.</td></tr>
-<tr><td>SSL</td><td>false (disabled)</td><td>At this time, SSL is not supported.</td></tr>
-<tr><td>Port</td><td>5435</td><td>The port where the PG Server is listening.</td></tr>
-<tr><td>Password</td><td>sa</td><td>The database password.</td></tr>
-</table>
-<p>
-To improve performance, please enable 'server side prepare' under Options / Datasource / Page 2 / Server side prepare.
-</p>
-<p>
-Afterwards, you may use this data source.
-</p>
-
-<h3>PG Protocol Support Limitations</h3>
-<p>
-At this time, only a subset of the PostgreSQL network protocol is implemented.
-Also, there may be compatibility problems on the SQL level, with the catalog, or with text encoding.
-Problems are fixed as they are found.
-Currently, statements can not be canceled when using the PG protocol.
-Also, H2 does not provide index meta over ODBC.
-</p>
-<p>
-PostgreSQL ODBC Driver Setup requires a database password; that means it
-is not possible to connect to H2 databases without password. This is a limitation
-of the ODBC driver.
-</p>
-
-<h3>Security Considerations</h3>
-<p>
-Currently, the PG Server does not support challenge response or encrypt passwords.
-This may be a problem if an attacker can listen to the data transferred between the ODBC driver
-and the server, because the password is readable to the attacker.
-Also, it is currently not possible to use encrypted SSL connections.
-Therefore the ODBC driver should not be used where security is important.
-</p>
-<p>
-The first connection that opens a database using the PostgreSQL server needs to be an administrator user.
-Subsequent connections don't need to be opened by an administrator.
-</p>
-
-<h3>Using Microsoft Access</h3>
-<p>
-When using Microsoft Access to edit data in a linked H2 table, you may need to enable the following option:
-Tools - Options - Edit/Find - ODBC fields.
-</p>
-
-<h2 id="microsoft_dot_net">Using H2 in Microsoft .NET</h2>
-<p>
-The database can be used from Microsoft .NET even without using Java, by using IKVM.NET.
-You can access a H2 database on .NET using the JDBC API, or using the ADO.NET interface.
-</p>
-
-<h3>Using the ADO.NET API on .NET</h3>
-<p>
-An implementation of the ADO.NET interface is available in the open source project
-<a href="https://code.google.com/archive/p/h2sharp/">H2Sharp</a>.
-</p>
-
-<h3>Using the JDBC API on .NET</h3>
-<ul><li>Install the .NET Framework from <a href="https://www.microsoft.com">Microsoft</a>.
-    Mono has not yet been tested.
-</li><li>Install <a href="http://www.ikvm.net">IKVM.NET</a>.
-</li><li>Copy the <code>h2*.jar</code> file to <code>ikvm/bin</code>
-</li><li>Run the H2 Console using:
-    <code>ikvm -jar h2*.jar</code>
-</li><li>Convert the H2 Console to an <code>.exe</code> file using:
-    <code>ikvmc -target:winexe h2*.jar</code>.
-    You may ignore the warnings.
-</li><li>Create a <code>.dll</code> file using (change the version accordingly):
-    <code>ikvmc.exe -target:library -version:1.0.69.0 h2*.jar</code>
-</li></ul>
-<p>
-If you want your C# application use H2, you need to add the <code>h2.dll</code> and the
-<code>IKVM.OpenJDK.ClassLibrary.dll</code> to your C# solution. Here some sample code:
-</p>
-<pre>
-using System;
-using java.sql;
-
-class Test
-{
-    static public void Main()
-    {
-        org.h2.Driver.load();
-        Connection conn = DriverManager.getConnection("jdbc:h2:~/test", "sa", "sa");
-        Statement stat = conn.createStatement();
-        ResultSet rs = stat.executeQuery("SELECT 'Hello World'");
-        while (rs.next())
-        {
-            Console.WriteLine(rs.getString(1));
-        }
-    }
-}
-</pre>
-
-<h2 id="acid">ACID</h2>
-<p>
-In the database world, ACID stands for:
-</p>
-<ul>
-<li>Atomicity: transactions must be atomic, meaning either all tasks are performed or none.
-</li><li>Consistency: all operations must comply with the defined constraints.
-</li><li>Isolation: transactions must be isolated from each other.
-</li><li>Durability: committed transaction will not be lost.
-</li></ul>
-
-<h3>Atomicity</h3>
-<p>
-Transactions in this database are always atomic.
-</p>
-
-<h3>Consistency</h3>
-<p>
-By default, this database is always in a consistent state.
-Referential integrity rules are enforced except when
-explicitly disabled.
-</p>
-
-<h3>Isolation</h3>
-<p>
-For H2, as with most other database systems, the default isolation level is 'read committed'.
-This provides better performance, but also means that transactions are not completely isolated.
-H2 supports the transaction isolation levels 'serializable', 'read committed', and 'read uncommitted'.
-</p>
-
-<h3>Durability</h3>
-<p>
-This database does not guarantee that all committed transactions survive a power failure.
-Tests show that all databases sometimes lose transactions on power failure (for details, see below).
-Where losing transactions is not acceptable, a laptop or UPS (uninterruptible power supply) should be used.
-If durability is required for all possible cases of hardware failure, clustering should be used,
-such as the H2 clustering mode.
-</p>
-
-<h2 id="durability_problems">Durability Problems</h2>
-<p>
-Complete durability means all committed transaction survive a power failure.
-Some databases claim they can guarantee durability, but such claims are wrong.
-A durability test was run against H2, HSQLDB, PostgreSQL, and Derby.
-All of those databases sometimes lose committed transactions.
-The test is included in the H2 download, see <code>org.h2.test.poweroff.Test</code>.
-</p>
-
-<h3>Ways to (Not) Achieve Durability</h3>
-<p>
-Making sure that committed transactions are not lost is more complicated than it seems first.
-To guarantee complete durability, a database must ensure that the log record is on the hard drive
-before the commit call returns. To do that, databases use different methods. One
-is to use the 'synchronous write' file access mode. In Java, <code>RandomAccessFile</code>
-supports the modes <code>rws</code> and <code>rwd</code>:
-</p>
-<ul>
-<li><code>rwd</code>: every update to the file's content is written synchronously to the underlying storage device.
-</li><li><code>rws</code>: in addition to <code>rwd</code>, every update to the metadata is written synchronously.</li>
-</ul>
-<p>
-A test (<code>org.h2.test.poweroff.TestWrite</code>) with one of those modes achieves
-around 50 thousand write operations per second.
-Even when the operating system write buffer is disabled, the write rate is around 50 thousand operations per second.
-This feature does not force changes to disk because it does not flush all buffers.
-The test updates the same byte in the file again and again. If the hard drive was able to write at this rate,
-then the disk would need to make at least 50 thousand revolutions per second, or 3 million RPM
-(revolutions per minute). There are no such hard drives. The hard drive used for the test is about 7200 RPM,
-or about 120 revolutions per second. There is an overhead, so the maximum write rate must be lower than that.
-</p>
-<p>
-Calling <code>fsync</code> flushes the buffers. There are two ways to do that in Java:
-</p>
-<ul>
-<li><code>FileDescriptor.sync()</code>. The documentation says that this forces all system
-buffers to synchronize with the underlying device.
-This method is supposed to return after all in-memory modified copies of buffers associated with this file descriptor
-have been written to the physical medium.
-</li><li><code>FileChannel.force()</code>. This method is supposed
-to force any updates to this channel's file to be written to the storage device that contains it.
-</li></ul>
-<p>
-By default, MySQL calls <code>fsync</code> for each commit. When using one of those methods, only around 60 write operations
-per second can be achieved, which is consistent with the RPM rate of the hard drive used.
-Unfortunately, even when calling <code>FileDescriptor.sync()</code> or
-<code>FileChannel.force()</code>,
-data is not always persisted to the hard drive, because most hard drives do not obey
-<code>fsync()</code>: see
-<a href="https://hardware.slashdot.org/story/05/05/13/0529252/your-hard-drive-lies-to-you">Your Hard Drive Lies to You</a>.
-In Mac OS X, <code>fsync</code> does not flush hard drive buffers. See
-<a href="https://lists.apple.com/archives/darwin-dev/2005/Feb/msg00072.html">Bad fsync?</a>.
-So the situation is confusing, and tests prove there is a problem.
-</p>
-<p>
-Trying to flush hard drive buffers is hard, and if you do the performance is very bad.
-First you need to make sure that the hard drive actually flushes all buffers.
-Tests show that this can not be done in a reliable way.
-Then the maximum number of transactions is around 60 per second.
-Because of those reasons, the default behavior of H2 is to delay writing committed transactions.
-</p>
-<p>
-In H2, after a power failure, a bit more than one second of committed transactions may be lost.
-To change the behavior, use <code>SET WRITE_DELAY</code> and
-<code>CHECKPOINT SYNC</code>.
-Most other databases support commit delay as well.
-In the performance comparison, commit delay was used for all databases that support it.
-</p>
-
-<h3>Running the Durability Test</h3>
-<p>
-To test the durability / non-durability of this and other databases, you can use the test application
-in the package <code>org.h2.test.poweroff</code>.
-Two computers with network connection are required to run this test.
-One computer just listens, while the test application is run (and power is cut) on the other computer.
-The computer with the listener application opens a TCP/IP port and listens for an incoming connection.
-The second computer first connects to the listener, and then created the databases and starts inserting
-records. The connection is set to 'autocommit', which means after each inserted record a commit is performed
-automatically. Afterwards, the test computer notifies the listener that this record was inserted successfully.
-The listener computer displays the last inserted record number every 10 seconds. Now, switch off the power
-manually, then restart the computer, and run the application again. You will find out that in most cases,
-none of the databases contains all the records that the listener computer knows about. For details, please
-consult the source code of the listener and test application.
-</p>
-
-<h2 id="using_recover_tool">Using the Recover Tool</h2>
-<p>
-The <code>Recover</code> tool can be used to extract the contents of a database file, even if the database is corrupted.
-It also extracts the content of the transaction log and large objects (CLOB or BLOB).
-To run the tool, type on the command line:
-</p>
-<pre>
-java -cp h2*.jar org.h2.tools.Recover
-</pre>
-<p>
-For each database in the current directory, a text file will be created.
-This file contains raw insert statements (for the data) and data definition (DDL) statements to recreate
-the schema of the database. This file can be executed using the <code>RunScript</code> tool or a
-<code>RUNSCRIPT FROM</code> SQL statement. The script includes at least one
-<code>CREATE USER</code> statement. If you run the script against a database that was created with the same
-user, or if there are conflicting users, running the script will fail. Consider running the script
-against a database that was created with a user name that is not in the script.
-</p>
-<p>
-The <code>Recover</code> tool creates a SQL script from database file. It also processes the transaction log.
-</p>
-<p>
-To verify the database can recover at any time, append <code>;RECOVER_TEST=64</code>
-to the database URL in your test environment. This will simulate an application crash after each 64 writes to the database file.
-A log file named <code>databaseName.h2.db.log</code> is created that lists the operations.
-The recovery is tested using an in-memory file system, that means it may require a larger heap setting.
-</p>
-
-<h2 id="file_locking_protocols">File Locking Protocols</h2>
-<p>
-Multiple concurrent connections to the same database are supported, however a database file
-can only be open for reading and writing (in embedded mode) by one process at the same time.
-Otherwise, the processes would overwrite each others data and corrupt the database file.
-To protect against this problem, whenever a database is opened, a lock file is created
-to signal other processes that the database is in use. If the database is closed, or if the process that opened
-the database stops normally, this lock file is deleted.
-</p><p>
-In special cases (if the process did not terminate normally, for example because
-there was a power failure), the lock file is not deleted by the process that created it.
-That means the existence of the lock file is not a safe protocol for file locking.
-However, this software uses a challenge-response protocol to protect the database
-files. There are two methods (algorithms) implemented to provide both security
-(that is, the same database files cannot be opened by two processes at the same time)
-and simplicity (that is, the lock file does not need to be deleted manually by the user).
-The two methods are 'file method' and 'socket methods'.
-</p>
-<p>
-The file locking protocols (except the file locking method 'FS')
-have the following limitation: if a shared file system is used,
-and the machine with the lock owner is sent to sleep (standby or hibernate),
-another machine may take over. If the machine that originally held the lock
-wakes up, the database may become corrupt. If this situation can occur,
-the application must ensure the database is closed when the application
-is put to sleep.
-</p>
-
-<h3>File Locking Method 'File'</h3>
-<p>
-The default method for database file locking for version 1.3 and older is the 'File Method'.
-The algorithm is:
-</p>
-<ul>
-<li>If the lock file does not exist, it is created (using the atomic operation
-<code>File.createNewFile</code>).
-Then, the process waits a little bit (20 ms) and checks the file again. If the file was changed
-during this time, the operation is aborted. This protects against a race condition
-when one process deletes the lock file just after another one create it, and a third process creates
-the file again. It does not occur if there are only two writers.
-</li><li>
-If the file can be created, a random number is inserted together with the locking method
-('file'). Afterwards, a watchdog thread is started that
-checks regularly (every second once by default) if the file was deleted or modified by
-another (challenger) thread / process. Whenever that occurs, the file is overwritten with the
-old data. The watchdog thread runs with high priority so that a change to the lock file does
-not get through undetected even if the system is very busy. However, the watchdog thread
-does use very little resources (CPU time), because it waits most of the time. Also, the watchdog only reads from the hard disk
-and does not write to it.
-</li><li>
-If the lock file exists and was recently modified, the process waits for some time (up to two seconds).
-If it was still changed, an exception is thrown (database is locked). This is done to eliminate race conditions with many concurrent
-writers. Afterwards, the file is overwritten with a new version (challenge).
-After that, the thread waits for 2 seconds.
-If there is a watchdog thread protecting the file, he will overwrite the change
-and this process will fail to lock the database.
-However, if there is no watchdog thread, the lock file will still be as written by
-this thread. In this case, the file is deleted and atomically created again.
-The watchdog thread is started in this case and the file is locked.
-</li></ul>
-<p>
-This algorithm is tested with over 100 concurrent threads. In some cases, when there are
-many concurrent threads trying to lock the database, they block each other (meaning
-the file cannot be locked by any of them) for some time. However, the file never gets
-locked by two threads at the same time. However using that many concurrent threads
-/ processes is not the common use case. Generally, an application should throw an error
-to the user if it cannot open a database, and not try again in a (fast) loop.
-</p>
-
-<h3>File Locking Method 'Socket'</h3>
-<p>
-There is a second locking mechanism implemented, but disabled by default.
-To use it, append <code>;FILE_LOCK=SOCKET</code> to the database URL.
-The algorithm is:
-</p>
-<ul>
-<li>If the lock file does not exist, it is created.
-Then a server socket is opened on a defined port, and kept open.
-The port and IP address of the process that opened the database is written
-into the lock file.
-</li><li>If the lock file exists, and the lock method is 'file', then the software switches
-to the 'file' method.
-</li><li>If the lock file exists, and the lock method is 'socket', then the process
-checks if the port is in use. If the original process is still running, the port is in use
-and this process throws an exception (database is in use). If the original process
-died (for example due to a power failure, or abnormal termination of the virtual machine),
-then the port was released. The new process deletes the lock file and starts again.
-</li></ul>
-<p>
-This method does not require a watchdog thread actively polling (reading) the same
-file every second. The problem with this method is, if the file is stored on a network
-share, two processes (running on different computers) could still open the same
-database files, if they do not have a direct TCP/IP connection.
-</p>
-
-<h3>File Locking Method 'FS'</h3>
-<p>
-This is the default mode for version 1.4 and newer.
-This database file locking mechanism uses native file system lock on the database file.
-No *.lock.db file is created in this case, and no background thread is started.
-This mechanism may not work on all systems as expected.
-Some systems allow to lock the same file multiple times within the same virtual machine,
-and on some system native file locking is not supported or files are not unlocked after a power failure.
-</p>
-<p>
-To enable this feature, append <code>;FILE_LOCK=FS</code> to the database URL.
-</p>
-<p>
-This feature is relatively new. When using it for production, please ensure
-your system does in fact lock files as expected.
-</p>
-
-<h2 id="passwords">Using Passwords</h2>
-
-<h3>Using Secure Passwords</h3>
-<p>
-Remember that weak passwords can be broken regardless of the encryption and security protocols.
-Don't use passwords that can be found in a dictionary. Appending numbers does not make passwords
-secure. A way to create good passwords that can be remembered is: take the first
-letters of a sentence, use upper and lower case characters, and creatively include special characters
-(but it's more important to use a long password than to use special characters).
-Example:
-</p><p>
-<code>i'sE2rtPiUKtT</code> from the sentence <code>it's easy to remember this password if you know the trick</code>.
-</p>
-
-<h3>Passwords: Using Char Arrays instead of Strings</h3>
-<p>
-Java strings are immutable objects and cannot be safely 'destroyed' by the application.
-After creating a string, it will remain in the main memory of the computer at least
-until it is garbage collected. The garbage collection cannot be controlled by the application,
-and even if it is garbage collected the data may still remain in memory.
-It might also be possible that the part of memory containing the password
-is swapped to disk (if not enough main memory is available), which is
-a problem if the attacker has access to the swap file of the operating system.
-</p><p>
-It is a good idea to use char arrays instead of strings for passwords.
-Char arrays can be cleared (filled with zeros) after use, and therefore the
-password will not be stored in the swap file.
-</p><p>
-This database supports using char arrays instead of string to pass user and file passwords.
-The following code can be used to do that:
-</p>
-<pre>
-import java.sql.*;
-import java.util.*;
-public class Test {
-    public static void main(String[] args) throws Exception {
-        String url = "jdbc:h2:~/test";
-        Properties prop = new Properties();
-        prop.setProperty("user", "sa");
-        System.out.print("Password?");
-        char[] password = System.console().readPassword();
-        prop.put("password", password);
-        Connection conn = null;
-        try {
-            conn = DriverManager.getConnection(url, prop);
-        } finally {
-            Arrays.fill(password, (char) 0);
-        }
-        conn.close();
-    }
-}
-</pre>
-<p>
-When using Swing, use <code>javax.swing.JPasswordField</code>.
-</p>
-
-<h3>Passing the User Name and/or Password in the URL</h3>
-<p>
-Instead of passing the user name as a separate parameter as in
-<code>
-Connection conn = DriverManager.
-    getConnection("jdbc:h2:~/test", "sa", "123");
-</code>
-the user name (and/or password) can be supplied in the URL itself:
-<code>
-Connection conn = DriverManager.
-    getConnection("jdbc:h2:~/test;USER=sa;PASSWORD=123");
-</code>
-The settings in the URL override the settings passed as a separate parameter.
-</p>
-
-<h2 id="password_hash">Password Hash</h2>
-<p>
-Sometimes the database password needs to be stored in a configuration file
-(for example in the <code>web.xml</code> file).
-In addition to connecting with the plain text password,
-this database supports connecting with the password hash.
-This means that only the hash of the password (and not the plain text password)
-needs to be stored in the configuration file.
-This will only protect others from reading or re-constructing the plain text password
-(even if they have access to the configuration file);
-it does not protect others from accessing the database using the password hash.
-</p>
-<p>
-To connect using the password hash instead of plain text password, append
-<code>;PASSWORD_HASH=TRUE</code> to the database URL, and replace
-the password with the password hash. To calculate the password hash from a plain text password,
-run the following command within the H2 Console tool:
-<code>@password_hash &lt;upperCaseUserName&gt; &lt;password&gt;</code>.
-As an example, if the user name is <code>sa</code> and the password is
-<code>test</code>, run the command
-<code>@password_hash SA test</code>.
-Then use the resulting password hash as you would use the plain text password.
-When using an encrypted database, then the user password and file password
-need to be hashed separately. To calculate the hash of the file password, run:
-<code>@password_hash file &lt;filePassword&gt;</code>.
-</p>
-
-<h2 id="sql_injection">Protection against SQL Injection</h2>
-<h3>What is SQL Injection</h3>
-<p>
-This database engine provides a solution for the security vulnerability known as 'SQL Injection'.
-Here is a short description of what SQL injection means.
-Some applications build SQL statements with embedded user input such as:
-</p>
-<pre>
-String sql = "SELECT * FROM USERS WHERE PASSWORD='"+pwd+"'";
-ResultSet rs = conn.createStatement().executeQuery(sql);
-</pre>
-<p>
-If this mechanism is used anywhere in the application, and user input is not correctly filtered or encoded,
-it is possible for a user to inject SQL functionality or statements by using specially built input
-such as (in this example) this password: <code>' OR ''='</code>.
-In this case the statement becomes:
-</p>
-<pre>
-SELECT * FROM USERS WHERE PASSWORD='' OR ''='';
-</pre>
-<p>
-Which is always true no matter what the password stored in the database is.
-For more information about SQL Injection, see <a href="#glossary_links">Glossary and Links</a>.
-</p>
-
-<h3>Disabling Literals</h3>
-<p>
-SQL Injection is not possible if user input is not directly embedded in SQL statements.
-A simple solution for the problem above is to use a prepared statement:
-</p>
-<pre>
-String sql = "SELECT * FROM USERS WHERE PASSWORD=?";
-PreparedStatement prep = conn.prepareStatement(sql);
-prep.setString(1, pwd);
-ResultSet rs = prep.executeQuery();
-</pre>
-<p>
-This database provides a way to enforce usage of parameters when passing user input
-to the database. This is done by disabling embedded literals in SQL statements.
-To do this, execute the statement:
-</p>
-<pre>
-SET ALLOW_LITERALS NONE;
-</pre>
-<p>
-Afterwards, SQL statements with text and number literals are not allowed any more.
-That means, SQL statement of the form <code>WHERE NAME='abc'</code>
-or <code>WHERE CustomerId=10</code> will fail.
-It is still possible to use prepared statements and parameters as described above. Also, it is still possible to generate
-SQL statements dynamically, and use the Statement API, as long as the SQL statements
-do not include literals.
-There is also a second mode where number literals are allowed:
-<code>SET ALLOW_LITERALS NUMBERS</code>.
-To allow all literals, execute <code>SET ALLOW_LITERALS ALL</code>
-(this is the default setting). Literals can only be enabled or disabled by an administrator.
-</p>
-
-<h3>Using Constants</h3>
-<p>
-Disabling literals also means disabling hard-coded 'constant' literals. This database supports
-defining constants using the <code>CREATE CONSTANT</code> command.
-Constants can be defined only
-when literals are enabled, but used even when literals are disabled. To avoid name clashes
-with column names, constants can be defined in other schemas:
-</p>
-<pre>
-CREATE SCHEMA CONST AUTHORIZATION SA;
-CREATE CONSTANT CONST.ACTIVE VALUE 'Active';
-CREATE CONSTANT CONST.INACTIVE VALUE 'Inactive';
-SELECT * FROM USERS WHERE TYPE=CONST.ACTIVE;
-</pre>
-<p>
-Even when literals are enabled, it is better to use constants instead
-of hard-coded number or text literals in queries or views. With constants, typos are found at compile
-time, the source code is easier to understand and change.
-</p>
-
-<h3>Using the ZERO() Function</h3>
-<p>
-It is not required to create a constant for the number 0 as there is already a built-in function <code>ZERO()</code>:
-</p>
-<pre>
-SELECT * FROM USERS WHERE LENGTH(PASSWORD)=ZERO();
-</pre>
-
-<h2 id="remote_access">Protection against Remote Access</h2>
-<p>
-By default this database does not allow connections from other machines when starting the H2 Console,
-the TCP server, or the PG server. Remote access can be enabled using the command line
-options <code>-webAllowOthers, -tcpAllowOthers, -pgAllowOthers</code>.
-</p>
-<p>
-If you enable remote access using
-<code>-tcpAllowOthers</code> or <code>-pgAllowOthers</code>,
-please also consider using the options <code>-baseDir</code>,
-so that remote users can not create new databases
-or access existing databases with weak passwords.
-When using the option <code>-baseDir</code>, only databases within that directory may be accessed.
-Ensure the existing accessible databases are protected using strong passwords.
-</p>
-<p>
-If you enable remote access using <code>-webAllowOthers</code>,
-please ensure the web server can only be accessed from trusted networks.
-The options <code>-baseDir</code> don't protect
-access to the tools section, prevent remote shutdown of the web server,
-changes to the preferences, the saved connection settings,
-or access to other databases accessible from the system.
-</p>
-
-<h2 id="restricting_classes">Restricting Class Loading and Usage</h2>
-<p>
-By default there is no restriction on loading classes and executing Java code for admins.
-That means an admin may call system functions such as
-<code>System.setProperty</code> by executing:
-</p>
-<pre>
-CREATE ALIAS SET_PROPERTY FOR "java.lang.System.setProperty";
-CALL SET_PROPERTY('abc', '1');
-CREATE ALIAS GET_PROPERTY FOR "java.lang.System.getProperty";
-CALL GET_PROPERTY('abc');
-</pre>
-<p>
-To restrict users (including admins) from loading classes and executing code,
-the list of allowed classes can be set in the system property
-<code>h2.allowedClasses</code>
-in the form of a comma separated list of classes or patterns (items ending with <code>*</code>).
-By default all classes are allowed. Example:
-</p>
-<pre>
-java -Dh2.allowedClasses=java.lang.Math,com.acme.*
-</pre>
-<p>
-This mechanism is used for all user classes, including database event listeners,
-trigger classes, user-defined functions, user-defined aggregate functions, and JDBC
-driver classes (with the exception of the H2 driver) when using the H2 Console.
-</p>
-
-<h2 id="security_protocols">Security Protocols</h2>
-<p>
-The following paragraphs document the security protocols used in this database.
-These descriptions are very technical and only intended for security experts that already know
-the underlying security primitives.
-</p>
-
-<h3>User Password Encryption</h3>
-<p>
-When a user tries to connect to a database, the combination of
-user name, @, and password are hashed using SHA-256, and this hash value
-is transmitted to the database.
-This step does not protect against an attacker that re-uses the value if he is able to listen to the
-(unencrypted) transmission between the client and the server.
-But, the passwords are never transmitted as plain text,
-even when using an unencrypted connection between client and server.
-That means if a user reuses the same password for different things,
-this password is still protected up to some point. See also
-'RFC 2617 - HTTP Authentication: Basic and Digest Access Authentication'
-for more information.
-</p><p>
-When a new database or user is created, a new random salt value is generated.
-The size of the salt is 64 bits. Using the random salt reduces the risk of an
-attacker pre-calculating hash values for many different (commonly used) passwords.
-</p><p>
-The combination of user-password hash value (see above) and salt is hashed
-using SHA-256. The resulting value is stored in the database.
-When a user tries to connect to the database, the database combines
-user-password hash value with the stored salt value and calculates the
-hash value. Other products use multiple iterations (hash the hash value again and again),
-but this is not done in this product to reduce the risk of denial of service attacks
-(where the attacker tries to connect with bogus passwords, and the server
-spends a lot of time calculating the hash value for each password).
-The reasoning is: if the attacker has access to the hashed passwords, he also has
-access to the data in plain text, and therefore does not need the password any more.
-If the data is protected by storing it on another computer and only accessible remotely,
-then the iteration count is not required at all.
-</p>
-
-<h3>File Encryption</h3>
-<p>
-The database files can be encrypted using the AES-128 algorithm.
-</p><p>
-When a user tries to connect to an encrypted database, the combination of
-<code>file@</code> and the file password is hashed using SHA-256. This hash value is
-transmitted to the server.
-</p><p>
-When a new database file is created, a new cryptographically secure
-random salt value is generated. The size of the salt is 64 bits.
-The combination of the file password hash and the salt value is hashed 1024 times
-using SHA-256. The reason for the iteration is to make it harder for an attacker to
-calculate hash values for common passwords.
-</p><p>
-The resulting hash value is used as the key for the block cipher algorithm.
-Then, an initialization vector (IV) key
-is calculated by hashing the key again using SHA-256.
-This is to make sure the IV is unknown to the attacker.
-The reason for using a secret IV is to protect against watermark attacks.
-</p><p>
-Before saving a block of data (each block is 8 bytes long), the following operations are executed:
-first, the IV is calculated by encrypting the block number with the IV key (using the same
-block cipher algorithm). This IV is combined with the plain text using XOR. The resulting data is
-encrypted using the AES-128 algorithm.
-</p><p>
-When decrypting, the operation is done in reverse. First, the block is decrypted using the key,
-and then the IV is calculated combined with the decrypted text using XOR.
-</p><p>
-Therefore, the block cipher mode of operation is CBC (cipher-block chaining), but each chain
-is only one block long. The advantage over the ECB (electronic codebook) mode is that patterns
-in the data are not revealed, and the advantage over multi block CBC is that flipped cipher text bits
-are not propagated to flipped plaintext bits in the next block.
-</p><p>
-Database encryption is meant for securing the database while it is not in use (stolen laptop and so on).
-It is not meant for cases where the attacker has access to files while the database is in use.
-When he has write access, he can for example replace pieces of files with pieces of older versions
-and manipulate data like this.
-</p><p>
-File encryption slows down the performance of the database engine. Compared to unencrypted mode,
-database operations take about 2.5 times longer using AES (embedded mode).
-</p>
-
-<h3>Wrong Password / User Name Delay</h3>
-<p>
-To protect against remote brute force password attacks, the delay after each unsuccessful
-login gets double as long. Use the system properties <code>h2.delayWrongPasswordMin</code>
-and <code>h2.delayWrongPasswordMax</code> to change the minimum (the default is 250 milliseconds)
-or maximum delay (the default is 4000 milliseconds, or 4 seconds). The delay only
-applies for those using the wrong password. Normally there is no delay for a user that knows the correct
-password, with one exception: after using the wrong password, there is a delay of up to (randomly distributed)
-the same delay as for a wrong password. This is to protect against parallel brute force attacks,
-so that an attacker needs to wait for the whole delay. Delays are synchronized. This is also required
-to protect against parallel attacks.
-</p>
-<p>
-There is only one exception message for both wrong user and for wrong password,
-to make it harder to get the list of user names. It is not possible from the stack trace to see
-if the user name was wrong or the password.
-</p>
-
-<h3>HTTPS Connections</h3>
-<p>
-The web server supports HTTP and HTTPS connections using <code>SSLServerSocket</code>.
-There is a default self-certified certificate to support an easy starting point, but
-custom certificates are supported as well.
-</p>
-
-<h2 id="tls_connections">TLS Connections</h2>
-<p>
-Remote TLS connections are supported using the Java Secure Socket Extension
-(<code>SSLServerSocket, SSLSocket</code>). By default, anonymous TLS is enabled.
-</p>
-<p>
-To use your own keystore, set the system properties <code>javax.net.ssl.keyStore</code> and
-<code>javax.net.ssl.keyStorePassword</code> before starting the H2 server and client.
-See also <a href="https://docs.oracle.com/javase/7/docs/technotes/guides/security/jsse/JSSERefGuide.html#CustomizingStores">
-Customizing the Default Key and Trust Stores, Store Types, and Store Passwords</a>
-for more information.
-</p>
-<p>
-To disable anonymous TLS, set the system property <code>h2.enableAnonymousTLS</code> to false.
-</p>
-
-<h2 id="uuid">Universally Unique Identifiers (UUID)</h2>
-<p>
-This database supports UUIDs. Also supported is a function to create new UUIDs using
-a cryptographically strong pseudo random number generator.
-With random UUIDs, the chance of two having the same value can be calculated
-using the probability theory. See also 'Birthday Paradox'.
-Standardized randomly generated UUIDs have 122 random bits.
-4 bits are used for the version (Randomly generated UUID), and 2 bits for the variant (Leach-Salz).
-This database supports generating such UUIDs using the built-in function
-<code>RANDOM_UUID()</code> or <code>UUID()</code>.
-Here is a small program to estimate the probability of having two identical UUIDs
-after generating a number of values:
-</p>
-<pre>
-public class Test {
-    public static void main(String[] args) throws Exception {
-        double x = Math.pow(2, 122);
-        for (int i = 35; i &lt; 62; i++) {
-            double n = Math.pow(2, i);
-            double p = 1 - Math.exp(-(n * n) / 2 / x);
-            System.out.println("2^" + i + "=" + (1L &lt;&lt; i) +
-                    " probability: 0" +
-                    String.valueOf(1 + p).substring(1));
-        }
-    }
-}
-</pre>
-<p>
-Some values are:
-</p>
-<table class="main">
-<tr><th>Number of UUIs</th><th>Probability of Duplicates</th></tr>
-<tr><td>2^36=68'719'476'736</td><td>0.000'000'000'000'000'4</td></tr>
-<tr><td>2^41=2'199'023'255'552</td><td>0.000'000'000'000'4</td></tr>
-<tr><td>2^46=70'368'744'177'664</td><td>0.000'000'000'4</td></tr>
-</table>
-<p>
-To help non-mathematicians understand what those numbers mean, here a comparison:
-one's annual risk of being hit by a meteorite is estimated to be one chance in 17 billion,
-that means the probability is about 0.000'000'000'06.
-</p>
-
-<h2 id="spatial_features">Spatial Features</h2>
-<p>
-H2 supports the geometry data type and spatial indexes.
-Here is an example SQL script to create a table with a spatial column and index:
-</p>
-<pre>
-CREATE TABLE GEO_TABLE(GID SERIAL, THE_GEOM GEOMETRY);
-INSERT INTO GEO_TABLE(THE_GEOM) VALUES
-    ('POINT(500 505)'),
-    ('LINESTRING(550 551, 525 512, 565 566)'),
-    ('POLYGON ((550 521, 580 540, 570 564, 512 566, 550 521))');
-CREATE SPATIAL INDEX GEO_TABLE_SPATIAL_INDEX
-    ON GEO_TABLE(THE_GEOM);
-</pre>
-<p>
-To query the table using geometry envelope intersection,
-use the operation <code>&amp;&amp;</code>, as in PostGIS:
-</p>
-<pre>
-SELECT * FROM GEO_TABLE
-    WHERE THE_GEOM &amp;&amp;
-    'POLYGON ((490 490, 536 490, 536 515, 490 515, 490 490))';
-</pre>
-<p>
-You can verify that the spatial index is used using the "explain plan" feature:
-</p>
-<pre>
-EXPLAIN SELECT * FROM GEO_TABLE
-    WHERE THE_GEOM &amp;&amp;
-    'POLYGON ((490 490, 536 490, 536 515, 490 515, 490 490))';
--- Result
-SELECT
-    "GEO_TABLE"."GID",
-    "GEO_TABLE"."THE_GEOM"
-FROM "PUBLIC"."GEO_TABLE"
-    /* PUBLIC.GEO_TABLE_SPATIAL_INDEX:
-    THE_GEOM &amp;&amp;
-    'POLYGON ((490 490, 536 490, 536 515, 490 515, 490 490))'::Geometry */
-WHERE INTERSECTS("THE_GEOM",
-    'POLYGON ((490 490, 536 490, 536 515, 490 515, 490 490))'::Geometry)
-</pre>
-<p>
-For persistent databases, the spatial index is stored on disk;
-for in-memory databases, the index is kept in memory.
-</p>
-
-<h2 id="recursive_queries">Recursive Queries</h2>
-<p>
-H2 has experimental support for recursive queries using so called "common table expressions" (CTE).
-Examples:
-</p>
-<pre>
-WITH RECURSIVE T(N) AS (
-    SELECT 1
-    UNION ALL
-    SELECT N+1 FROM T WHERE N&lt;10
-)
-SELECT * FROM T;
--- returns the values 1 .. 10
-
-WITH RECURSIVE T(N) AS (
-    SELECT 1
-    UNION ALL
-    SELECT N*2 FROM T WHERE N&lt;10
-)
-SELECT * FROM T;
--- returns the values 1, 2, 4, 8, 16
-
-CREATE TABLE FOLDER(ID INT PRIMARY KEY, NAME VARCHAR(255), PARENT INT);
-
-INSERT INTO FOLDER VALUES(1, null, null), (2, 'src', 1),
-(3, 'main', 2), (4, 'org', 3), (5, 'test', 2);
-
-WITH LINK(ID, NAME, LEVEL) AS (
-    SELECT ID, NAME, 0 FROM FOLDER WHERE PARENT IS NULL
-    UNION ALL
-    SELECT FOLDER.ID, IFNULL(LINK.NAME || '/', '') || FOLDER.NAME, LEVEL + 1
-    FROM LINK INNER JOIN FOLDER ON LINK.ID = FOLDER.PARENT
-)
-SELECT NAME FROM LINK WHERE NAME IS NOT NULL ORDER BY ID;
--- src
--- src/main
--- src/main/org
--- src/test
-</pre>
-<p>
-Limitations: Recursive queries need to be of the type <code>UNION ALL</code>,
-and the recursion needs to be on the second part of the query.
-No tables or views with the name of the table expression may exist.
-Different table expression names need to be used when using multiple distinct table
-expressions within the same transaction and for the same session.
-All columns of the table expression are of type <code>VARCHAR</code>,
-and may need to be cast to the required data type.
-Views with recursive queries are not supported.
-Subqueries and <code>INSERT INTO ... FROM</code> with recursive queries are not supported.
-Parameters are only supported within the last <code>SELECT</code> statement
-(a workaround is to use session variables like <code>@start</code>
-within the table expression).
-The syntax is:
-</p>
-<pre>
-WITH RECURSIVE recursiveQueryName(columnName, ...) AS (
-    nonRecursiveSelect
-    UNION ALL
-    recursiveSelect
-)
-select
-</pre>
-
-<h2 id="system_properties">Settings Read from System Properties</h2>
-<p>
-Some settings of the database can be set on the command line using
-<code>-DpropertyName=value</code>. It is usually not required to change those settings manually.
-The settings are case sensitive.
-Example:
-</p>
-<pre>
-java -Dh2.serverCachedObjects=256 org.h2.tools.Server
-</pre>
-<p>
-The current value of the settings can be read in the table
-<code>INFORMATION_SCHEMA.SETTINGS</code>.
-</p>
-<p>
-For a complete list of settings, see
-<a href="http://www.h2database.com/javadoc/org/h2/engine/SysProperties.html">SysProperties</a>.
-</p>
-
-<h2 id="server_bind_address">Setting the Server Bind Address</h2>
-<p>
-Usually server sockets accept connections on any/all local addresses.
-This may be a problem on multi-homed hosts.
-To bind only to one address, use the system property <code>h2.bindAddress</code>.
-This setting is used for both regular server sockets and for TLS server sockets.
-IPv4 and IPv6 address formats are supported.
-</p>
-
-<h2 id="file_system">Pluggable File System</h2>
-<p>
-This database supports a pluggable file system API.
-The file system implementation is selected using a file name prefix.
-Internally, the interfaces are very similar to the Java 7 NIO2 API, but do not (yet) use or require Java 7.
-The following file systems are included:
-</p>
-<ul><li><code>zip:</code>  read-only zip-file based file system. Format: <code>zip:/zipFileName!/fileName</code>.
-</li><li><code>split:</code> file system that splits files in 1 GB files (stackable with other file systems).
-</li><li><code>nio:</code> file system that uses <code>FileChannel</code> instead of <code>RandomAccessFile</code> (faster in some operating systems).
-</li><li><code>nioMapped:</code> file system that uses memory mapped files (faster in some operating systems).
-    Please note that there currently is a file size limitation of 2 GB when using this file system.
-    To work around this limitation, combine it with the split file system: <code>split:nioMapped:test</code>.
-</li><li><code>async:</code> experimental file system that uses <code>AsynchronousFileChannel</code> instead of <code>RandomAccessFile</code> (faster in some operating systems).
-</li><li><code>memFS:</code> in-memory file system (slower than mem; experimental; mainly used for testing the database engine itself).
-</li><li><code>memLZF:</code> compressing in-memory file system (slower than memFS but uses less memory; experimental; mainly used for testing the database engine itself).
-</li><li><code>nioMemFS:</code> stores data outside of the VM's heap - useful for large memory DBs without incurring GC costs.
-</li>
-<li>
-    <code>nioMemLZF:</code> stores compressed data outside of the VM's heap -
-    useful for large memory DBs without incurring GC costs.
-    Use "nioMemLZF:12:" to tweak the % of blocks that are stored uncompressed.
-    If you size this to your working set correctly,
-    compressed storage is roughly the same performance as uncompressed.
-    The default value is 1%.
-</li></ul>
-<p>
-As an example, to use the <code>nio</code> file system with PageStore storage engine,
-use the following database URL: <code>jdbc:h2:nio:~/test;MV_STORE=FALSE</code>.
-With MVStore storage engine nio file system is used by default.
-</p>
-<p>
-To register a new file system, extend the classes <code>org.h2.store.fs.FilePath, FileBase</code>,
-and call the method <code>FilePath.register</code> before using it.
-</p>
-<p>
-For input streams (but not for random access files), URLs may be used in addition to the registered file systems.
-Example: <code>jar:file:///c:/temp/example.zip!/org/example/nested.csv</code>.
-To read a stream from the classpath, use the prefix <code>classpath:</code>, as in
-<code>classpath:/org/h2/samples/newsfeed.sql</code>.
-</p>
-
-<h2 id="file_system_split">Split File System</h2>
-<p>
-The file system prefix <code>split:</code> is used to split logical files into multiple physical files,
-for example so that a database can get larger than the maximum file system size of the operating system.
-If the logical file is larger than the maximum file size, then the file is split as follows:
-</p>
-<ul><li><code>&lt;fileName&gt;</code> (first block, is always created)
-</li><li><code>&lt;fileName&gt;.1.part</code> (second block)
-</li></ul>
-<p>
-More physical files (<code>*.2.part, *.3.part</code>) are automatically created / deleted if needed.
-The maximum physical file size of a block is 2^30 bytes, which is also called 1 GiB or 1 GB.
-However this can be changed if required, by specifying the block size in the file name.
-The file name format is: <code>split:&lt;x&gt;:&lt;fileName&gt;</code> where the file size per block is 2^x.
-For 1 MiB block sizes, use x = 20 (because 2^20 is 1 MiB).
-The following file name means the logical file is split into 1 MiB blocks: <code>split:20:test.h2.db</code>.
-An example database URL for this case is <code>jdbc:h2:split:20:~/test</code>.
-</p>
-
-<h2 id="database_upgrade">Database Upgrade</h2>
-<p>
-In version 1.2, H2 introduced a new file store implementation which is incompatible to the one used in versions &lt; 1.2.
-To automatically convert databases to the new file store, it is necessary to include an additional jar file.
-The file can be found at <a href="http://h2database.com/h2mig_pagestore_addon.jar">http://h2database.com/h2mig_pagestore_addon.jar</a> .
-If this file is in the classpath, every connect to an older database will result in a conversion process.
-</p>
-<p>
-The conversion itself is done internally via <code>'script to'</code> and <code>'runscript from'</code>. After the conversion process, the files will be
-renamed from
-</p>
-<ul>
-<li><code>dbName.data.db</code> to <code>dbName.data.db.backup</code>
-</li><li><code>dbName.index.db</code> to <code>dbName.index.db.backup</code>
-</li></ul>
-<p>
-by default. Also, the temporary script will be written to the database directory instead of a temporary directory.
-Both defaults can be customized via
-</p>
-<ul>
-<li><code>org.h2.upgrade.DbUpgrade.setDeleteOldDb(boolean)</code>
-</li><li><code>org.h2.upgrade.DbUpgrade.setScriptInTmpDir(boolean)</code>
-</li></ul>
-<p>
-prior opening a database connection.
-</p>
-<p>
-Since version 1.2.140 it is possible to let the old h2 classes (v 1.2.128) connect to the database.
-The automatic upgrade .jar file must be present, and the URL must start with <code>jdbc:h2v1_1:</code>
-(the JDBC driver class is <code>org.h2.upgrade.v1_1.Driver</code>).
-If the database should automatically connect using the old version if a database with the old format exists
-(without upgrade), and use the new version otherwise, then append <code>;NO_UPGRADE=TRUE</code>
-to the database URL.
-Please note the old driver did not process the system property <code>"h2.baseDir"</code> correctly,
-so that using this setting is not supported when upgrading.
-</p>
-
-<h2 id="java_objects_serialization">Java Objects Serialization</h2>
-<p>
-Java objects serialization is enabled by default for columns of type <code>OTHER</code>, using standard Java serialization/deserialization semantics.
-</p>
-<p>
-To disable this feature set the system property <code>h2.serializeJavaObject=false</code> (default: true).
-</p>
-<p>
-Serialization and deserialization of java objects is customizable both at system level and at database level providing a
-<a href="http://www.h2database.com/javadoc/org/h2/api/JavaObjectSerializer.html">JavaObjectSerializer</a> implementation:
-</p>
-<ul>
-<li>
-At system level set the system property <code>h2.javaObjectSerializer</code> with the
-Fully Qualified Name of the <code>JavaObjectSerializer</code> interface implementation.
-It will be used over the entire JVM session to (de)serialize java objects being stored in column of type OTHER.
-Example <code>h2.javaObjectSerializer=com.acme.SerializerClassName</code>.
-</li>
-<li>
-At database level execute the SQL statement <code>SET JAVA_OBJECT_SERIALIZER 'com.acme.SerializerClassName'</code>
-or append <code>;JAVA_OBJECT_SERIALIZER='com.acme.SerializerClassName'</code> to the database URL: <code>jdbc:h2:~/test;JAVA_OBJECT_SERIALIZER='com.acme.SerializerClassName'</code>.
-<p>
-Please note that this SQL statement can only be executed before any tables are defined.
-</p>
-</li>
-</ul>
-
-<h2 id="custom_data_types_handler_api">Custom Data Types Handler API</h2>
-<p>
-It is possible to extend the type system of the database by providing your own implementation
-of minimal required API basically consisting of type identification and conversion routines.
-</p>
-<p>
-In order to enable this feature, set the system property <code>h2.customDataTypesHandler</code> (default: null) to the fully qualified name of the class providing
-<a href="http://www.h2database.com/javadoc/org/h2/api/CustomDataTypesHandler.html">CustomDataTypesHandler</a> interface implementation. <br />
-The instance of that class will be created by H2 and used to:
-</p>
-<ul>
-<li>resolve the names and identifiers of extrinsic data types.
-</li>
-<li>convert values of extrinsic data types to and from values of built-in types.
-</li>
-<li>provide order of the data types.
-</li>
-</ul>
-<p>This is a system-level setting, i.e. affects all the databases.</p>
-
-<p><b>Note: </b>Please keep in mind that this feature may not possibly provide the same ABI stability level as other features as it exposes many of the H2 internals. You may be required to update your code occasionally due to internal changes in H2 if you are going to use this feature.
-</p>
-
-
-<h2 id="limits_limitations">Limits and Limitations</h2>
-<p>
-This database has the following known limitations:
-</p>
-<ul>
-<li>Database file size limit:
-    4 TB (using the default page size of 2 KB) or higher (when using a larger page size).
-    This limit is including CLOB and BLOB data.
-</li><li>The maximum file size for FAT or FAT32 file systems is 4 GB.
-    That means when using FAT or FAT32, the limit is 4 GB for the data. This is the limitation of the file system.
-    The database does provide a workaround for this problem, it is to use the file name prefix <code>split:</code>.
-    In that case files are split into files of 1 GB by default.
-    An example database URL is: <code>jdbc:h2:split:~/test</code>.
-</li><li>The maximum number of rows per table is 2^64.
-</li><li>The maximum number of open transactions is 65535.
-</li><li>Main memory requirements: The larger the database, the more main memory is required.
-    With the current storage mechanism (the page store),
-    the minimum main memory required is around 1 MB for each 8 GB database file size.
-</li><li>Limit on the complexity of SQL statements.
-Statements of the following form will result in a stack overflow exception:
-<pre>
-SELECT * FROM DUAL WHERE X = 1
-OR X = 2 OR X = 2 OR X = 2 OR X = 2 OR X = 2
--- repeat previous line 500 times --
-</pre>
-</li><li>There is no limit for the following entities, except the memory and storage capacity:
-    maximum identifier length (table name, column name, and so on);
-    maximum number of tables, columns, indexes, triggers, and other database objects;
-    maximum statement length, number of parameters per statement, tables per statement, expressions
-    in order by, group by, having, and so on;
-    maximum rows per query;
-    maximum columns per table, columns per index, indexes per table, lob columns per table, and so on;
-    maximum row length, index row length, select row length;
-    maximum length of a varchar column, decimal column, literal in a statement.
-</li><li>Querying from the metadata tables is slow if there are many tables (thousands).
-</li><li>For limitations on data types, see the documentation of the respective Java data type
-    or the data type documentation of this database.
-</li></ul>
-
-<h2 id="glossary_links">Glossary and Links</h2>
-<table class="main">
-    <tr>
-        <th>Term</th>
-        <th>Description</th>
-    </tr>
-    <tr>
-        <td>AES-128</td>
-        <td>A block encryption algorithm. See also: <a
-            href="https://en.wikipedia.org/wiki/Advanced_Encryption_Standard">Wikipedia:
-        Advanced Encryption Standard</a></td>
-    </tr>
-    <tr>
-        <td>Birthday Paradox</td>
-        <td>Describes the higher than expected probability that two
-        persons in a room have the same birthday. Also valid for randomly
-        generated UUIDs. See also: <a
-            href="https://en.wikipedia.org/wiki/Birthday_problem">Wikipedia:
-        Birthday problem</a></td>
-    </tr>
-    <tr>
-        <td>Digest</td>
-        <td>Protocol to protect a password (but not to protect data).
-        See also: <a href="https://www.ietf.org/rfc/rfc2617.txt">RFC
-        2617: HTTP Digest Access Authentication</a></td>
-    </tr>
-    <tr>
-        <td>HTTPS</td>
-        <td>A protocol to provide security to HTTP connections. See
-        also: <a href="https://www.ietf.org/rfc/rfc2818.txt">RFC 2818:
-        HTTP Over TLS</a></td>
-    </tr>
-    <tr>
-        <td>Modes of Operation</td>
-        <td><a
-            href="https://en.wikipedia.org/wiki/Block_cipher_mode_of_operation">Wikipedia:
-        Block cipher mode of operation</a></td>
-    </tr>
-    <tr>
-        <td>Salt</td>
-        <td>Random number to increase the security of passwords. See
-        also: <a href="https://en.wikipedia.org/wiki/Key_derivation_function">Wikipedia:
-        Key derivation function</a></td>
-    </tr>
-    <tr>
-        <td>SHA-256</td>
-        <td>A cryptographic one-way hash function. See also: <a
-            href="https://en.wikipedia.org/wiki/Secure_Hash_Algorithms">Wikipedia:
-            Secure Hash Algorithms</a></td>
-    </tr>
-    <tr>
-        <td>SQL Injection</td>
-        <td>A security vulnerability where an application embeds SQL
-        statements or expressions in user input. See also: <a
-            href="https://en.wikipedia.org/wiki/SQL_injection">Wikipedia:
-        SQL injection</a></td>
-    </tr>
-    <tr>
-        <td>Watermark Attack</td>
-        <td>Security problem of certain encryption programs where the
-        existence of certain data can be proven without decrypting. For more
-        information, search in the internet for 'watermark attack
-        cryptoloop'</td>
-    </tr>
-    <tr>
-        <td>SSL/TLS</td>
-        <td>Secure Sockets Layer / Transport Layer Security. See also:
-        <a href="https://docs.oracle.com/javase/7/docs/technotes/guides/security/jsse/JSSERefGuide.html">Java Secure Socket
-        Extension (JSSE)</a></td>
-    </tr>
-</table>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
diff --git a/modules/h2/src/docsrc/html/architecture.html b/modules/h2/src/docsrc/html/architecture.html
deleted file mode 100644
index f9b2946..0000000
--- a/modules/h2/src/docsrc/html/architecture.html
+++ /dev/null
@@ -1,154 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head>
-<meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Architecture
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>Architecture</h1>
-<a href="#introduction">
-    Introduction</a><br />
-<a href="#top_down">
-    Top-down overview</a><br />
-<a href="#jdbc">
-    JDBC driver</a><br />
-<a href="#connection">
-    Connection/session management</a><br />
-<a href="#command">
-    Command execution and planning</a><br />
-<a href="#table">
-    Table/index/constraints</a><br />
-<a href="#transaction">
-    Undo log, redo log, and transactions layer</a><br />
-<a href="#btree">
-    B-tree engine and page-based storage allocation</a><br />
-<a href="#filesystem">
-    Filesystem abstraction</a><br />
-
-<h2 id="introduction">Introduction</h2>
-<p>
-H2 implements an embedded and standalone ANSI-SQL89 compliant SQL engine on top of a B-tree based disk store.
-</p>
-<p>
-As of October 2013, Thomas is still working on our next-generation storage engine called MVStore. This will
-in time replace the B-tree based storage engine.
-</p>
-
-<h2 id="top_down">Top-down Overview</h2>
-<p>
-Working from the top down, the layers look like this:
-<ul><li>JDBC driver.
-</li><li>Connection/session management.
-</li><li>SQL Parser.
-</li><li>Command execution and planning.
-</li><li>Table/Index/Constraints.
-</li><li>Undo log, redo log, and transactions layer.
-</li><li>B-tree engine and page-based storage allocation.
-</li><li>Filesystem abstraction.
-</li></ul>
-</p>
-
-<h2 id="jdbc">JDBC Driver</h2>
-<p>
-The JDBC driver implementation lives in <code>org.h2.jdbc, org.h2.jdbcx</code>
-</p>
-
-<h2 id="connection">Connection/session management</h2>
-<p>
-The primary classes of interest are:
-<table class="main">
-<tr><th>Package</th><th>Description</th></tr>
-<tr><td>org.h2.engine.Database</td><td>the root/global class</td></tr>
-<tr><td>org.h2.engine.SessionInterface</td>
-    <td>abstracts over the differences between embedded and remote sessions</td></tr>
-<tr><td>org.h2.engine.Session</td>
-    <td>local/embedded session</td></tr>
-<tr><td>org.h2.engine.SessionRemote</td>
-    <td>remote session</td></tr>
-</table>
-</p>
-
-<h2 id="jdbc">Parser</h2>
-<p>
-The parser lives in <code>org.h2.command.Parser</code>. It uses a straightforward recursive-descent design.
-</p>
-<p>
-See Wikipedia <a href="https://en.wikipedia.org/wiki/Recursive_descent_parser">Recursive descent parser</a> page.
-</p>
-
-
-<h2 id="command">Command execution and planning</h2>
-<p>
-Unlike other databases, we do not have an intermediate step where we generate some kind of IR (intermediate representation) of the query.
-The parser class directly generates a command execution object.
-Then we run some optimisation steps over the command to possibly generate a more efficient command.
-
-The primary packages of interest are:
-<table class="main">
-<tr><th>Package</th><th>Description</th></tr>
-<tr><td>org.h2.command.ddl</td><td>Commands that modify schema data structures</td></tr>
-<tr><td>org.h2.command.dml</td><td>Commands that modify data</td></tr>
-</table>
-</p>
-
-<h2 id="table">Table/Index/Constraints</h2>
-<p>
-One thing to note here is that indexes are simply stored as special kinds of tables.
-</p>
-<p>
-The primary packages of interest are:
-<table class="main">
-<tr><th>Package</th><th>Description</th></tr>
-<tr><td>org.h2.table</td><td>Implementations of different kinds of tables</td></tr>
-<tr><td>org.h2.index</td><td>Implementations of different kinds of indices</td></tr>
-</table>
-</p>
-
-<h2 id="transaction">Undo log, redo log, and transactions layer</h2>
-<p>
-We have a transaction log, which is shared among all sessions. See also
-<a href="https://en.wikipedia.org/wiki/Transaction_log">https://en.wikipedia.org/wiki/Transaction_log</a>
-<a href="http://h2database.com/html/grammar.html#set_log">http://h2database.com/html/grammar.html#set_log</a>
-</p>
-<p>
-We also have an undo log, which is per session, to undo an operation (an update that fails for example)
-and to rollback a transaction.
-Theoretically, the transaction log could be used, but for simplicity, H2 currently uses it's
-own "list of operations" (usually in-memory).
-</p>
-<p>
-With the MVStore, this is no longer needed (just the transaction log).
-</p>
-
-<h2 id="btree">B-tree engine and page-based storage allocation.</h2>
-<p>
-The primary package of interest is <code>org.h2.store</code>.
-</p>
-<p>
-This implements a storage mechanism which allocates pages of storage (typically 2k in size)
-and also implements a b-tree over those pages to allow fast retrieval and update.
-</p>
-
-<h2 id="filesystem">Filesystem abstraction.</h2>
-<p>
-The primary class of interest is <code>org.h2.store.FileStore</code>.
-</p>
-<p>
-This implements an abstraction of a random-access file.
-This allows the higher layers to treat in-memory vs. on-disk vs. zip-file databases the same.
-</p>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
diff --git a/modules/h2/src/docsrc/html/build.html b/modules/h2/src/docsrc/html/build.html
deleted file mode 100644
index c516e77..0000000
--- a/modules/h2/src/docsrc/html/build.html
+++ /dev/null
@@ -1,325 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head>
-<meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Build
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1 id="build_index">Build</h1>
-<a href="#portability">
-    Portability</a><br />
-<a href="#environment">
-    Environment</a><br />
-<a href="#building">
-    Building the Software</a><br />
-<a href="#build_targets">
-    Build Targets</a><br />
-<a href="#maven2">
-    Using Maven 2</a><br />
-<a href="#using_eclipse">
-    Using Eclipse</a><br />
-<a href="#translating">
-    Translating</a><br />
-<a href="#providing_patches">
-    Submitting Source Code Changes</a><br />
-<a href="#support">
-    Reporting Problems or Requests</a><br />
-<a href="#automated">
-    Automated Build</a><br />
-<a href="#railroad">
-    Generating Railroad Diagrams</a><br />
-
-<h2 id="portability">Portability</h2>
-<p>
-This database is written in Java and therefore works on many platforms.
-</p>
-
-<h2 id="environment">Environment</h2>
-<p>
-To run this database, a Java Runtime Environment (JRE) version 7 or higher is required.
-</p>
-<p>
-To create the database executables, the following software stack was used.
-To use this database, it is not required to install this software however.
-</p>
-<ul><li>Mac OS X and Windows
-</li><li><a href="http://www.oracle.com/technetwork/java/javase/downloads/index.html">Oracle JDK Version 7</a>
-(version 7 is not available for free download any more)
-</li><li><a href="http://www.eclipse.org">Eclipse</a>
-</li><li>Eclipse Plugins:
-    <a href="http://subclipse.tigris.org">Subclipse</a>,
-    <a href="https://checkstyle.github.io/eclipse-cs/">Eclipse Checkstyle Plug-in</a>,
-    <a href="http://www.eclemma.org">EclEmma Java Code Coverage</a>
-</li><li><a href="https://www.mozilla.com/firefox">Mozilla Firefox</a>
-</li><li><a href="http://www.openoffice.org">OpenOffice</a>
-</li><li><a href="http://nsis.sourceforge.net">NSIS</a> (Nullsoft Scriptable Install System)
-</li><li><a href="http://maven.apache.org">Maven</a>
-</li></ul>
-
-<h2 id="building">Building the Software</h2>
-<p>
-You need to install a JDK, for example the Oracle JDK version 7 or 8.
-Ensure that Java binary directory is included in the <code>PATH</code> environment variable, and that
-the environment variable <code>JAVA_HOME</code> points to your Java installation.
-On the command line, go to the directory <code>h2</code> and execute the following command:
-</p>
-<pre>
-build -?
-</pre>
-<p>
-For Linux and OS X, use <code>./build.sh</code> instead of <code>build</code>.
-</p>
-<p>
-You will get a list of targets. If you want to build the <code>jar</code> file, execute (Windows):
-</p>
-<pre>
-build jar
-</pre>
-<p>
-To run the build tool in shell mode, use the command line option <code>-</code>:
-</p>
-<pre>
-./build.sh -
-</pre>
-
-<h2 id="build_targets">Build Targets</h2>
-<p>
-The build system can generate smaller jar files as well. The following targets are currently supported:
-</p>
-<ul><li><code>jarClient</code>
-    creates the file <code>h2client.jar</code>. This only contains the JDBC client.
-</li><li><code>jarSmall</code>
-    creates the file <code>h2small.jar</code>.
-    This only contains the embedded database. Debug information is disabled.
-</li><li><code>javadocImpl</code> creates the Javadocs of the implementation.
-</li></ul>
-<p>
-To create the file <code>h2client.jar</code>, go to the directory <code>h2</code> and execute the following command:
-</p>
-<pre>
-build jarClient
-</pre>
-
-<h3>Using Apache Lucene</h3>
-<p>
-Apache Lucene 5.5.5 is used for testing.
-Newer versions up to 7.7.1 can also be used.
-</p>
-
-<h2 id="maven2">Using Maven 2</h2>
-<h3>Using a Central Repository</h3>
-<p>
-You can include the database in your Maven 2 project as a dependency.
-Example:
-</p>
-<pre>
-&lt;dependency&gt;
-    &lt;groupId&gt;com.h2database&lt;/groupId&gt;
-    &lt;artifactId&gt;h2&lt;/artifactId&gt;
-    &lt;version&gt;${version}&lt;/version&gt;
-&lt;/dependency&gt;
-</pre>
-<p>
-New versions of this database are first uploaded to http://hsql.sourceforge.net/m2-repo/ and then automatically
-synchronized with the main <a href="http://repo2.maven.org/maven2/com/h2database/h2/">Maven repository</a>;
-however after a new release it may take a few hours before they are available there.
-</p>
-<h3>Maven Plugin to Start and Stop the TCP Server</h3>
-<p>
-A Maven plugin to start and stop the H2 TCP server is available from
-<a href="https://github.com/ljnelson/h2-maven-plugin">Laird Nelson at GitHub</a>.
-To start the H2 server, use:
-</p>
-<pre>
-mvn com.edugility.h2-maven-plugin:1.0-SNAPSHOT:spawn
-</pre>
-<p>
-To stop the H2 server, use:
-</p>
-<pre>
-mvn com.edugility.h2-maven-plugin:1.0-SNAPSHOT:stop
-</pre>
-
-<h3>Using Snapshot Version</h3>
-<p>
-To build a <code>h2-*-SNAPSHOT.jar</code> file and upload it the to the local Maven 2 repository, execute the following command:
-</p>
-<pre>
-build mavenInstallLocal
-</pre>
-<p>
-Afterwards, you can include the database in your Maven 2 project as a dependency:
-</p>
-<pre>
-&lt;dependency&gt;
-    &lt;groupId&gt;com.h2database&lt;/groupId&gt;
-    &lt;artifactId&gt;h2&lt;/artifactId&gt;
-    &lt;version&gt;1.0-SNAPSHOT&lt;/version&gt;
-&lt;/dependency&gt;
-</pre>
-
-<h2 id="using_eclipse">Using Eclipse</h2>
-<p>
-To create an Eclipse project for H2, use the following steps:
-</p>
-<ul><li>Install Git and <a href="http://www.eclipse.org">Eclipse</a>.
-</li><li>Get the H2 source code from Github:<br />
-    <code>git clone https://github.com/h2database/h2database</code>
-</li><li>Download all dependencies:<br />
-    <code>build.bat download</code>(Windows)<br />
-    <code>./build.sh download</code>(otherwise)<br />
-</li><li>In Eclipse, create a new Java project from existing source code:
-    <code>File, New, Project, Java Project, Create project from existing source</code>.
-</li><li>Select the <code>h2</code> folder, click <code>Next</code> and <code>Finish</code>.
-</li><li>To resolve <code>com.sun.javadoc</code> import statements,
-    you may need to manually add the file <code>&lt;java.home&gt;/../lib/tools.jar</code> to the build path.
-</li></ul>
-
-<h2 id="translating">Translating</h2>
-<p>
-The translation of this software is split into the following parts:
-</p>
-<ul>
-<li>H2 Console: <code>src/main/org/h2/server/web/res/_text_*.prop</code>
-</li><li>Error messages: <code>src/main/org/h2/res/_messages_*.prop</code>
-</li></ul>
-<p>
-To translate the H2 Console, start it and select Preferences / Translate.
-After you are done, send the translated <code>*.prop</code> file to the Google Group.
-The web site is currently translated using Google.
-</p>
-
-<h2 id="providing_patches">Submitting Source Code Changes</h2>
-<p>
-If you'd like to contribute bug fixes or new features, please consider the following guidelines to simplify merging them:
-</p>
-<ul><li>Only use Java 7 features (do not use Java 8/9/etc) (see <a href="#environment">Environment</a>).
-</li><li>Follow the coding style used in the project, and use Checkstyle (see above) to verify.
-    For example, do not use tabs (use spaces instead).
-    The checkstyle configuration is in <code>src/installer/checkstyle.xml</code>.
-</li><li>A template of the Eclipse settings are in
-    <code>src/installer/eclipse.settings/*</code>. If you want to use them,
-    you need to copy them to the <code>.settings</code> directory.
-    The formatting options (<code>eclipseCodeStyle</code>) are also included.
-</li><li>Please provide test cases and integrate them into the test suite.
-    For Java level tests, see <code>src/test/org/h2/test/TestAll.java</code>.
-    For SQL level tests, see SQL files in <code>src/test/org/h2/test/scripts</code>.
-</li><li>The test cases should cover at least 90% of the changed and new code;
-    use a code coverage tool to verify that (see above).
-    or use the build target <code>coverage</code>.
-</li><li>Verify that you did not break other features: run the test cases by executing
-    <code>build test</code>.
-</li><li>Provide end user documentation if required (<code>src/docsrc/html/*</code>).
-</li><li>Document grammar changes in <code>src/docsrc/help/help.csv</code>
-</li><li>Provide a change log entry (<code>src/docsrc/html/changelog.html</code>).
-</li><li>Verify the spelling using <code>build spellcheck</code>. If required
-    add the new words to <code>src/tools/org/h2/build/doc/dictionary.txt</code>.
-</li><li>Run <code>src/installer/buildRelease</code> to find and fix formatting errors.
-</li><li>Verify the formatting using <code>build docs</code> and
-    <code>build javadoc</code>.
-</li><li>Submit changes using GitHub's "pull requests". You'll require a free <a href="https://github.com/">GitHub</a>
-    account. If you are not familiar with pull requests, please read GitHub's
-    <a href="https://help.github.com/articles/using-pull-requests/">Using pull requests</a> page.
-</li></ul>
-<p>
-For legal reasons, patches need to be public in the form of an
-    <a href="https://github.com/h2database/h2database/issues">issue report or attachment</a> or in the form of an email
-    to the <a href="https://groups.google.com/group/h2-database">group</a>.
-Significant contributions need to include the following statement:
-</p>
-<p>
-"I wrote the code, it's mine, and I'm contributing it to H2 for distribution
-multiple-licensed under the MPL 2.0, and the EPL 1.0
-(http://h2database.com/html/license.html)."
-</p>
-
-<h2 id="support">Reporting Problems or Requests</h2>
-<p>
-Please consider the following checklist if you have a question, want to report a problem,
-or if  you have a feature request:
-</p>
-<ul><li>For bug reports, please provide a
-    <a href="http://sscce.org/">short, self contained, correct (compilable), example</a> of the problem.
-</li><li>Feature requests are always welcome, even if the feature is already on the
-    <a href="http://www.h2database.com/html/roadmap.html">roadmap</a>. Your mail will help prioritize feature requests.
-    If you urgently need a feature, consider <a href="#providing_patches">providing a patch</a>.
-</li><li>Before posting problems, check the
-    <a href="faq.html">FAQ</a> and do a <a href="http://google.com">Google search</a>.
-</li><li>When got an unexpected exception, please try the
-    <a href="http://www.h2database.com/html/sourceError.html">Error Analyzer tool</a>. If this doesn't help,
-    please report the problem, including the complete error message and stack trace,
-    and the root cause stack trace(s).
-</li><li>When sending source code, please use a public web clipboard such as
-    <a href="https://pastebin.com/">Pastebin</a> or
-    <a href="http://www.mysticpaste.com/new">Mystic Paste</a>
-    to avoid formatting problems.
-    Please keep test cases as simple and short as possible,
-    but so that the problem can still be reproduced.
-    As a template, use:
-    <a href="https://github.com/h2database/h2database/tree/master/h2/src/test/org/h2/samples/HelloWorld.java">HelloWorld.java</a>.
-    Method that simply call other methods should be avoided,
-    as well as unnecessary exception handling.
-    Please use the JDBC API and no external tools or libraries.
-    The test should include all required initialization code, and
-    should be started with the main method.
-</li><li>For large attachments, use a public storage such as
-    <a href="https://www.google.com/drive/">Google Drive</a>.
-</li><li>Google Group versus issue tracking:
-    Use the
-    <a href="http://groups.google.com/group/h2-database">Google Group</a>
-    for questions or if you are not sure it's a bug.
-    If you are sure it's a bug, you can create an
-    <a href="https://github.com/h2database/h2database/issues">issue</a>,
-    but you don't need to (sending an email to the group is enough).
-    Please note that only few people monitor the issue tracking system.
-</li><li>For out-of-memory problems, please analyze the problem yourself first,
-    for example using the command line option
-    <code>-XX:+HeapDumpOnOutOfMemoryError</code>
-    (to create a heap dump file on out of memory)
-    and a memory analysis tool such as the
-    <a href="http://www.eclipse.org/mat">Eclipse Memory Analyzer (MAT)</a>.
-</li><li>It may take a few days to get an answers. Please do not double post.
-</li></ul>
-
-<h2 id="automated">Automated Build</h2>
-<p>
-This build process is automated and runs regularly.
-The build process includes running the tests and code coverage, using the command line
-<code>./build.sh clean jar coverage -Dh2.ftpPassword=... uploadBuild</code>.
-The last results are available here:
-</p>
-<ul><li><a href="http://h2database.com/html/testOutput.html">Test Output</a>
-</li><li><a href="http://h2database.com/coverage/overview.html">Code Coverage Summary</a>
-</li><li><a href="http://h2database.com/coverage/coverage.zip">Code Coverage Details (download, 1.3 MB)</a>
-</li><li><a href="http://www.h2database.com/automated/news.xml">Build Newsfeed</a>
-</li></ul>
-
-<h2 id="railroad">Generating Railroad Diagrams</h2>
-<p>
-The railroad diagrams of the <a href="grammar.html">SQL grammar</a> are HTML, formatted as nested tables.
-The diagrams are generated as follows:
-</p>
-<ul><li>The BNF parser (<code>org.h2.bnf.Bnf</code>) reads and parses the BNF from the file <code>help.csv</code>.
-</li><li>The page parser (<code>org.h2.server.web.PageParser</code>) reads the template HTML file and fills in the diagrams.
-</li><li>The rail images (one straight, four junctions, two turns) are generated using a simple Java application.
-</li></ul>
-<p>
-To generate railroad diagrams for other grammars, see the package <code>org.h2.jcr</code>.
-This package is used to generate the SQL-2 railroad diagrams for the JCR 2.0 specification.
-</p>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
-
diff --git a/modules/h2/src/docsrc/html/changelog.html b/modules/h2/src/docsrc/html/changelog.html
deleted file mode 100644
index 6a36a27..0000000
--- a/modules/h2/src/docsrc/html/changelog.html
+++ /dev/null
@@ -1,1487 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Change Log
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>Change Log</h1>
-
-<h2>Next Version (unreleased)</h2>
-<ul>
-<li>-
-</li>
-</ul>
-
-<h2>Version 1.4.199 (2019-03-13)</h2>
-<ul>
-<li>PR #1807: Reduce code duplication and remove h2.mixedGeometries
-</li>
-<li>PR #1806: Improve SELECT FOR UPDATE documentation
-</li>
-<li>PR #1804: Lift limit of 10 characters on enum value (1.4.198 regression)
-</li>
-<li>PR #1803: Do not rely on index sorting in SELECT FOR UPDATE
-</li>
-<li>Issue #1800: Remove experimental status from window functions
-</li>
-<li>PR #1799: Fire triggers after row locking and remove some leftovers
-</li>
-<li>PR #1798: Reuse some string builders, remove StatementBuilder and other minor changes
-</li>
-<li>Issue #1795: 1.4.198 regression with batch updates and transactions
-</li>
-<li>PR #1794: Ask password in Shell in secure way and improve database creation information in tutorial
-</li>
-<li>PR #1791: Move commands to commands.html and other changes
-</li>
-<li>Issue #1774: H2 Browser configuration is unclear and fails on KUbuntu
-</li>
-<li>PR #1790: Do not convert standard TRIM function to non-standard functions
-</li>
-<li>Issue #1787: Non-standard MERGE throws LOCK_TIMEOUT_1 on violation of some constraints
-</li>
-<li>PR #1784: improve database not found error
-</li>
-<li>Issue #1740: Enhancement Request: h2 server: do not swallow exceptions
-</li>
-<li>Issue #1616: Metadata and scripts should be persisted with unconditionally quoted identifiers
-</li>
-<li>PR #1779: Improve isSimpleIdentifier() and enquoteIdentifier()
-</li>
-<li> PR #1776: Improve DATABASE_TO_LOWER handling
-</li>
-<li>Issue #1771: NPE in Comparison.createIndexConditions
-</li>
-<li>PR #1772: Fix newlines in test scripts
-</li>
-<li>Issue #1762: NullPointerException in Parser. Introduced in 1.4.198
-</li>
-<li>PR #1768: Add more context-sensitive keywords
-</li>
-<li>Issue #1758: sequence restart issue with 1.4.198
-</li>
-<li>Issue #1759: SELECT &#8230; FOR UPDATE returns old data in 1.4.198
-</li>
-<li>PR #1756: Fix DISTINCT ON in presence of ORDER BY
-</li>
-<li>PR #1754: Fix window functions in JOIN with ON condition
-</li>
-<li>Issue #1751: making it easier to open console and create local databases
-</li>
-<li>Issue #1750: JOIN t ON t.col IN (SELECT ...) throws AssertionError
-</li>
-</ul>
-
-<h2>Version 1.4.198 (2019-02-22)</h2>
-<ul>
-<li>Issue #1746: Infinite loop in TestConcurrent.testConcurrentChangeAndGetVersion()
-</li>
-<li>Issue #1739: Table and view names not case sensitive when using DATABASE_TO_UPPER=FALSE
-</li>
-<li>Issue #848: H2 PostgreSQL Compatibility Mode: lowercase metadata
-</li>
-<li>Issue #485: Problem is in invalid case for schema's IGNORECASE=true;DATABASE_TO_UPPER=false
-</li>
-<li>Issue #1742, PR #1743: Assorted small changes
-</li>
-<li>PR #1738: Reduce memory allocation in getSQL() methods
-</li>
-<li>PR #1737: more javadoc updates
-</li>
-<li>Issue #1735: Creating views with DATABASE_TO_UPPER=FALSE fails
-</li>
-<li>Issue #1732: source.html does not work
-</li>
-<li>Issue #1730: Show error in H2 Console if specified driver is not compatible with URL
-</li>
-<li>Issue #1590: Error on executing "DELETE FROM table1 WHERE ID = ?; DELETE FROM table2 WHERE ID = ?;"
-</li>
-<li>Issue #1727: Support ISODOW as identifier for the extract function additional to ISO_DAY_OF_WEEK
-</li>
-<li>PR #1580, #1726: Disable remote database creation by default
-</li>
-<li>PR #1725: Add partial implementation of standard LISTAGG aggregate function
-</li>
-<li>PR #1722: Fix window definition lookup in some queries
-</li>
-<li>PR #1721: Fix derived column list in complex queries
-</li>
-<li>Issue #1718: Window function and values clause don't work well together
-</li>
-<li>Issue #1592: Index out of bounds exception in Page.getKey()
-</li>
-<li>PR #1716: Improve documentation of some DML commands
-</li>
-<li>Issue #1715: Postgres mode: Domain "regproc" already exists
-</li>
-<li>PR #1714: Assorted changes
-</li>
-<li>PR #1713: Remove DataType.defaultDisplaySize and fix display size in TypeInfo
-</li>
-<li>PR #1711: Add QUALIFY clause to SELECT command
-</li>
-<li>Issue #1708: CREATE TABLE AS doesn't support column lists without data types
-</li>
-<li>PR #1707: Fix sort order and ENUM data type in external results
-</li>
-<li>PR #1706: Add hypothetical set functions
-</li>
-<li>PR #1705: Fix GROUP_CONCAT with variable separator
-</li>
-<li>PR #1704: Fix return type of PERCENTILE_CONT and MEDIAN
-</li>
-<li>PR #1701: Add PERCENTILE_CONT and PERCENTILE_DISC inverse distribution functions
-</li>
-<li>Issues #1297, #1697: Failure on concurrent session closure
-</li>
-<li>Issue #1297: removeOldTempIndexes on PageStore causes NullPointerException
-</li>
-<li>Issue #1354: TestCrashAPI: another NPE
-</li>
-<li>PR #1695: Reduce memory for TestMVTempResult to 64m
-</li>
-<li>Issue #1691: Append mode causes OOME in MVPlainTempResult
-</li>
-<li>PR #1692: Use MVTempResult unconditionally
-</li>
-<li>Issue #1689: Use separate constants for data types in Data, ValueDataType, and Transfer
-</li>
-<li>PR #1687: MVMap minor cleanup
-</li>
-<li>PR #1686: Fix a regression with ENUM data type
-</li>
-<li>PR #1685: Fix CHAR in PostgreSQL mode and refactor some code
-</li>
-<li>Issue #1681: IN () doesn't work with row values when data types are not exactly the same
-</li>
-<li>Issue #1320: OOME / GC overhead in IndexCursor.nextCursor()
-</li>
-<li>PR #1680: Assorted fixes for ALTER TABLE ALTER COLUMN
-</li>
-<li>PR #1679: Use TestScript for testSimple
-</li>
-<li>Issue #1677: Unable to use VALUES keyword in WHERE clause
-</li>
-<li>Issue #1672: Deadlock on MVStore close in TestOutOfMemory
-</li>
-<li>Issue #1665: TestCrashAPI: NPE with ENUM in MINUS operator
-</li>
-<li>Issue #1602: Combine type, precision, scale, display size and extTypeInfo into one object
-</li>
-<li>PR #1671: Assorted changes
-</li>
-<li>Issue #1668: MySQL compatibility DATE() function should return NULL on error
-</li>
-<li>Issue #1604: TestCrashAPI: PreparedStatement.getGeneratedKeys() is already closed
-</li>
-<li>PR #1667: Detect NULL values and overflow in window frame bounds
-</li>
-<li>PR #1664: Allow any expressions in window frames
-</li>
-<li>Issue #1576: H2 Console should not display precision and scale for data types that don't have them
-</li>
-<li>PR #1662: Fix Alter Table Drop Column In View when table name is wrapped by Double Quotes
-</li>
-<li>PR #1660: Optimize window aggregates with AND UNBOUNDED FOLLOWING and no exclusions
-</li>
-<li>PR #1658: Assorted small changes
-</li>
-<li>PR #1657: Failure to stop background thread
-</li>
-<li>PR #1656: Optimize window aggregates with ORDER BY + UNBOUNDED PRECEDING + no exclusions
-</li>
-<li>Issue #1654: OOM in TestMemoryUsage, in big mode
-</li>
-<li>Issue #1651: TIMESTAMP values near DST may be changed in MVStore database due to UTC-based PageStore format in some
-temporary storages
-</li>
-<li>PR #1650: Fix race in MVStore.close()
-</li>
-<li>Issue #1212: TestDiskFull: The file is locked
-</li>
-<li>PR #1648: Add functions ARRAY_CAT(), ARRAY_APPEND() and ARRAY_SLICE()
-</li>
-<li>PR #1646: In preparation to a release
-</li>
-<li>PR #1643: more javadoc update
-</li>
-<li>PR #1642: update javadoc
-</li>
-<li>PR #1641: Update copyright years
-</li>
-<li>PR #1640: Suggest ANY(?) instead of variable IN() again
-</li>
-<li>PR #1638: Add support for Java 11 to test suite
-</li>
-<li>PR #1637: Remove explicit unboxing
-</li>
-<li>PR #1635: Optimize UUID to VARCHAR conversion and use correct time check in Engine.openSession()
-</li>
-<li>Issue #1632: TestMVTableEngine failure
-</li>
-<li>PR #1631: Prepare to release: javadoc cleanup
-</li>
-<li>PR #1630: fix duplicate words typos in comments and javadoc
-</li>
-<li>PR #1627: Use lock to protect append buffer
-</li>
-<li>Issue #1618: GROUP BY does not work with two identical columns in selected expressions
-</li>
-<li>Issue #1619: Two-phase commit regression in MASTER
-</li>
-<li>PR #1626: fix doc
-</li>
-<li>PR #1625: Prepare to release: javadoc cleanup, fix maven build, fix javadoc build
-</li>
-<li>Issue #1620: UUIDs are unexpectedly sorted as signed
-</li>
-<li>PR #1614: Use bulk .addAll() operation
-</li>
-<li>PR #1613: Add explicit table query
-</li>
-<li>Issue #1608: ARRAY and row value expression should not be the same
-</li>
-<li>Issue #1606: Quantified comparison predicate doesn't work correctly on primary key column
-</li>
-<li>Issue #1057: Very slow execution with subquery and connection parameter LAZY_QUERY_EXECUTION=1
-</li>
-<li>Issue #1072: Very slow execution with join and connection parameter LAZY_QUERY_EXECUTION=1
-</li>
-<li>PR #1601: Return BIGINT from ROWNUM(), ROW_NUMBER() and rank functions
-</li>
-<li>PR #1599: cleanup StringUtils.cache
-</li>
-<li>PR #1598: Minor changes in parser and documentation
-</li>
-<li>PR #1597: Remove SysProperties.CHECK preconditions around simple assertions
-</li>
-<li>PR #1596: Improve SQL Standard compliance in LOB precision parsing
-</li>
-<li>Issue #1594: DBSettings.optimizeIsNull and dead code in IndexCursor.getMax()
-</li>
-<li>PR #1591: Use multi-catch java 7 language construction to simplify code
-</li>
-<li>Issue #1582: h2 not using best index for &gt;=
-</li>
-<li>PR #1588: Add support for java.time.Period
-</li>
-<li>Issue #446: FILE_READ from classpath not working because of 0 byte file length
-</li>
-<li>PR #1579: fix unintentional append mode disruption
-</li>
-<li>Issue #1573: DELETE FROM w/ ROWNUM and subquery
-</li>
-<li>Issue #187: SHUTDOWN DEFRAG corrupts splitted file database
-</li>
-<li>PR #1571: Optimizing ConditionAndOr queries
-</li>
-<li>Issue #1565: SOME / ANY conflict
-</li>
-<li>PR #1564: Refactor Expression implementations
-</li>
-<li>Issue #1561: Incorrect documentation and strange fallback value of SysProperties.FILE_ENCODING
-</li>
-<li>Issue #1566: MVStore implements Closeable/AutoCloseable
-</li>
-<li>Issue #1550: OutOfMemoryError during "shutdown defrag"
-</li>
-<li>Issue #1440: OOM when executing "shutdown compact" in server mode
-</li>
-<li>Issue #1561: Incorrect documentation and strange fallback value of SysProperties.FILE_ENCODING
-</li>
-<li>PR #1557: increase lock timeout to TestConcurrentUpdate due to Travis failures
-</li>
-<li>Issue #1554: REGEXP_REPLACE - accept 'g' flag in PostgreSQL compatibility mode
-</li>
-<li>Issue #950: Comparison between databases in README.md and in features.html
-</li>
-<li>Issue #1549: [RFE] Implement locking modes (select for update)
-</li>
-<li>PR #1548: Add AsynchronousFileChannel-based experimental FilePathAsync
-</li>
-<li>PR #1547: Speedup unused chunks collection
-</li>
-<li>PR #1546: Tiny optimization: use `System.arraycopy` when possible
-</li>
-<li>PR #1545: Export datetime value functions to SQL using standard syntax
-</li>
-<li>Issue #1371: NPE in CacheLRU
-</li>
-<li>Issue #1534: Typo in message
-</li>
-<li>Issue #1527: Parser performance: Excessive use of regular expressions to validate column names
-</li>
-<li>PR #1543: MVStore assorted re-factorings
-</li>
-<li>PR #1538: Add support for newer Lucene versions without recompilation
-</li>
-<li>Issue #1536: CURRENT_TIMESTAMP result doesn't change under Transactions
-</li>
-<li>Issue #239: Consider supporting Lucene 5 indexes
-</li>
-<li>PR #1520: Fixes bug in PutIfAbsentDecisionMaker
-</li>
-<li>Issue #1518: ENUM and VIEW with filtering on enum column
-</li>
-<li>Issue #1516: Array element reference array[index] should be 1-based
-</li>
-<li>Issue #1512: TestMVTableEngine.testLowRetentionTime(): NPE in VersionedValue.Type
-</li>
-<li>PR #1513: Assorted minor changes
-</li>
-<li>PR #1510: Add optional EXCEPT clause to wildcards
-</li>
-<li>PR #1509: Use domain term everywhere
-</li>
-<li>Issue #1507: Add INFORMATION_SCHEMA.COLUMNS.COLUMN_TYPE qualification for domains
-</li>
-<li>Issue #1499: TestScript::envelope.sql failure in &#8220;big&#8221; mode
-</li>
-<li>Issue #1498: NPE in SimpleResultSet.getColumnCount()
-</li>
-<li>Issue #1495: MERGE statement doesn't affect any rows when Oracle UPDATE .. WHERE .. DELETE .. WHERE is used
-</li>
-<li>Issue #1493: MERGE statement fails when it updates more than one row
-</li>
-<li>Issue #1492: Unnecessary restriction on MERGE USING statement when ON clause doesn't reference any target table columns
-</li>
-<li>Issue #1491: Unnecessary restriction on MERGE USING statement when ON predicate doesn't match inserted row
-</li>
-<li>Issue #1490: NullPointerException when running invalid MERGE statement
-</li>
-<li>Issue #1489: MERGE USING documentation has misleading railroad diagram
-</li>
-<li>Issue #1488: Improve documentation of window and some other functions
-</li>
-<li>Issue #1485: Default window frame in presence of ORDER BY is RANGE .., not ROWS
-</li>
-<li>PR #1484: New tests, reimplemented EXCLUDE clause, and assorted changes
-</li>
-<li>Issue #1338: MSSQLServer compatibility enhancements
-</li>
-<li>PR #1480: Update Maven build instruction and fix some problems
-</li>
-<li>PR #1478: Upgrade maven-surefire-plugin
-</li>
-<li>PR #1476: Add TransactionStore to MVStore jar
-</li>
-<li>Issue #1475: Dropping column used by a view produces misleading error message
-</li>
-<li>Issue #1473: TestScript needs better detection of sorted result
-</li>
-<li>PR #1471: issue 1350: TestCrashAPI: PageStore.freeListPagesPerList
-</li>
-<li>PR #1470: Fix window functions in queries with HAVING
-</li>
-<li>PR #1469: Forbid incorrect nesting of aggregates and window functions
-</li>
-<li>Issue #1437: Generated as Identity has a different behaviour.
-</li>
-<li>PR #1467: Fix subtraction of timestamps
-</li>
-<li>PR #1464: Assorted minor changes in window processing code
-</li>
-<li>PR #1463: Fix some window aggregates and reduce amount of collecting implementations
-</li>
-<li>PR #1462: Separate aggregate and window code in some places
-</li>
-<li>PR #1461: Add WINDOW clause support
-</li>
-<li>Issue #1427: Scalability problem in MVSpatialIndex
-</li>
-<li>PR #1459: Improve window clause correctness checks
-</li>
-<li>PR #1457: Add NTILE(), LEAD() and LAG() window functions
-</li>
-<li>PR #1456: Add experimental implementation of remaining types of window frames
-</li>
-<li>PR #1454: Add FIRST_VALUE(), LAST_VALUE(), and NTH_VALUE()
-</li>
-<li>PR #1453, Issue #1161: Add ROW_NUMBER(), RANK(), DENSE_RANK(), PERCENT_RANK(), and CUME_DIST() window functions
-</li>
-<li>PR #1452: Reset aggregates before reuse
-</li>
-<li>PR #1451: Add experimental support for aggregates with OVER (ORDER BY *)
-</li>
-<li>PR #1450: Evaluate window aggregates only once for each partition
-</li>
-<li>PR #1449: Move more code from Aggregate and JavaAggregate to AbstractAggregate
-</li>
-<li>PR #1448: Add experimental implementation of grouped window queries
-</li>
-<li>PR #1447: Refactor OVER() processing code and fix some issues
-</li>
-<li>PR #1446: fix : The French messages are bad generated (not contain DB message)
-</li>
-<li>PR #1445: Use PostGIS-compatible format for SRID-only constraint in GEOMETRY
-</li>
-<li>PR #1444: Add experimental unoptimized support for OVER ([PARTITION BY ...]) in aggregates
-</li>
-<li>PR #1442: Bugfix - Release MVStore lock and file resources rightly even if errors when compacting database
-</li>
-<li>PR #1441: Add GEOMETRY type subtypes with type and SRID constraints
-</li>
-<li>PR #1434: Add support for ENUM in CAST and other changes
-</li>
-<li>PR #1431: Fix some inconsistencies in documentation and improve mvn build
-</li>
-<li>PR #1428: Add support for M and ZM dimensions to GEOMETRY data type
-</li>
-<li>Issue #1405: Introduce LocalResult factory
-</li>
-<li>PR #1422: Add ENVELOPE aggregate function
-</li>
-<li>Issue #1421: Remove old-style outer join
-</li>
-<li>PR #1419: Assorted minor changes
-</li>
-<li>PR #1414: DEFRAG and COMPACT mixup
-</li>
-<li>PR #1413: improvements to MVStore garbage collection
-</li>
-<li>PR #1412: Added org.h2.store.fs package to exported osgi bundles
-</li>
-<li>PR #1409: Map all remaining error codes to custom exception classes
-</li>
-<li>Issue #1407: Add a MODE() aggregate function
-</li>
-<li>PR #1402: Duplicate conditions in column check constraint
-</li>
-<li>PR #1399: Add more subclasses of SQLException and use it for some error codes
-</li>
-<li>PR #1397: Add DATEADD return type detection
-</li>
-<li>Issue #1393: Add INFORMATION_SCHEMA.COLUMNS.IS_VISIBLE
-</li>
-<li>PR #1392: Some refactoring and assorted minor optimizations
-</li>
-<li>PR #1388: Extract UnaryOperation from Operation and other changes
-</li>
-<li>PR #1386: DISK_SPACE_USED() for MVStore and other minor changes
-</li>
-<li>PR #1385: split up the rather large convertTo method
-</li>
-<li>PR #1384: Throw exception if unknown mode is specified in database URL
-</li>
-<li>Issue #1365, PR #1382: Parse more date-time literals for compatibility with other databases
-</li>
-<li>PR #1381: Minor fixes for INTERVAL data type
-</li>
-<li>PR #1380: Improve documentation of intervals
-</li>
-<li>Issue #1189: "Merge into using" parameters aren't found
-</li>
-<li>Issue #1377: org.h2.api.Interval and TIME leftovers
-</li>
-<li>PR #1376: TestMultiThreadedKernel is back
-</li>
-<li>PR #1373: INTERVAL data type
-</li>
-<li>Issue #1369: In MSSQL Server Mode generated UUID fields need NEWID() function
-</li>
-<li>Issue #756: FunctionsMySql is not in the main jar
-</li>
-<li>PR #1368: Parse BINARY VARYING, BINARY LARGE OBJECT, and CHARACTER LARGE OBJECT
-</li>
-<li>PR #1367: Assorted changes with SELECT output limitation clauses
-</li>
-<li>Issue #1363: Why H2 requires random own packages in OSGi bundle description?
-</li>
-<li>Issue #1192: Add an Automatic-Module-Name
-</li>
-<li>Issue #1361, PR #1362: Add limited support for MONEY and SMALLMONEY in compatibility modes
-</li>
-<li>Issue #1327: mvn build misses some resources
-</li>
-<li>PR #1359: Add system property to return OffsetDateTime from ResultSet.getObject()
-</li>
-<li>PR #1357: Simplify execution flow in some places
-</li>
-<li>PR #1356: Fix NPE in Query.initExpression()
-</li>
-<li>PR #1355: Assorted changes in MetaTable
-</li>
-<li>Issue #1352: TestCrashAPI: Prepared.getObjectId() was called before
-</li>
-<li>PR #1349: Changes is conversion and comparison methods of Value
-</li>
-<li>Issue #1346: Exception when using IN condition for enums
-</li>
-<li>PR #1345: Replace some init methods with constructors
-</li>
-<li>PR #1344: Streamline last chunk verification on startup
-</li>
-<li>PR #1341: Optimize MVSecondaryIndex.convertToKey()
-</li>
-<li>PR #1340: NoSuchElementException instead of returning null
-</li>
-<li>PR #1339: Add support of TIMESTAMP WITH TIME ZONE to addition and subtraction operators
-</li>
-<li>PR #1337: Streamline Value comparison
-</li>
-<li>PR #1336: Minor refactorings
-</li>
-<li>Issue #1332: Constraint name not set correctly
-</li>
-<li>Rename fields to reflect actual type
-</li>
-<li>Issue #1331: Regression in Database.updateMeta()
-</li>
-<li>Issue #1323: Slow update after altering table in 1.4.197
-</li>
-<li>PR #1326: Add support of PERCENT in FETCH and TOP clauses
-</li>
-<li>PR #1325: Optimize WITH TIES in some queries and specify data types for KEY_COLUMN_USAGE
-</li>
-<li>PR #1321: Do not add rows before OFFSET to result if possible
-</li>
-<li>PR #1319: Treat NEXTVAL as an auto-generated key
-</li>
-<li>PR #1318: Mode append fo MVPlainTempResult
-</li>
-<li>PR #1314: Add ALTER VIEW RENAME command
-</li>
-<li>PR #1313, issue #1315: Bugfix - using default locale encoding issue in conversion between varchar and varbinary value, and checking javac output text issue in SourceCompiler
-</li>
-<li>PR #1312: Add Java 9+ support to NIO_CLEANER_HACK
-</li>
-<li>PR #1311: Fix minor issues with ResultSet.getObject(..., Class) and WITH TIES
-</li>
-<li>Issue #1298: TestKillRestartMulti: A map named undoLog.2 already exists
-</li>
-<li>Issue #1307: Invalid value "null" for parameter "calendar" [90008-193]
-</li>
-<li>PR #1306: Add initial implementation of WITH TIES clause
-</li>
-<li>PR #1304: Update changelog and fix building of documentation
-</li>
-<li>PR #1302: Use OpenJDK instead of OracleJDK 10 in Travis builds due to Travis problem
-</li>
-<li>Issue #1032: Error when executing "SELECT DISTINCT ON"
-</li>
-<li>Issue #1295: ConditionInSelect violates requirements of LocalResult
-</li>
-<li>PR #1296: Assorted minor changes
-</li>
-<li>PR #1293: Move HELP and SHOW tests into own files
-</li>
-<li>PR #1291: Fix update count for REPLACE and move some SQL tests into separate files
-</li>
-<li>PR #1290: Do not load the whole LOBs into memory for comparison operation
-</li>
-<li>Issue #408: DISTINCT does not properly work with ORDER BY on function like LOWER
-</li>
-<li>PR #1286: Fix MVTempResult implementations for results with invisible columns
-</li>
-<li>Issue #1284: Nanoseconds of timestamps from old H2 versions are not read properly
-</li>
-<li>PR #1283: Clean up interaction between LocalResult and ResultExternal
-</li>
-<li>Issue #1265: OOME is not handled properly in TraceObject.logAndConvert()
-</li>
-<li>Issue #1061: Regression: Braces after WITH clause not allowed anymore
-</li>
-<li>PR #1277: Assorted changes in Parser
-</li>
-<li>PR #1276: Improve support of ARRAY and SQLXML in JDBC layer
-</li>
-<li>PR #1275: Do not quote other lower case characters
-</li>
-<li>PR #1274: Use token type in Parser instead of string comparisons
-</li>
-<li>PR #1272: Reduce code duplication in Parser
-</li>
-<li>PR #1271: Minor memory leak
-</li>
-<li>PR #1270: drop TableView isPersistent field
-</li>
-<li>PR #1269: Eliminate commit of empty batch in some tests
-</li>
-<li>Issue #1266: Add INFORMATION_SCHEMA.COLUMNS.DATETIME_PRECISION
-</li>
-<li>Issue #1261: How to discover stored enum types through INFORMATION_SCHEMA
-</li>
-<li>Issue #1258: Failing to remove index when using schema.table
-</li>
-<li>PR #1256: misc tiny refactorings
-</li>
-<li>PR #1255: Minor changes in MERGE USING, DATE_TRUNC, and EXTRACT
-</li>
-<li>Issue #1214: Internal compiler believes that "3 warnings" is an error
-</li>
-<li>PR #1252: Assorted minor changes
-</li>
-<li>PR #1251: Fix SQL representation of CAST for types with fractional seconds precision
-</li>
-<li>PR #1250: Batch append mode for MVMap
-</li>
-<li>PR #1248: StringIndexOutOfBoundsException due to undoLog map
-</li>
-<li>PR #1246: Detect disabled tests
-</li>
-<li>PR #1242: Add implementation of SQLXML interface
-</li>
-<li>PR #1241: Various tweaks in attempting to fix TestDiskFull test
-</li>
-<li>PR #1240: Optimise ValueLobDB comparison methods
-</li>
-<li>PR #1239: Don't try to find tools.jar on Java 9+
-</li>
-<li>PR #1238: remove unfinished android API
-</li>
-<li>PR #1237: remove JaQu
-</li>
-<li>PR #1236: remove STORE_LOCAL_TIME code
-</li>
-<li>PR #1235: Do not use deprecated Class.newInstance()
-</li>
-<li>PR #1234: Fix NPE in Parser.parseMergeUsing()
-</li>
-<li>PR #1233: Simplify old lob ValueLob class
-</li>
-<li>Issue 1227: lob growth in pagestore mode
-</li>
-<li>PR #1230: clean up some javadoc and some throws clauses
-</li>
-<li>PR #1229: Create UndoLog only when necessary and remove outdated code
-</li>
-<li>PR #1228: Remove some PageStore+MVCC leftovers
-</li>
-<li>PR #1226: Fix inconsistencies in checks for transaction isolation level
-</li>
-<li>PR #1224: Enable Java 10 testing on Travis
-</li>
-<li>PR #1223: Fix issues with testing on latest Java versions
-</li>
-<li>PR #1222: Leftovers handling
-</li>
-<li>Issue #1220: JDK-9 build fails due to usage of java.xml.bind in external authentication
-</li>
-<li>PR #1218: Test utilities only once during TestAll
-</li>
-<li>PR #1217: Postpone session.endStatement() until after commit
-</li>
-<li>PR #1213: KillRestart fix
-</li>
-<li>PR #1211: Assorted minor changes
-</li>
-<li>Issue #1204: Always use MVCC with MVStore and never use it with PageStore
-</li>
-<li>PR #1206: Forbid reconnects in non-regular modes in TestScript
-</li>
-<li>PR #1205: Misc test fixes
-</li>
-<li>Issue 1198: Enable MULTI_THREADED by default for MVStore mode
-</li>
-<li>Issue #1195: Calling setBytes to set VARCHAR field fails
-</li>
-<li>PR #1197: Fix or suppress errors in tests
-</li>
-<li>PR #1194: TestKillRestartMulti: A map named undoLog-1 already exists
-</li>
-<li>PR #1193: enable TestRandomSQL on non-memory databases
-</li>
-<li>PR #1191: External authentication with datasource issue
-</li>
-<li>PR #1188: Undo log split to reduce contention
-</li>
-<li>PR #1186: TransactionMap::sizeAsLong() optimized - temp map eliminated
-</li>
-<li>PR #1185: Improve naming of the object id field in Prepared
-</li>
-<li>Issue #1196: Feature request for MS SQL Server Compatibility Mode
-</li>
-<li>Issue #1177: Resource leak in Recover tool
-</li>
-<li>PR #1183: Improve concurrency of connection pool with wait-free implement
-</li>
-<li>Issue #1073: H2 v1.4.197 fails to open an existing database with the error [Unique index or primary key violation: "PRIMARY KEY ON """".PAGE_INDEX"]
-</li>
-<li>PR #1179: Drop TransactionMap.readLogId
-</li>
-<li>PR #1181: Improve CURRENT_TIMESTAMP and add LOCALTIME and LOCALTIMESTAMP
-</li>
-<li>PR #1176: Magic value replacement with constant
-</li>
-<li>PR #1171: Introduce last committed value into a VersionedValue
-</li>
-<li>PR #1175: tighten test conditions - do not ignore any exceptions
-</li>
-<li>PR #1174: Remove mapid
-</li>
-<li>PR #1173: protect first background exception encountered and relate it to clients
-</li>
-<li>PR #1172: Yet another attempt to tighten that testing loop
-</li>
-<li>PR #1170: Add support of CONTINUE | RESTART IDENTITY to TRUNCATE TABLE
-</li>
-<li>Issue #1168: ARRAY_CONTAINS() returning incorrect results when inside subquery with Long elements.
-</li>
-<li>PR #1167: MVStore: Undo log synchronization removal
-</li>
-<li>PR #1166: Add SRID support to EWKT format
-</li>
-<li>PR #1165: Optimize isTargetRowFound() and buildColumnListFromOnCondition() in MergeUsing
-</li>
-<li>PR #1164: More fixes for parsing of MERGE USING and other changes in Parser
-</li>
-<li>PR #1154: Support for external authentication
-</li>
-<li>PR #1162: Reduce allocation of temporary strings
-</li>
-<li>PR #1158: make fields final
-</li>
-<li>Issue #1129: TestCrashAPI / TestFuzzOptimizations throw OOME on Travis in PageStore mode
-</li>
-<li>PR #1156: Add support for SQL:2003 WITH [NO] DATA to CREATE TABLE AS
-</li>
-<li>PR #1149: fix deadlock between OnExitDatabaseCloser.DATABASES and Engine.DATABASES
-</li>
-<li>PR #1152: skip intermediate DbException object when creating SQLException
-</li>
-<li>PR #1144: Add missing schema name with recursive view
-</li>
-<li>Issue #1091: get rid of the "New" class
-</li>
-<li>PR #1147: Assorted minor optimizations
-</li>
-<li>PR #1145: Reduce code duplication
-</li>
-<li>PR #1142: Misc small fixes
-</li>
-<li>PR #1141: Assorted optimizations and fixes
-</li>
-<li>PR #1138, #1139: Fix a memory leak caused by DatabaseCloser objects
-</li>
-<li>PR #1137: Step toward making transaction commit atomic
-</li>
-<li>PR #1136: Assorted minor optimizations
-</li>
-<li>PR #1134: Detect possible overflow in integer division and optimize some code
-</li>
-<li>PR #1133: Implement Comparable&lt;Value&gt; in CompareMode and optimize ValueHashMap.keys()
-</li>
-<li>PR #1132: Reduce allocation of ExpressionVisitor instances
-</li>
-<li>PR #1130: Improve TestScript and TestCrashAPI
-</li>
-<li>PR #1128: Fix ON DUPLICATE KEY UPDATE with ENUM
-</li>
-<li>PR #1127: Update JdbcDatabaseMetaData.getSQLKeywords() and perform some minor optimizations
-</li>
-<li>PR #1126: Fix an issue with code coverage and building of documentation
-</li>
-<li>PR #1123: Fix TCP version check
-</li>
-<li>PR #1122: Assorted changes
-</li>
-<li>PR #1121: Add some protection to ValueHashMap against hashes with the same less significant bits
-</li>
-<li>Issue #1097: H2 10x slower than HSQLDB and 6x than Apache Derby for specific query with GROUP BY and DISTINCT subquery
-</li>
-<li>Issue #1093: Use temporary files for ResultSet buffer tables in MVStore
-</li>
-<li>PR #1117: Fix sorting with distinct in ResultTempTable
-</li>
-<li>Issue #1095: Add support for INSERT IGNORE INTO &lt;table&gt; (&lt;columns&gt;) SELECT in MySQL Mode
-</li>
-<li>PR #1114: Minor cleanup and formatting fixes
-</li>
-<li>PR #1112: Improve test scripts
-</li>
-<li>PR #1111: Use a better fix for issue with SRID
-</li>
-<li>Issue #1107: Restore support of DATETIME2 with specified fractional seconds precision
-</li>
-<li>Issue #1106: Get rid of SwitchSource
-</li>
-<li>PR #1105: Assorted minor changes
-</li>
-<li>Issue #1102: CREATE SYNONYM rejects valid definition
-</li>
-<li>PR #1103: Remove redundant synchronization
-</li>
-<li>Issue #1048: 1.4.197 regression. org.h2.jdbc.JdbcSQLException: Timeout trying to lock table "SYS"
-</li>
-<li>PR #1101: Move some tests in better place and add an additional test for 2PC
-</li>
-<li>PR #1100: Fix Insert.prepareUpdateCondition() for PageStore
-</li>
-<li>PR #1098: Fix some issues with NULLS FIRST / LAST
-</li>
-<li>Issue #1089: Parser does not quote words INTERSECTS, DUAL, TOP
-</li>
-<li>Issue #230: Renaming a column does not update foreign key constraint
-</li>
-<li>Issue #1091 Get rid if the New class
-</li>
-<li>PR #1087: improve performance of planning large queries
-</li>
-<li>PR #1085: Add tests for simple one-column index sorting
-</li>
-<li>PR #1084: re-enable some pagestore testing
-</li>
-<li>PR #1083: Assorted changes
-</li>
-<li>Issue #394: Recover tool places COLLATION and BINARY_COLLATION after temporary tables
-</li>
-<li>PR #1081: Session.getTransactionId should return a more distinguishing value
-</li>
-<li>Improve the script-based unit testing to check the error code of the exception thrown.
-</li>
-<li>Issue #1041: Support OR syntax while creating trigger
-</li>
-<li>Issue #1023: MVCC and existing page store file
-</li>
-<li>Issue #1003: Decrypting database with incorrect password renders the database corrupt
-</li>
-<li>Issue #873: No error when `=` in equal condition when column is not of array type
-</li>
-<li>Issue #1069: Failed to add DATETIME(3) column since 1.4.197
-</li>
-<li>Issue #456: H2 table privileges referring to old schema after schema rename
-</li>
-<li>Issue #1062: Concurrent update in table "SYS" caused by Analyze.analyzeTable()
-</li>
-<li>Yet another fix to Page memory accounting
-</li>
-<li>Replace MVStore.ASSERT variable with assertions
-</li>
-<li>Issue #1063: Leftover comments about enhanced for loops
-</li>
-<li>PR #1059: Assorted minor changes
-</li>
-<li>PR #1058: Txcommit atomic
-</li>
-<li>Issue #1038: ora_hash function implementation off by one
-</li>
-<li>PR #1054: Introduce overflow bit in tx state
-</li>
-<li>Issue #1047: Support DISTINCT in custom aggregate functions
-</li>
-<li>PR #1051: Atomic change of transaction state
-</li>
-<li>PR #1046: Split off Transaction TransactionMap VersionedValue
-</li>
-<li>PR #1045: TransactionStore move into separate org.h2.mvstore.tx package
-</li>
-<li>PR #1044: Encapsulate TransactionStore.store field in preparation to a move
-</li>
-<li>PR #1040: generate less garbage for String substring+trim
-</li>
-<li>PR #1035: Minor free space accounting changes
-</li>
-<li>Issue #1034: MERGE USING should not require the same column count in tables
-</li>
-<li>PR #1033: Fix issues with BUILTIN_ALIAS_OVERRIDE=1
-</li>
-<li>PR #1031: Drop schema rights together with schema
-</li>
-<li>PR #1029: No need to remove orphaned LOBs when the db is read-only
-</li>
-<li>Issue #1027: Add support for fully qualified names in MySQL compatibility mode
-</li>
-<li>Issue #178: INSERT ON DUPLICATE KEY UPDATE returns wrong generated key
-</li>
-<li>PR #1025: Remove BitField and replace its usages with BitSet
-</li>
-<li>Issue #1019: Console incorrectly sorts BigDecimal columns alphanumerically
-</li>
-<li>PR #1021: Update JdbcDatabaseMetaData to JDBC 4.1 (Java 7)
-</li>
-<li>Issue #992: 1.4.197 client cannot use DatabaseMetaData with 1.4.196 and older server
-</li>
-<li>Issue #1016: ResultSet.getObject() should return enum value, not ordinal
-</li>
-<li>Issue #1012: NPE when querying INFORMATION_SCHEMA.COLUMNS on a view that references an ENUM column
-</li>
-<li>Issue #1010: MERGE USING table not found with qualified table
-</li>
-<li>PR #1009: Fix ARRAY_AGG with ORDER BY and refactor aggregates
-</li>
-<li>Issue #1006: "Empty enums are not allowed" in 1.4.197 (mode=MYSQL)
-</li>
-<li>PR #1007: Copy also SRID in ValueGeometry.getGeometry()
-</li>
-<li>PR #1004: Preserve type names in more places especially for UUID
-</li>
-<li>Issue #1000: Regression in INFORMATION_SCHEMA.CONSTRAINTS.CONSTRAINT_TYPE content
-</li>
-<li>Issue #997: Can not delete from tables with enums
-</li>
-<li>Issue #994: Too much column in result set for GENERATED_KEYS on table with DEFAULT
-</li>
-<li>PR #993: Fix some compiler warnings and improve assert*() methods
-</li>
-<li>PR #991: Generate shorter queries in JdbcDatabaseMetaData.getTables() and remove some dead code
-</li>
-<li>PR #989: Fix more issues with range table and improve its documentation
-</li>
-</ul>
-
-<h2>Version 1.4.197 (2018-03-18)</h2>
-<ul>
-<li>PR #988: Fix RangeTable.getRowCount() for non-default step
-</li>
-<li>PR #987: ValueBoolean constants are not cleared and may be used directly
-</li>
-<li>PR #986: Check parameters in JdbcPreparedStatement.addBatch()
-</li>
-<li>PR #984: Minor refactorings in Parser
-</li>
-<li>PR #983: Code cleanups via IntelliJ IDEA inspections
-</li>
-<li>Issue #960: Implement remaining time unit in "date_trunc" function
-</li>
-<li>Issue #933: MVStore background writer endless loop
-</li>
-<li>PR #981: Reorganize date-time functions
-</li>
-<li>PR #980: Add Parser.toString() method for improved debugging experience
-</li>
-<li>PR #979: Remove support of TCP protocol versions 6 and 7
-</li>
-<li>PR #977: Add database versions to javadoc of TCP protocol versions and update dictionary.txt
-</li>
-<li>PR #976: Add and use incrementDateValue() and decrementDateValue()
-</li>
-<li>Issue #974: Inline PRIMARY KEY definition loses its name
-</li>
-<li>PR #972: Add META-INF/versions to all non-Android jars that use Bits
-</li>
-<li>PR #971: Update ASM from 6.1-beta to 6.1
-</li>
-<li>PR #970: Added support for ENUM in prepared statement where clause
-</li>
-<li>PR #968: Assorted changes
-</li>
-<li>PR #967: Adds ARRAY_AGG function
-</li>
-<li>PR #966: Do not include help and images in client jar
-</li>
-<li>PR #965: Do not include mvstore.DataUtils in client jar and other changes
-</li>
-<li>PR #964: Fix TestFunctions.testToCharFromDateTime()
-</li>
-<li>PR #963 / Issue #962: Improve documentation of compatibility modes and fix ssl URL description
-</li>
-<li>Issue #219: H2 mode MySQL- ON UPDATE CURRENT_TIMESTAMP not supported
-</li>
-<li>PR #958: More fixes for PgServer
-</li>
-<li>PR #957: Update database size information and links in README.md
-</li>
-<li>PR #956: Move tests added in 821117f1db120a265647a063dca13ab5bee98efc to a proper place
-</li>
-<li>PR #955: Support getObject(?, Class) in generated keys
-</li>
-<li>PR #954: Avoid incorrect reads in iterators of TransactionMap
-</li>
-<li>PR #952: Optimize arguments for MVMap.init()
-</li>
-<li>PR #949: Fix table borders in PDF and other changes
-</li>
-<li>PR #948: Fix some grammar descriptions and ALTER TABLE DROP COLUMN parsing
-</li>
-<li>PR #947: Fix building of documentation and use modern names of Java versions
-</li>
-<li>PR #943: Assorted changes in documentation and a fix for current-time.sql
-</li>
-<li>PR #942: Fix page numbers in TOC in PDF and move System Tables into own HTML / section in PDF
-</li>
-<li>PR #941: Use >> syntax in median.sql and move out more tests from testScript.sql
-</li>
-<li>PR #940: add Support for MySQL: DROP INDEX index_name ON tbl_name
-</li>
-<li>PR #939: Short syntax for SQL tests
-</li>
-<li>Issue #935: The "date_trunc" function is not recognized for 'day'
-</li>
-<li>PR #936: Fix font size, line length, TOC, and many broken links in PDF
-</li>
-<li>PR #931: Assorted changes in documentation
-</li>
-<li>PR #930: Use Math.log10() and remove Mode.getOracle()
-</li>
-<li>PR #929: Remove Mode.supportOffsetFetch
-</li>
-<li>PR #928: Show information about office configuration instead of fallback PDF generation mode
-</li>
-<li>PR #926: Describe datetime fields in documentation
-</li>
-<li>PR #925: Fix time overflow in DATEADD
-</li>
-<li>Issue #416: Add support for DROP SCHEMA x { RESTRICT | CASCADE }
-</li>
-<li>PR #922: Parse and treat fractional seconds precision as described in SQL standard
-</li>
-<li>Issue #919: Add support for mixing adding constraints and columns in multi-add ALTER TABLE statement
-</li>
-<li>PR #916: Implement TABLE_CONSTRAINTS and REFERENTIAL_CONSTRAINTS from the SQL standard
-</li>
-<li>PR #915: Implement INFORMATION_SCHEMA.KEY_COLUMN_USAGE from SQL standard
-</li>
-<li>PR #914: don't allow null values in ConcurrentArrayList
-</li>
-<li>PR #913: Assorted changes in tests and documentation
-</li>
-<li>Issue #755: Missing FLOAT(precision)?
-</li>
-<li>PR #911: Add support for MySQL-style ALTER TABLE ADD ... FIRST
-</li>
-<li>Issue #409: Support derived column list syntax on table alias
-</li>
-<li>PR #908: remove dead code
-</li>
-<li>PR #907: Nest joins only if required and fix some issues with complex joins
-</li>
-<li>PR #906: Fix obscure error on non-standard SELECT * FROM A LEFT JOIN B NATURAL JOIN C
-</li>
-<li>PR #805: Move some JOIN tests from testScript.sql to own file
-</li>
-<li>PR #804: Remove unused parameters from readJoin() and readTableFilter()
-</li>
-<li>Issue #322: CSVREAD WHERE clause containing ORs duplicates number of rows
-</li>
-<li>PR #902: Remove DbSettings.nestedJoins
-</li>
-<li>PR #900: Convert duplicate anonymous classes in TableFilter to nested for reuse
-</li>
-<li>PR #899: Fix ON DUPLICATE KEY UPDATE for inserts with multiple rows
-</li>
-<li>PR #898: Parse TIME WITHOUT TIME ZONE and fix TIMESTAMP as column name
-</li>
-<li>PR #897: Update JTS to version 1.15.0 from LocationTech
-</li>
-<li>PR #896: Assorted changes in help.csv
-</li>
-<li>PR #895: Parse more variants of timestamps with time zones
-</li>
-<li>PR #893: TIMESTAMP WITHOUT TIME ZONE, TIMEZONE_HOUR, and TIMEZONE_MINUTE
-</li>
-<li>PR #892: Assorted minor changes in Parser
-</li>
-<li>PR #891: Update documentation of date-time types and clean up related code a bit
-</li>
-<li>PR #890: Implement conversions for TIMESTAMP WITH TIME ZONE
-</li>
-<li>PR #888: Fix two-phase commit in MVStore
-</li>
-<li>Issue #884: Wrong test Resources path in pom.xml
-</li>
-<li>PR #886: Fix building of documentation
-</li>
-<li>PR #883: Add support for TIMESTAMP WITH TIME ZONE to FORMATDATETIME
-</li>
-<li>PR #881: Reimplement dateValueFromDate() and nanosFromDate() without a Calendar
-</li>
-<li>PR #880: Assorted date-time related changes
-</li>
-<li>PR #879: Reimplement TO_DATE without a Calendar and fix a lot of bugs an incompatibilities
-</li>
-<li>PR #878: Fix IYYY in TO_CHAR and reimplement TRUNCATE without a Calendar
-</li>
-<li>PR #877: Reimplement TO_CHAR without a Calendar and fix 12 AM / 12 PM in it
-</li>
-<li>PR #876: Test out of memory
-</li>
-<li>PR #875: Improve date-time related parts of documentation
-</li>
-<li>PR #872: Assorted date-time related changes
-</li>
-<li>PR #871: Fix OOME in Transfer.readValue() with large CLOB V2
-</li>
-<li>PR #867: TestOutOfMemory stability
-</li>
-<li>Issue #834: Add support for the SQL standard FILTER clause on aggregate functions
-</li>
-<li>PR #864: Minor changes in DateUtils and Function
-</li>
-<li>PR #863: Polish: use isEmpty() to check whether the collection is empty or not.
-</li>
-<li>PR #862: Convert constraint type into enum
-</li>
-<li>PR #861: Avoid resource leak
-</li>
-<li>PR #860: IndexCursor inList
-</li>
-<li>PR #858 / Issue #690 and others: Return all generated rows and columns from getGeneratedKeys()
-</li>
-<li>Make the JDBC client independent of the database engine
-</li>
-<li>PR #857: Do not write each SQL error multiple times in TestScript
-</li>
-<li>PR #856: Fix TestDateTimeUtils.testDayOfWeek() and example with ANY(?
-</li>
-<li>PR #855: Reimplement DATEADD without a Calendar and fix some incompatibilities
-</li>
-<li>PR #854: Improve test stability
-</li>
-<li>PR #851: Reimplement DATEDIFF without a Calendar
-</li>
-<li>Issue #502: SQL "= ANY (?)" supported?
-</li>
-<li>PR #849: Encode date and time in fast and proper way in PgServerThread
-</li>
-<li>PR #847: Reimplement remaining parts of EXTRACT, ISO_YEAR, etc without a Calendar
-</li>
-<li>PR #846: Read known fields directly in DateTimeUtils.getDatePart()
-</li>
-<li>Issue #832: Extract EPOCH from a timestamp
-</li>
-<li>PR #844: Add simple implementations of isWrapperFor() and unwrap() to JdbcDataSource
-</li>
-<li>PR #843: Add MEDIAN to help.csv and fix building of documentation
-</li>
-<li>PR #841: Support indexes with nulls last for MEDIAN aggregate
-</li>
-<li>PR #840: Add MEDIAN aggregate
-</li>
-<li>PR #839: TestTools should not leave testing thread in interrupted state
-</li>
-<li>PR #838: (tests) Excessive calls to Runtime.getRuntime().gc() cause OOM for no reason
-</li>
-<li>Don't use substring when doing StringBuffer#append
-</li>
-<li>PR #837: Use StringUtils.replaceAll() in Function.replace()
-</li>
-<li>PR #836: Allow to read invalid February 29 dates with LocalDate as March 1
-</li>
-<li>PR #835: Inline getTimeTry() into DateTimeUtils.getMillis()
-</li>
-<li>PR #827: Use dateValueFromDate() and nanosFromDate() in parseTimestamp()
-</li>
-<li>Issue #115: to_char fails with pattern FM0D099
-</li>
-<li>PR #825: Merge code for parsing and formatting timestamp values
-</li>
-<li>Enums for ConstraintActionType, UnionType, and OpType
-</li>
-<li>PR 824: Add partial support for INSERT IGNORE in MySQL mode
-</li>
-<li>PR #823: Use ValueByte.getInt() and ValueShort.getInt() in convertTo()
-</li>
-<li>PR #820: Fix some compiler warnings
-</li>
-<li>PR #818: Fixes for remaining issues with boolean parameters
-</li>
-<li>Use enum for file lock method
-</li>
-<li>PR #817: Parse also 1 as true and 0 as false in Utils.parseBoolean()
-</li>
-<li>PR #815: Fix count of completed statements
-</li>
-<li>PR #814: Method.isVarArgs() is available on all supported platforms
-</li>
-<li>Issue #812: TIME values should be in range 0:00:00.000000000 23:59:59.999999999?
-</li>
-<li>PR #811: Issues with Boolean.parseBoolean()
-</li>
-<li>PR #809: Use type constants from LocalDateTimeUtils directly
-</li>
-<li>PR #808: Use HmacSHA256 provided by JRE
-</li>
-<li>PR #807: Use SHA-256 provided by JRE / Android and use rotateLeft / Right in Fog
-</li>
-<li>PR #806: Implement setBytes() and setString() with offset and len
-</li>
-<li>PR #805: Improve support of TIMESTAMP WITH TIME ZONE
-</li>
-<li>PR #803: Use new ArrayList(Collection) and assertThrows()
-</li>
-<li>PR #802: Use Arrays.copyOf() and Arrays.copyOfRange()
-</li>
-<li>PR #801: Fix NULL support in PgServer for primitive types too
-</li>
-<li>PR #800: More fixes in date-time types for ODBC drivers
-</li>
-<li>PR #798: Add partial support of DATE, TIME, and TIMESTAMP data types to PgServer
-</li>
-<li>PR #799: Use result of ArrayList.remove()
-</li>
-<li>PR #797: Add ceilingKey() and floorKey() to TransactionMap (version 2)
-</li>
-<li>PR #796: Add MDY to DateStyle in PgServerThread
-</li>
-<li>PR #794: Sort files in generated jars
-</li>
-<li>PR #793: Change return type of Value.getBoolean() to boolean (unwrapped)
-</li>
-<li>PR #792: Inherit classpath from parent process
-</li>
-<li>PR #791: Switch to JaCoCo code coverage
-</li>
-<li>PR #788: Update lists of keywords
-</li>
-<li>PR #789: Map DATE in Oracle mode to ValueTimestamp
-</li>
-<li>PR #787: Assorted changes
-</li>
-<li>PR #785: Optimize NULL handling in MVSecondaryIndex.add()
-</li>
-<li>PR #783: Add Bits implementation for Java 9 and later versions
-</li>
-<li>PR #784: Hardcoded port numbers should not be used in unit tests
-</li>
-<li>PR #780: Close JavaFileManager after use.
-</li>
-<li>PR #782: Leftover shared lock after release
-</li>
-<li>PR #781: Locks left behind after commit
-</li>
-<li>PR #778: Reduce code duplication
-</li>
-<li>PR #775: Fix building of documentation and zip
-</li>
-<li>PR #774: Assorted changes
-</li>
-<li>PR #773: Better checks for arguments of partial LOB reading methods
-</li>
-<li>PR #772: getBinaryStream() and getCharacterStream() with pos and length
-</li>
-<li>Issue #754: Make NUMERIC type read as NUMERIC
-</li>
-<li>PR #768: Add DataUtils.parseChecksummedMap()
-</li>
-<li>PR #769: Do not copy result of DataUtils.parseMap() to a new maps
-</li>
-<li>PR #766: Minor clean up of DateTimeUtils
-</li>
-<li>PR #764: Make use of try-with-resources statement
-</li>
-<li>Issue #406: Return from ResultSet.getObject not in line with JDBC specification
-</li>
-<li>Issue #710: Misleading exception message when INSERT has no value for self referential 'AS' column
-</li>
-<li>PR #763: Add DataUtils.getMapName()
-</li>
-<li>PR #762: Add row deletion confirmation to web console
-</li>
-<li>PR #760: Assorted minor optimizations
-</li>
-<li>PR #759: Improve the look of error messages in web console
-</li>
-<li>PR #758: Allocate less amount of garbage
-</li>
-<li>PR #757: Fix handling of UUID in Datatype.readValue()
-</li>
-<li>PR #753: Optimize StringUtils.trim() and remove StringUtils.equals()
-</li>
-<li>PR #752: Use predefined charsets instead of names where possible
-</li>
-<li>PR #750: Use AtomicIntegerArray and StandardCharsets
-</li>
-<li>PR #749: Fix some build checks in sources
-</li>
-<li>Issue #740: TestWeb hangups if webSSL=true specified in configuration
-</li>
-<li>Issue #736: Copyright years in sources
-</li>
-<li>Issue #744: TestFile failure on Java 9 and Java 10
-</li>
-<li>PR #741: More cleanups in LocalDateTimeUtils and other minor changes
-</li>
-<li>PR #743: Change REGEXP_REPLACE mode for MariaDB and PostgreSQL
-</li>
-<li>Issue#646 NPE in CREATE VIEW WITH RECURSIVE &amp; NON_RECURSIVE CTE
-</li>
-<li>PR #738: Copy javadoc to *BackwardsCompat to fix building of documentation
-</li>
-<li>PR #735: Add support of java.time.Instant V2
-</li>
-<li>PR #733: Remove JPA/ORM configuration txt files as they're already integrated
-</li>
-<li>PR #732: Fix ==
-</li>
-<li>PR #730: Implement enquoteIdentifier() and isSimpleIdentifier() from JDBC 4.3
-</li>
-<li>PR #729: Grammar documentation change
-</li>
-<li>PR #727: Integer/Long.compare(x, y) can be used to compare primitive values
-</li>
-<li>PR #726: Fixes in tests
-</li>
-<li>Issue #725: FilePathMem.tryLock() fails since Java 9
-</li>
-<li>PR #723: Clean up LocalDateTimeUtils
-</li>
-<li>PR #724: Use StringBuilder instead of StringBuffer
-</li>
-<li>PR #720: DROP TABLE RESTRICT shouldn't drop foreign keys in other tables
-</li>
-<li>PR #722: Assorted minor changes
-</li>
-<li>Issue #638: Oracle mode: incompatible regexp back-reference syntax
-</li>
-<li>Make ALL a reserved keyword
-</li>
-<li>Issue #311: Avoid calling list.toArray(new X[list.size()]) for performance
-</li>
-<li>PR #715: Better getObject error message
-</li>
-<li>PR #714: SecureRandom is already synchronized
-</li>
-<li>PR #712: Return properly encoded UUID from SimpleResultSet.getBytes()
-</li>
-<li>PR #711: TestFunctions less english dependent
-</li>
-<li>Issue #644: Year changing from negative -509 to a positive 510.
-</li>
-<li>PR #706: SIGNAL function
-</li>
-<li>PR #704: added Javascript support for Triggers' source
-</li>
-<li>Issue #694: Oracle syntax for adding NOT NULL constraint not supported.
-</li>
-<li>Issue #699: When using an index for sorting, the index is ignored when also using NULLS LAST/FIRST
-</li>
-<li>Issue #697: FilePathDisk.newInputStream fails for contextual class loading
-</li>
-<li>Issue #695: jdbc:postgresql protocol connection issue in H2 Console Application in case of redshift driver in classpath
-</li>
-<li>Fix 'file not closed' when using FILE_READ
-</li>
-<li>Fix bug in LinkSchema tool when object exists with same name in different schemas
-</li>
-<li>Issue #675: Fix date operations on Locales with non-Gregorian calendars
-</li>
-<li>Fix removal of LOB when rolling back transaction on a table containing more than one LOB column.
-</li>
-<li>Issue #654: List ENUM type values in INFORMATION_SCHEMA.COLUMNS
-</li>
-<li>Issue #650: Simple nested SELECT causes error for table with TIMESTAMP WITH TIMEZONE column
-</li>
-<li>Issue #654: List ENUM type values in INFORMATION_SCHEMA.COLUMNS
-</li>
-<li>Issue #668: Fail of an update command on large table with ENUM column
-</li>
-<li>Issue #662: column called CONSTRAINT is not properly escaped when storing to metadata
-</li>
-<li>Issue #660: Outdated java version mentioned on http://h2database.com/html/build.html#providing_patches
-</li>
-<li>Issue #643: H2 doesn't use index when I use IN and EQUAL in one query
-</li>
-<li>Reset transaction start timestamp on ROLLBACK
-</li>
-<li>Issue #632: CREATE OR REPLACE VIEW creates incorrect columns names
-</li>
-<li>Issue #630: Integer overflow in CacheLRU can cause unrestricted cache growth
-</li>
-<li>Issue #497: Fix TO_DATE in cases of 'inline' text. E.g. the "T" and "Z" in to_date('2017-04-21T00:00:00Z', 'YYYY-MM-DD"T"HH24:MI:SS"Z"')
-</li>
-<li>Fix bug in MySQL/ORACLE-syntax silently corrupting the modified column in cases of setting the 'NULL'- or 'NOT NULL'-constraint. E.g. alter table T modify C NULL;
-</li>
-<li>Issue #570: MySQL compatibility for ALTER TABLE .. DROP INDEX
-</li>
-<li>Issue #537: Include the COLUMN name in message "Numeric value out of range"
-</li>
-<li>Issue #600: ROW_NUMBER() behaviour change in H2 1.4.195
-</li>
-<li>Fix a bunch of race conditions found by vmlens.com, thank you to vmlens for giving us a license.
-</li>
-<li>PR #597: Support more types in getObject
-</li>
-<li>Issue #591: Generated SQL from WITH-CTEs does not include a table identifier
-</li>
-<li>PR #593: Make it possible to create a cluster without using temporary files.
-</li>
-<li>PR #592: "Connection is broken: "unexpected status 16777216" [90067-192]" message when using older h2 releases as client
-</li>
-<li>Issue #585: MySQL mode DELETE statements compatibility
-</li>
-<li>PR #586: remove extra tx preparation
-</li>
-<li>PR #568: Implement MetaData.getColumns() for synonyms.
-</li>
-<li>Issue #581: org.h2.tools.RunScript assumes -script parameter is part of protocol
-</li>
-<li>Fix a deadlock in the TransactionStore
-</li>
-<li>PR #579: Disallow BLOB type in PostgreSQL mode
-</li>
-<li>Issue #576: Common Table Expression (CTE): WITH supports INSERT, UPDATE, MERGE, DELETE, CREATE TABLE ...
-</li>
-<li>Issue #493: Query with distinct/limit/offset subquery returns unexpected rows
-</li>
-<li>Issue #575: Support for full text search in multithreaded mode
-</li>
-<li>Issue #569: ClassCastException when filtering on ENUM value in WHERE clause
-</li>
-<li>Issue #539: Allow override of builtin functions/aliases
-</li>
-<li>Issue #535: Allow explicit paths on Windows without drive letter
-</li>
-<li>Issue #549: Removed UNION ALL requirements for CTE
-</li>
-<li>Issue #548: Table synonym support
-</li>
-<li>Issue #531: Rollback and delayed meta save.
-</li>
-<li>Issue #515: "Unique index or primary key violation" in TestMvccMultiThreaded
-</li>
-<li>Issue #458: TIMESTAMPDIFF() test failing. Handling of timestamp literals.
-</li>
-<li>PR #546: Fixes the missing file tree.js in the web console
-</li>
-<li>Issue #543: Prepare statement with regexp will not refresh parameter after metadata change
-</li>
-<li>PR #536: Support TIMESTAMP_WITH_TIMEZONE 2014 JDBC type
-</li>
-<li>Fix bug in parsing ANALYZE TABLE xxx SAMPLE_SIZE yyy
-</li>
-<li>Add padding for CHAR(N) values in PostgreSQL mode
-</li>
-<li>Issue #89: Add DB2 timestamp format compatibility
-</li>
-</ul>
-
-<h2>Version 1.4.196 (2017-06-10)</h2>
-<ul>
-<li>Issue#479 Allow non-recursive CTEs (WITH statements), patch from stumc
-</li>
-<li>Fix startup issue when using "CHECK" as a column name.
-</li>
-<li>Issue #423: ANALYZE performed multiple times on one table during execution of the same statement.
-</li>
-<li>Issue #426: Support ANALYZE TABLE statement
-</li>
-<li>Issue #438: Fix slow logging via SLF4J (TRACE_LEVEL_FILE=4).
-</li>
-<li>Issue #472: Support CREATE SEQUENCE ... ORDER as a NOOP for Oracle compatibility
-</li>
-<li>Issue #479: Allow non-recursive Common Table Expressions (CTE)
-</li>
-<li>On Mac OS X, with IPv6 and no network connection, the Console tool was not working as expected.
-</li>
-</ul>
-
-<h2>Version 1.4.195 (2017-04-23)</h2>
-<ul>
-<li>Lazy query execution support.
-</li>
-<li>Added API for handling custom data types (System property "h2.customDataTypesHandler", API org.h2.api.CustomDataTypesHandler).
-</li>
-<li>Added support for invisible columns.
-</li>
-<li>Added an ENUM data type, with syntax similar to that of MySQL.
-</li>
-<li>MVStore: for object data types, the cache size memory estimation
-    was sometimes far off in a read-only scenario.
-    This could result in inefficient cache usage.
-</li>
-</ul>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
diff --git a/modules/h2/src/docsrc/html/cheatSheet.html b/modules/h2/src/docsrc/html/cheatSheet.html
deleted file mode 100644
index 16237e5..0000000
--- a/modules/h2/src/docsrc/html/cheatSheet.html
+++ /dev/null
@@ -1,216 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head>
-<meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-H2 Database Engine
-</title>
-<style type="text/css">
-td, input, select, textarea, body, td, th {
-    font: 13px Arial, sans-serif;
-}
-h1, h2, h3, h4, h5 {
-    font: 13px Arial, sans-serif;
-    font-weight: bold;
-}
-h1 {
-    background-color: #0000bb;
-    padding: 2px 4px 2px 4px;
-    margin-bottom: 0px;
-    color: #fff;
-    font-size: 19px;
-    line-height: normal;
-}
-h2 {
-    font-size: 16px;
-}
-a.link {
-    text-decoration: underline;
-    color: blue;
-}
-a.link:hover {
-    text-decoration: underline;
-    color: blue;
-}
-a {
-    text-decoration: none;
-    color: black;
-}
-a:hover {
-    text-decoration: underline;
-    color: blue;
-}
-td, input, select, textarea, body, code, pre {
-    font: 13px Arial, sans-serif;
-}
-pre {
-    background-color: #ece9d8;
-    border: 1px solid #aca899;
-    padding: 6px;
-
-    -moz-border-radius: 4px;
-    -webkit-border-radius: 4px;
-    -khtml-border-radius: 4px;
-    border-radius: 4px;
-
-    -moz-box-shadow: 2px 2px 2px #aca899;
-    -webkit-box-shadow: 2px 2px 2px #aca899;
-    -khtml-box-shadow: 2px 2px 2px #aca899;
-    -o-box-shadow: 2px 2px 2px #aca899;
-    box-shadow: 2px 2px 2px #aca899;
-}
-code {
-    background-color: #ece9d8;
-    padding: 0px 4px;
-
-    -moz-border-radius: 4px;
-    -webkit-border-radius: 4px;
-    -khtml-border-radius: 4px;
-    border-radius: 4px;
-}
-table {
-    background-color: #ffffff;
-    border-collapse: collapse;
-    border: 0px solid #aca899;
-}
-th {
-    text-align: left;
-    background-color: #ece9d8;
-    border: 1px solid #aca899;
-    padding: 2px;
-}
-td {
-    background-color: #ffffff;
-    text-align: left;
-    vertical-align: top;
-    border: 0px solid #aca899;
-    padding: 2px;
-}
-ul, ol {
-    list-style-position: outside;
-    padding-left: 20px;
-}
-li {
-    margin-top: 2px;
-}
-</style>
-</head><body>
-
-<div style="width:780px; margin:0 auto;">
-
-<h1>H2 Database Engine Cheat Sheet</h1>
-<div style="float:left; margin:5px; width:370px;">
-
-<h2>Using H2</h2>
-<ul><li><a href="http://h2database.com">H2</a> is
-    <a href="https://github.com/h2database/h2database">open source</a>,
-    <a href="license.html">free to use and distribute</a>.
-</li><li><a href="http://h2database.com/html/download.html">Download</a>:
-    <a href="http://repo1.maven.org/maven2/com/h2database/h2/${version}/h2-${version}.jar" class="link">jar</a>,
-    <a href="http://www.h2database.com/h2-setup-${versionDate}.exe" class="link">installer (Windows)</a>,
-    <a href="http://www.h2database.com/h2-${versionDate}.zip" class="link">zip</a>.
-</li><li>To start the
-    <a href="quickstart.html#h2_console">H2 Console tool</a>, double click the jar file, or
-    run <code>java -jar h2*.jar</code>, <code>h2.bat</code>, or <code>h2.sh</code>.
-</li><li><a href="tutorial.html#creating_new_databases">A new database is automatically created</a>
-    <a href="features.html#database_only_if_exists">by default</a>.
-</li><li><a href="features.html#closing_a_database">Closing the last connection closes the database</a>.
-</li></ul>
-
-<h2>Documentation</h2>
-<p>
-Reference:
-<a href="grammar.html" class="link">SQL grammar</a>,
-<a href="functions.html" class="link">functions</a>,
-<a href="datatypes.html" class="link">data types</a>,
-<a href="tutorial.html#command_line_tools" class="link">tools</a>,
-<a href="../javadoc/index.html" class="link">API</a>
-<br />
-<a href="features.html">Features</a>:
-<a href="tutorial.html#fulltext" class="link">fulltext search</a>,
-<a href="features.html#file_encryption" class="link">encryption</a>,
-<a href="features.html#read_only" class="link">read-only</a>
-<a href="features.html#database_in_zip" class="link">(zip/jar)</a>,
-<a href="tutorial.html#csv" class="link">CSV</a>,
-<a href="features.html#auto_reconnect" class="link">auto-reconnect</a>,
-<a href="features.html#triggers" class="link">triggers</a>,
-<a href="features.html#user_defined_functions" class="link">user functions</a>
-</p>
-
-<h2><a href="features.html#database_url">Database URLs</a></h2>
-<p>
-<b><a href="features.html#connection_modes">Embedded</a></b><br />
-<code>jdbc:h2:~/test</code> 'test' in the user home directory<br />
-<code>jdbc:h2:/data/test</code> 'test' in the directory /data<br />
-<code>jdbc:h2:./test</code> in the current(!) working directory<br />
-</p><p>
-<b><a href="features.html#in_memory_databases">In-Memory</a></b><br />
-<code>jdbc:h2:mem:test</code> multiple connections in one process<br />
-<code>jdbc:h2:mem:</code> unnamed private; one connection<br />
-</p><p>
-<b><a href="tutorial.html#using_server">Server Mode</a></b><br />
-<code>jdbc:h2:tcp://localhost/~/test</code> user home dir<br />
-<code>jdbc:h2:tcp://localhost//data/test</code> absolute dir<br />
-<a href="tutorial.html#using_server">Server start</a>:<code>java -cp *.jar org.h2.tools.Server</code>
-</p><p>
-<b><a href="features.html#database_url">Settings</a></b><br />
-<code>jdbc:h2:..;MODE=MySQL</code> <a href="features.html#compatibility" >compatibility (or HSQLDB,...)</a><br />
-<code>jdbc:h2:..;TRACE_LEVEL_FILE=3</code> <a href="features.html#trace_options">log to *.trace.db</a><br />
-</p>
-
-</div>
-<div style="float:right; padding:5px; width:370px;">
-
-<h2><a href="tutorial.html#connecting_using_jdbc">Using the JDBC API</a></h2>
-<pre>
-Connection conn = DriverManager.
-    getConnection("jdbc:h2:~/test");
-conn.close();
-</pre>
-
-<h2><a href="tutorial.html#connection_pool">Connection Pool</a></h2>
-<pre>
-import org.h2.jdbcx.JdbcConnectionPool;
-JdbcConnectionPool cp = JdbcConnectionPool.
-    create("jdbc:h2:~/test", "sa", "sa");
-Connection conn = cp.getConnection();
-conn.close(); cp.dispose();
-</pre>
-
-<h2><a href="build.html#maven2">Maven 2</a></h2>
-<pre>
-&lt;dependency&gt;
-    &lt;groupId&gt;com.h2database&lt;/groupId&gt;
-    &lt;artifactId&gt;h2&lt;/artifactId&gt;
-    &lt;version&gt;${version}&lt;/version&gt;
-&lt;/dependency&gt;
-</pre>
-
-<h2><a href="tutorial.html#using_hibernate">Hibernate</a></h2>
-<p>
-hibernate.cfg.xml (or use the HSQLDialect):
-</p>
-<pre>
-&lt;property name="dialect"&gt;
-    org.hibernate.dialect.H2Dialect
-&lt;/property&gt;
-</pre>
-
-<h2><a href="tutorial.html#using_toplink">TopLink and Glassfish</a></h2>
-<p>
-Datasource class: <code>org.h2.jdbcx.JdbcDataSource</code><br />
-<code>oracle.toplink.essentials.platform.</code><br />
-<code>database.H2Platform</code>
-</p>
-
-</div>
-
-</div>
-
-</body></html>
\ No newline at end of file
diff --git a/modules/h2/src/docsrc/html/commands.html b/modules/h2/src/docsrc/html/commands.html
deleted file mode 100644
index 3e92a63..0000000
--- a/modules/h2/src/docsrc/html/commands.html
+++ /dev/null
@@ -1,179 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Commands
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>Commands</h1>
-<h2 id="commands_index">Index</h2>
-<h3>Commands (Data Manipulation)</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="commandsDML">
-    <a href="#${item.link}">${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="commandsDML-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="commandsDML-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="commandsDML-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<h3>Commands (Data Definition)</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="commandsDDL">
-    <a href="#${item.link}">${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="commandsDDL-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="commandsDDL-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="commandsDDL-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<h3>Commands (Other)</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="commandsOther">
-    <a href="#${item.link}">${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="commandsOther-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="commandsOther-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="commandsOther-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<!-- railroad-start -->
-<h2>Details</h2>
-<p>Click on the header to switch between railroad diagram and BNF.</p>
-<!-- railroad-end -->
-
-<h2>Commands (Data Manipulation)</h2>
-<c:forEach var="item" items="commandsDML">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">
-${item.example}</p>
-</c:forEach>
-
-<h2>Commands (Data Definition)</h2>
-<c:forEach var="item" items="commandsDDL">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">
-${item.example}</p>
-</c:forEach>
-
-<h2>Commands (Other)</h2>
-<c:forEach var="item" items="commandsOther">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">
-${item.example}</p>
-</c:forEach>
-
-<!--[if lte IE 7]><script language="javascript">switchBnf(null);</script><![endif]-->
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
diff --git a/modules/h2/src/docsrc/html/datatypes.html b/modules/h2/src/docsrc/html/datatypes.html
deleted file mode 100644
index 41eddf8..0000000
--- a/modules/h2/src/docsrc/html/datatypes.html
+++ /dev/null
@@ -1,99 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Data Types
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>Data Types</h1>
-<h2 id="datatypes_index">Index</h2>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="dataTypes">
-    <a href="#${item.link}" >${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="dataTypes-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="dataTypes-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="dataTypes-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<!-- railroad-start -->
-<h2>Details</h2>
-<p>Click on the header to switch between railroad diagram and BNF.</p>
-<!-- railroad-end -->
-
-<c:forEach var="item" items="dataTypes">
-<h2 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h2>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">${item.example}</p>
-</c:forEach>
-
-<h2>Interval Data Types</h2>
-
-<c:forEach var="item" items="intervalDataTypes">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">${item.example}</p>
-</c:forEach>
-
-<!--[if lte IE 7]><script language="javascript">switchBnf(null);</script><![endif]-->
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
-
diff --git a/modules/h2/src/docsrc/html/download.html b/modules/h2/src/docsrc/html/download.html
deleted file mode 100644
index f68a60f..0000000
--- a/modules/h2/src/docsrc/html/download.html
+++ /dev/null
@@ -1,76 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Downloads
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>Downloads</h1>
-
-<h3>Version ${version} (${versionDate})</h3>
-<p>
-<a href="http://www.h2database.com/h2-setup-${versionDate}.exe">Windows Installer</a>
-<!-- sha1Exe --><br />
-<a href="http://www.h2database.com/h2-${versionDate}.zip">Platform-Independent Zip</a>
-<!-- sha1Zip --><br />
-</p>
-
-<h3>Version ${stableVersion} (${stableVersionDate}), Last Stable</h3>
-<p>
-<a href="http://www.h2database.com/h2-setup-${stableVersionDate}.exe">Windows Installer</a><br />
-<a href="http://www.h2database.com/h2-${stableVersionDate}.zip">Platform-Independent Zip</a><br />
-</p>
-
-<h3>Old Versions</h3>
-<p>
-<a href="http://code.google.com/p/h2database/downloads/list">Platform-Independent Zip</a><br />
-</p>
-
-<h3>Jar File</h3>
-<p>
-<a href="http://repo2.maven.org/maven2/com/h2database/h2/${version}/h2-${version}.jar">Maven.org</a><br />
-<a href="http://hsql.sourceforge.net/m2-repo/com/h2database/h2/${version}/h2-${version}.jar">Sourceforge.net</a><br />
-</p>
-
-<h3>Maven (Binary, Javadoc, and Source)</h3>
-<p>
-<a href="http://repo2.maven.org/maven2/com/h2database/h2/${version}/h2-${version}.jar">Binary</a><br />
-<a href="http://repo2.maven.org/maven2/com/h2database/h2/${version}/h2-${version}-javadoc.jar">Javadoc</a><br />
-<a href="http://repo2.maven.org/maven2/com/h2database/h2/${version}/h2-${version}-sources.jar">Sources</a><br />
-</p>
-
-<h3>Database Upgrade Helper File</h3>
-<p>
-<a href="http://h2database.com/h2mig_pagestore_addon.jar">Upgrade database from 1.1 to the current version</a>
-</p>
-
-<h3>Git Source Repository</h3>
-<p>
-<a href="https://github.com/h2database/h2database">Github</a>
-</p>
-
-<p>
-For details about changes, see the <a href="changelog.html">Change Log</a>.
-</p>
-
-<h3>News and Project Information</h3>
-<p>
-<a href="http://www.h2database.com/html/newsfeed-atom.xml">Atom Feed</a><br />
-<a href="http://www.h2database.com/html/newsfeed-rss.xml">RSS Feed</a><br />
-<a href="http://www.h2database.com/html/doap-h2.rdf">DOAP File</a> (<a href="http://en.wikipedia.org/wiki/DOAP">what is this</a>)
-</p>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
-
diff --git a/modules/h2/src/docsrc/html/faq.html b/modules/h2/src/docsrc/html/faq.html
deleted file mode 100644
index fcda24a..0000000
--- a/modules/h2/src/docsrc/html/faq.html
+++ /dev/null
@@ -1,288 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Frequently Asked Questions
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1 id="faq_index">Frequently Asked Questions</h1>
-
-<a href="#support">
-    I Have a Problem or Feature Request</a><br />
-<a href="#known_bugs">
-    Are there Known Bugs? When is the Next Release?</a><br />
-<a href="#open_source">
-    Is this Database Engine Open Source?</a><br />
-<a href="#commercial_support">
-    Is Commercial Support Available?</a><br />
-<a href="#create_database">
-    How to Create a New Database?</a><br />
-<a href="#connect">
-    How to Connect to a Database?</a><br />
-<a href="#database_files">
-    Where are the Database Files Stored?</a><br />
-<a href="#size_limit">
-    What is the Size Limit (Maximum Size) of a Database?</a><br />
-<a href="#reliable">
-    Is it Reliable?</a><br />
-<a href="#slow_open">
-    Why is Opening my Database Slow?</a><br />
-<a href="#query_slow">
-    My Query is Slow</a><br />
-<a href="#database_slow">
-    H2 is Very Slow</a><br />
-<a href="#column_names_incorrect">
-    Column Names are Incorrect?</a><br />
-<a href="#float_is_double">
-    Float is Double?</a><br />
-<a href="#how_to_translate">
-    How to Translate this Project?</a><br />
-<a href="#how_to_contribute">
-    How to Contribute to this Project?</a><br />
-
-<h3 id="support">I Have a Problem or Feature Request</h3>
-<p>
-Please read the <a href="build.html#support">support checklist</a>.
-</p>
-
-<h3 id="known_bugs">Are there Known Bugs? When is the Next Release?</h3>
-<p>
-Usually, bugs get fixes as they are found. There is a release every few weeks.
-Here is the list of known and confirmed issues:
-</p>
-<ul><li>When opening a database file in a timezone that has different
-    daylight saving rules: the time part of dates where the daylight saving doesn't match
-    will differ. This is not a problem within regions that use the same rules (such as, within
-    USA, or within Europe), even if the timezone itself is different. As a workaround, export the
-    database to a SQL script using the old timezone, and create a new database in the new
-    timezone.
-</li><li>Tomcat and Glassfish 3 set most static fields (final or non-final) to <code>null</code> when
-    unloading a web application. This can cause a <code>NullPointerException</code> in H2 versions
-    1.1.107 and older, and may still not work in newer versions. Please report it if you
-    run into this issue. In Tomcat &gt;= 6.0 this behavior can be disabled by setting the
-    system property <code>org.apache.catalina.loader.WebappClassLoader.ENABLE_CLEAR_REFERENCES=false</code>,
-    however Tomcat may then run out of memory. A known workaround is to
-    put the <code>h2*.jar</code> file in a shared <code>lib</code> directory
-    (<code>common/lib</code>).
-</li><li>Some problems have been found with right outer join. Internally, it is converted
-    to left outer join, which does not always produce the same results as other databases
-    when used in combination with other joins. This problem is fixed in H2 version 1.3.
-</li></ul>
-<p>
-For a complete list, see <a href="https://github.com/h2database/h2database/issues">Open Issues</a>.
-</p>
-
-<h3 id="open_source">Is this Database Engine Open Source?</h3>
-<p>
-Yes. It is free to use and distribute, and the source code is included.
-See also under license.
-</p>
-
-<h3 id="commercial_support">Is Commercial Support Available?</h3>
-<p>
-No, currently commercial support is not available.
-</p>
-
-<h3 id="create_database">How to Create a New Database?</h3>
-<p>
-By default, a new database is automatically created if it does not yet exist when
-<a href="features.html#database_url">embedded</a> URL is used.
-See <a href="tutorial.html#creating_new_databases">Creating New Databases</a>.
-</p>
-
-<h3 id="connect">How to Connect to a Database?</h3>
-<p>
-The database driver is <code>org.h2.Driver</code>,
-and the database URL starts with <code>jdbc:h2:</code>.
-To connect to a database using JDBC, use the following code:
-</p>
-<pre>
-Connection conn = DriverManager.getConnection("jdbc:h2:~/test", "sa", "");
-</pre>
-
-<h3 id="database_files">Where are the Database Files Stored?</h3>
-<p>
-When using database URLs like <code>jdbc:h2:~/test</code>,
-the database is stored in the user directory.
-For Windows, this is usually
-<code>C:\Documents and Settings\&lt;userName&gt;</code> or
-<code>C:\Users\&lt;userName&gt;</code>.
-If the base directory is not set (as in <code>jdbc:h2:./test</code>),
-the database files are stored in the directory where the application is started
-(the current working directory).
-When using the H2 Console application from the start menu,
-this is <code>&lt;Installation Directory&gt;/bin</code>.
-The base directory can be set in the database URL.
-A fixed or relative path can be used. When using the URL
-<code>jdbc:h2:file:./data/sample</code>, the database is stored in the directory
-<code>data</code> (relative to the current working directory).
-The directory is created automatically if it does not yet exist.
-It is also possible to use the fully qualified directory name (and for Windows, drive name).
-Example: <code>jdbc:h2:file:C:/data/test</code>
-</p>
-
-<h3 id="size_limit">What is the Size Limit (Maximum Size) of a Database?</h3>
-<p>
-See <a href="advanced.html#limits_limitations">Limits and Limitations</a>.
-</p>
-
-<h3 id="reliable">Is it Reliable?</h3>
-<p>
-That is not easy to say. It is still a quite new product. A lot of tests have been written,
-and the code coverage of these tests is higher than 80% for each package.
-Randomized stress tests are run regularly. But there are probably still
-bugs that have not yet been found (as with most software). Some features are known
-to be dangerous, they are only supported for situations where performance is more important
-than reliability. Those dangerous features are:
-</p>
-<ul><li>Disabling the transaction log or FileDescriptor.sync() using LOG=0 or LOG=1.
-</li><li>Using the transaction isolation level <code>READ_UNCOMMITTED</code>
-    (<code>LOCK_MODE 0</code>) while at the same time using multiple
-    connections.
-</li><li>Disabling database file protection using (setting <code>FILE_LOCK</code> to
-    <code>NO</code> in the database URL).
-</li><li>Disabling referential integrity using <code>SET REFERENTIAL_INTEGRITY FALSE</code>.
-</li></ul>
-<p>
-In addition to that, running out of memory should be avoided.
-In older versions, OutOfMemory errors while using the database could corrupt a databases.
-</p>
-<p>
-This database is well tested using automated test cases. The tests run every night
-and run for more than one hour. But not all areas of this database are equally well tested.
-When using one of the following features for production, please ensure your use case
-is well tested (if possible with automated test cases). The areas that are not well tested are:
-</p>
-<ul>
-<li>Platforms other than Windows, Linux, Mac OS X, or runtime environments other than Oracle / OpenJDK 7, 8, 9.
-</li><li>The features <code>AUTO_SERVER</code> and <code>AUTO_RECONNECT</code>.
-</li><li>Cluster mode, 2-phase commit, savepoints.
-</li><li>Fulltext search.
-</li><li>Operations on LOBs over 2 GB.
-</li><li>The optimizer may not always select the best plan.
-</li><li>Using the ICU4J collator.
-</li></ul>
-<p>
-Areas considered experimental are:
-</p>
-<ul>
-<li>The PostgreSQL server
-</li><li>Clustering (there are cases were transaction isolation can be broken
-    due to timing issues, for example one session overtaking another session).
-</li><li>Multi-threading within the old PageStore engine using <code>SET MULTI_THREADED=1</code>.
-    Default MVStore engine is multi-threaded by default.
-</li><li>Compatibility modes for other databases (only some features are implemented).
-</li><li>The soft reference cache (<code>CACHE_TYPE=SOFT_LRU</code>). It might not improve performance,
-    and out of memory issues have been reported.
-</li></ul>
-<p>
-Some users have reported that after a power failure, the database cannot be opened sometimes.
-In this case, use a backup of the database or the Recover tool. Please report such problems.
-The plan is that the database automatically recovers in all situations.
-</p>
-
-<h3 id="slow_open">Why is Opening my Database Slow?</h3>
-<p>
-To find out what the problem is, use the H2 Console and click on "Test Connection"
-instead of "Login". After the "Login Successful" appears, click on it (it's a link).
-This will list the top stack traces. Then either analyze this yourself, or
-post those stack traces in the Google Group.
-</p>
-<p>
-Other possible reasons are: the database is very big (many GB), or contains linked tables
-that are slow to open.
-</p>
-
-<h3 id="query_slow">My Query is Slow</h3>
-<p>
-Slow <code>SELECT</code> (or <code>DELETE, UPDATE, MERGE</code>)
-statement can have multiple reasons. Follow this checklist:
-</p>
-<ul>
-<li>Run <code>ANALYZE</code> (see documentation for details).
-</li><li>Run the query with <code>EXPLAIN</code> and check if indexes are used
-    (see documentation for details).
-</li><li>If required, create additional indexes and try again using
-    <code>ANALYZE</code> and <code>EXPLAIN</code>.
-</li><li>If it doesn't help please report the problem.
-</li>
-</ul>
-
-
-<h3 id="database_slow">H2 is Very Slow</h3>
-<p>
-By default, H2 closes the database when the last connection is closed.
-If your application closes the only connection after each operation,
-the database is opened and closed a lot, which is quite slow.
-There are multiple ways to solve this problem, see
-<a href="performance.html#database_performance_tuning">Database Performance Tuning</a>.
-</p>
-
-<h3 id="column_names_incorrect">Column Names are Incorrect?</h3>
-<p>
-For the query <code>SELECT ID AS X FROM TEST</code> the method
-<code>ResultSetMetaData.getColumnName()</code> returns <code>ID</code>, I expect it to
-return <code>X</code>. What's wrong?
-</p>
-<p>
-This is not a bug. According the JDBC specification, the method
-<code>ResultSetMetaData.getColumnName()</code> should return the name of the column
-and not the alias name. If you need the alias name, use
-<a href="https://docs.oracle.com/javase/7/docs/api/java/sql/ResultSetMetaData.html#getColumnLabel(int)"><code>ResultSetMetaData.getColumnLabel()</code></a>.
-Some other database don't work like this yet (they don't follow the JDBC specification).
-If you need compatibility with those databases, use the <a href="features.html#compatibility">Compatibility Mode</a>,
-or append <a href="http://www.h2database.com/javadoc/org/h2/engine/DbSettings.html#ALIAS_COLUMN_NAME"><code>;ALIAS_COLUMN_NAME=TRUE</code></a> to the database URL.
-</p>
-<p>
-This also applies to DatabaseMetaData calls that return a result set.
-The columns in the JDBC API are column labels, not column names.
-</p>
-
-<h3 id="float_is_double">Float is Double?</h3>
-<p>
-For a table defined as <code>CREATE TABLE TEST(X FLOAT)</code> the method
-<code>ResultSet.getObject()</code> returns a <code>java.lang.Double</code>, I expect it to
-return a <code>java.lang.Float</code>. What's wrong?
-</p>
-<p>
-This is not a bug. According the JDBC specification, the JDBC data type <code>FLOAT</code>
-is equivalent to <code>DOUBLE</code>, and both are mapped to <code>java.lang.Double</code>.
-See also
-<a href="https://docs.oracle.com/javase/1.5.0/docs/guide/jdbc/getstart/mapping.html#1055162">
-Mapping SQL and Java Types - 8.3.10 FLOAT</a>.</p>
-<p>Use REAL or FLOAT(24) data type for <code>java.lang.Float</code> values.</p>
-
-<h3 id="how_to_translate">How to Translate this Project?</h3>
-<p>
-For more information, see
-<a href="build.html#translating">Build/Translating</a>.
-</p>
-
-<h3 id="how_to_contribute">How to Contribute to this Project?</h3>
-<p>
-There are various way to help develop an open source project like H2. The first step could be to
-<a href="build.html#translating">translate</a> the error messages and the GUI to your native language.
-Then, you could
-<a href="build.html#providing_patches">provide patches</a>.
-Please start with small patches. That could be adding a test case to improve the
-<a href="build.html#automated">code coverage</a> (the target code coverage for this project is 90%, higher is better).
-You will have to <a href="build.html">develop, build and run the tests</a>.
-Once you are familiar with the code, you could implement missing features from the
-<a href="http://www.h2database.com/html/roadmap.html">feature request list</a>.
-I suggest to start with very small features that are easy to implement.
-Keep in mind to provide test cases as well.
-</p>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
diff --git a/modules/h2/src/docsrc/html/features.html b/modules/h2/src/docsrc/html/features.html
deleted file mode 100644
index 4c802f1..0000000
--- a/modules/h2/src/docsrc/html/features.html
+++ /dev/null
@@ -1,1719 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Features
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>Features</h1>
-
-<a href="#feature_list">
-    Feature List</a><br />
-<a href="#products_work_with">
-    H2 in Use</a><br />
-<a href="#connection_modes">
-    Connection Modes</a><br />
-<a href="#database_url">
-    Database URL Overview</a><br />
-<a href="#embedded_databases">
-    Connecting to an Embedded (Local) Database</a><br />
-<a href="#in_memory_databases">
-    In-Memory Databases</a><br />
-<a href="#file_encryption">
-    Database Files Encryption</a><br />
-<a href="#database_file_locking">
-    Database File Locking</a><br />
-<a href="#database_only_if_exists">
-    Opening a Database Only if it Already Exists</a><br />
-<a href="#closing_a_database">
-    Closing a Database</a><br />
-<a href="#ignore_unknown_settings">
-    Ignore Unknown Settings</a><br />
-<a href="#other_settings">
-    Changing Other Settings when Opening a Connection</a><br />
-<a href="#custom_access_mode">
-    Custom File Access Mode</a><br />
-<a href="#multiple_connections">
-    Multiple Connections</a><br />
-<a href="#database_file_layout">
-    Database File Layout</a><br />
-<a href="#logging_recovery">
-    Logging and Recovery</a><br />
-<a href="#compatibility">
-    Compatibility</a><br />
-<a href="#auto_reconnect">
-    Auto-Reconnect</a><br />
-<a href="#auto_mixed_mode">
-    Automatic Mixed Mode</a><br />
-<a href="#page_size">
-    Page Size</a><br />
-<a href="#trace_options">
-    Using the Trace Options</a><br />
-<a href="#other_logging">
-    Using Other Logging APIs</a><br />
-<a href="#read_only">
-    Read Only Databases</a><br />
-<a href="#database_in_zip">
-    Read Only Databases in Zip or Jar File</a><br />
-<a href="#computed_columns">
-    Computed Columns / Function Based Index</a><br />
-<a href="#multi_dimensional">
-    Multi-Dimensional Indexes</a><br />
-<a href="#user_defined_functions">
-    User-Defined Functions and Stored Procedures</a><br />
-<a href="#pluggable_tables">
-    Pluggable or User-Defined Tables</a><br />
-<a href="#triggers">
-    Triggers</a><br />
-<a href="#compacting">
-    Compacting a Database</a><br />
-<a href="#cache_settings">
-    Cache Settings</a><br />
-<a href="#external_authentication">
-    External Authentication (Experimental)</a><br />
-
-<h2 id="feature_list">Feature List</h2>
-<h3>Main Features</h3>
-<ul>
-<li>Very fast database engine
-</li><li>Open source
-</li><li>Written in Java
-</li><li>Supports standard SQL, JDBC API
-</li><li>Embedded and Server mode, Clustering support
-</li><li>Strong security features
-</li><li>The PostgreSQL ODBC driver can be used
-</li><li>Multi version concurrency
-</li></ul>
-
-<h3>Additional Features</h3>
-<ul>
-<li>Disk based or in-memory databases and tables, read-only database support, temporary tables
-</li><li>Transaction support (read committed), 2-phase-commit
-</li><li>Multiple connections, table level locking
-</li><li>Cost based optimizer, using a genetic algorithm for complex queries, zero-administration
-</li><li>Scrollable and updatable result set support, large result set, external result sorting,
-    functions can return a result set
-</li><li>Encrypted database (AES), SHA-256 password encryption, encryption functions, SSL
-</li></ul>
-
-<h3>SQL Support</h3>
-<ul>
-<li>Support for multiple schemas, information schema
-</li><li>Referential integrity / foreign key constraints with cascade, check constraints
-</li><li>Inner and outer joins, subqueries, read only views and inline views
-</li><li>Triggers and Java functions / stored procedures
-</li><li>Many built-in functions, including XML and lossless data compression
-</li><li>Wide range of data types including large objects (BLOB/CLOB) and arrays
-</li><li>Sequence and autoincrement columns, computed columns (can be used for function based indexes)
-</li><li>ORDER BY, GROUP BY, HAVING, UNION, OFFSET / FETCH (including PERCENT and WITH TIES), LIMIT, TOP,
-    DISTINCT / DISTINCT ON (...)
-</li><li>Window functions
-</li><li>Collation support, including support for the ICU4J library
-</li><li>Support for users and roles
-</li><li>Compatibility modes for IBM DB2, Apache Derby, HSQLDB,
-    MS SQL Server, MySQL, Oracle, and PostgreSQL.
-</li></ul>
-
-<h3>Security Features</h3>
-<ul>
-<li>Includes a solution for the SQL injection problem
-</li><li>User password authentication uses SHA-256 and salt
-</li><li>For server mode connections, user passwords are never transmitted in plain text over the network
-    (even when using insecure connections; this only applies to the TCP server and not to the H2 Console however;
-    it also doesn't apply if you set the password in the database URL)
-</li><li>All database files (including script files that can be used to backup data) can be
-encrypted using the AES-128 encryption algorithm
-</li><li>The remote JDBC driver supports TCP/IP connections over TLS
-</li><li>The built-in web server supports connections over TLS
-</li><li>Passwords can be sent to the database using char arrays instead of Strings
-</li></ul>
-
-<h3>Other Features and Tools</h3>
-<ul>
-<li>Small footprint (around 2 MB), low memory requirements
-</li><li>Multiple index types (b-tree, tree, hash)
-</li><li>Support for multi-dimensional indexes
-</li><li>CSV (comma separated values) file support
-</li><li>Support for linked tables, and a built-in virtual 'range' table
-</li><li>Supports the <code>EXPLAIN PLAN</code> statement; sophisticated trace options
-</li><li>Database closing can be delayed or disabled to improve the performance
-</li><li>Web-based Console application (translated to many languages) with autocomplete
-</li><li>The database can generate SQL script files
-</li><li>Contains a recovery tool that can dump the contents of the database
-</li><li>Support for variables (for example to calculate running totals)
-</li><li>Automatic re-compilation of prepared statements
-</li><li>Uses a small number of database files
-</li><li>Uses a checksum for each record and log entry for data integrity
-</li><li>Well tested (high code coverage, randomized stress tests)
-</li></ul>
-
-<h2 id="products_work_with">H2 in Use</h2>
-<p>
-For a list of applications that work with or use H2, see:
-<a href="http://www.h2database.com/html/links.html">Links</a>.
-</p>
-
-<h2 id="connection_modes">Connection Modes</h2>
-<p>
-The following connection modes are supported:
-</p>
-<ul>
-<li>Embedded mode (local connections using JDBC)
-</li><li>Server mode (remote connections using JDBC or ODBC over TCP/IP)
-</li><li>Mixed mode (local and remote connections at the same time)
-</li></ul>
-
-<h3>Embedded Mode</h3>
-<p>
-In embedded mode, an application opens a database from within the same JVM using JDBC.
-This is the fastest and easiest connection mode.
-The disadvantage is that a database may only be open in one virtual machine (and class loader) at any time.
-As in all modes, both persistent and in-memory databases are supported.
-There is no limit on the number of database open concurrently,
-or on the number of open connections.
-</p>
-<img src="images/connection-mode-embedded-2.png"
-    width="208" height="259"
-    alt="The database is embedded in the application" />
-
-<h3>Server Mode</h3>
-<p>
-When using the server mode (sometimes called remote mode or client/server mode),
-an application opens a database remotely using the JDBC or ODBC API.
-A server needs to be started within the same or another virtual machine, or on another computer.
-Many applications can connect to the same database at the same time, by connecting to this server.
-Internally, the server process opens the database(s) in embedded mode.
-</p>
-<p>
-The server mode is slower than the embedded mode, because all data is transferred over TCP/IP.
-As in all modes, both persistent and in-memory databases are supported.
-There is no limit on the number of database open concurrently per server,
-or on the number of open connections.
-</p>
-<img src="images/connection-mode-remote-2.png"
-    width="376" height="218"
-    alt="The database is running in a server; the application connects to the server" />
-
-<h3>Mixed Mode</h3>
-<p>
-The mixed mode is a combination of the embedded and the server mode.
-The first application that connects to a database does that in embedded mode, but also starts
-a server so that other applications (running in different processes or virtual machines) can
-concurrently access the same data. The local connections are as fast as if
-the database is used in just the embedded mode, while the remote
-connections are a bit slower.
-</p><p>
-The server can be started and stopped from within the application (using the server API),
-or automatically (automatic mixed mode). When using the <a href="#auto_mixed_mode">automatic mixed mode</a>,
-all clients that want to connect to the database (no matter if
-it's an local or remote connection) can do so using the exact same database URL.
-</p>
-<img src="images/connection-mode-mixed-2.png"
-    width="403" height="240"
-    alt="Database, server, and application run in one JVM; an application connects" />
-
-<h2 id="database_url">Database URL Overview</h2>
-<p>
-This database supports multiple connection modes and connection settings.
-This is achieved using different database URLs. Settings in the URLs are not case sensitive.
-</p>
-<table class="main">
-<tr><th>Topic</th><th>URL Format and Examples</th></tr>
-<tr>
-    <td><a href="#embedded_databases">Embedded (local) connection</a></td>
-    <td class="notranslate">
-        jdbc:h2:[file:][&lt;path&gt;]&lt;databaseName&gt;<br />
-        jdbc:h2:~/test<br />
-        jdbc:h2:file:/data/sample<br />
-        jdbc:h2:file:C:/data/sample (Windows only)<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="#in_memory_databases">In-memory (private)</a></td>
-    <td class="notranslate">jdbc:h2:mem:</td>
-</tr>
-<tr>
-    <td><a href="#in_memory_databases">In-memory (named)</a></td>
-    <td class="notranslate">
-        jdbc:h2:mem:&lt;databaseName&gt;<br />
-        jdbc:h2:mem:test_mem
-    </td>
-</tr>
-<tr>
-    <td><a href="tutorial.html#using_server">Server mode (remote connections)<br /> using TCP/IP</a></td>
-    <td class="notranslate">
-        jdbc:h2:tcp://&lt;server&gt;[:&lt;port&gt;]/[&lt;path&gt;]&lt;databaseName&gt;<br />
-        jdbc:h2:tcp://localhost/~/test<br />
-        jdbc:h2:tcp://dbserv:8084/~/sample<br />
-        jdbc:h2:tcp://localhost/mem:test<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="advanced.html#tls_connections">Server mode (remote connections)<br /> using TLS</a></td>
-    <td class="notranslate">
-        jdbc:h2:ssl://&lt;server&gt;[:&lt;port&gt;]/[&lt;path&gt;]&lt;databaseName&gt;<br />
-        jdbc:h2:ssl://localhost:8085/~/sample;
-    </td>
-</tr>
-<tr>
-    <td><a href="#file_encryption">Using encrypted files</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;CIPHER=AES<br />
-        jdbc:h2:ssl://localhost/~/test;CIPHER=AES<br />
-        jdbc:h2:file:~/secure;CIPHER=AES<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="#database_file_locking">File locking methods</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;FILE_LOCK={FILE|SOCKET|NO}<br />
-        jdbc:h2:file:~/private;CIPHER=AES;FILE_LOCK=SOCKET<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="#database_only_if_exists">Only open if it already exists</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;IFEXISTS=TRUE<br />
-        jdbc:h2:file:~/sample;IFEXISTS=TRUE<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="#do_not_close_on_exit">Don't close the database when the VM exits</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;DB_CLOSE_ON_EXIT=FALSE
-    </td>
-</tr>
-<tr>
-    <td><a href="#execute_sql_on_connection">Execute SQL on connection</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;INIT=RUNSCRIPT FROM '~/create.sql'<br />
-        jdbc:h2:file:~/sample;INIT=RUNSCRIPT FROM '~/create.sql'\;RUNSCRIPT FROM '~/populate.sql'<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="advanced.html#passwords">User name and/or password</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;[;USER=&lt;username&gt;][;PASSWORD=&lt;value&gt;]<br />
-        jdbc:h2:file:~/sample;USER=sa;PASSWORD=123<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="#trace_options">Debug trace settings</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;TRACE_LEVEL_FILE=&lt;level 0..3&gt;<br />
-        jdbc:h2:file:~/sample;TRACE_LEVEL_FILE=3<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="#ignore_unknown_settings">Ignore unknown settings</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;IGNORE_UNKNOWN_SETTINGS=TRUE<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="#custom_access_mode">Custom file access mode</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;ACCESS_MODE_DATA=rws<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="#database_in_zip">Database in a zip file</a></td>
-    <td class="notranslate">
-        jdbc:h2:zip:&lt;zipFileName&gt;!/&lt;databaseName&gt;<br />
-        jdbc:h2:zip:~/db.zip!/test
-    </td>
-</tr>
-<tr>
-    <td><a href="#compatibility">Compatibility mode</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;MODE=&lt;databaseType&gt;<br />
-        jdbc:h2:~/test;MODE=MYSQL;DATABASE_TO_LOWER=TRUE
-    </td>
-</tr>
-<tr>
-    <td><a href="#auto_reconnect">Auto-reconnect</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;AUTO_RECONNECT=TRUE<br />
-        jdbc:h2:tcp://localhost/~/test;AUTO_RECONNECT=TRUE
-    </td>
-</tr>
-<tr>
-    <td><a href="#auto_mixed_mode">Automatic mixed mode</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;AUTO_SERVER=TRUE<br />
-        jdbc:h2:~/test;AUTO_SERVER=TRUE
-    </td>
-</tr>
-<tr>
-    <td><a href="#page_size">Page size</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;PAGE_SIZE=512<br />
-    </td>
-</tr>
-<tr>
-    <td><a href="#other_settings">Changing other settings</a></td>
-    <td class="notranslate">
-        jdbc:h2:&lt;url&gt;;&lt;setting&gt;=&lt;value&gt;[;&lt;setting&gt;=&lt;value&gt;...]<br />
-        jdbc:h2:file:~/sample;TRACE_LEVEL_SYSTEM_OUT=3<br />
-    </td>
-</tr>
-</table>
-
-<h2 id="embedded_databases">Connecting to an Embedded (Local) Database</h2>
-<p>
-The database URL for connecting to a local database is
-<code>jdbc:h2:[file:][&lt;path&gt;]&lt;databaseName&gt;</code>.
-The prefix <code>file:</code> is optional. If no or only a relative path is used, then the current working
-directory is used as a starting point. The case sensitivity of the path and database name depend on the
-operating system, however it is recommended to use lowercase letters only.
-The database name must be at least three characters long
-(a limitation of <code>File.createTempFile</code>).
-The database name must not contain a semicolon.
-To point to the user home directory, use <code>~/</code>, as in: <code>jdbc:h2:~/test</code>.
-</p>
-
-<h2 id="in_memory_databases">In-Memory Databases</h2>
-<p>
-For certain use cases (for example: rapid prototyping, testing, high performance
-operations, read-only databases), it may not be required to persist data, or persist changes to the data.
-This database supports the in-memory mode, where the data is not persisted.
-</p><p>
-In some cases, only one connection to a in-memory database is required.
-This means the database to be opened is private. In this case, the database URL is
-<code>jdbc:h2:mem:</code> Opening two connections within the same virtual machine
-means opening two different (private) databases.
-</p><p>
-Sometimes multiple connections to the same in-memory database are required.
-In this case, the database URL must include a name. Example: <code>jdbc:h2:mem:db1</code>.
-Accessing the same database using this URL only works within the same virtual machine and
-class loader environment.
-</p><p>
-To access an in-memory database from another process or from another computer,
-you need to start a TCP server in the same process as the in-memory database was created.
-The other processes then need to access the database over TCP/IP or TLS,
-using a database URL such as: <code>jdbc:h2:tcp://localhost/mem:db1</code>.
-</p><p>
-By default, closing the last connection to a database closes the database.
-For an in-memory database, this means the content is lost.
-To keep the database open, add <code>;DB_CLOSE_DELAY=-1</code> to the database URL.
-To keep the content of an in-memory database as long as the virtual machine is alive, use
-<code>jdbc:h2:mem:test;DB_CLOSE_DELAY=-1</code>.
-</p>
-
-<h2 id="file_encryption">Database Files Encryption</h2>
-<p>
-The database files can be encrypted.
-Three encryption algorithms are supported:
-</p>
-<ul>
-<li>"AES" - also known as Rijndael, only AES-128 is implemented.</li>
-<li>"XTEA" - the 32 round version.</li>
-<li>"FOG" - pseudo-encryption only useful for hiding data from a text editor.</li>
-</ul>
-<p>
-To use file encryption, you need to specify the encryption algorithm (the 'cipher')
-and the file password (in addition to the user password) when connecting to the database.
-</p>
-
-<h3>Creating a New Database with File Encryption</h3>
-<p>
-By default, a new database is automatically created if it does not exist yet
-when the <a href="#database_url">embedded</a> url is used.
-To create an encrypted database, connect to it as it would already exist locally using the embedded URL.
-</p>
-
-<h3>Connecting to an Encrypted Database</h3>
-<p>
-The encryption algorithm is set in the database URL, and the file password is specified in the password field,
-before the user password. A single space separates the file password
-and the user password; the file password itself may not contain spaces. File passwords
-and user passwords are case sensitive. Here is an example to connect to a
-password-encrypted database:
-</p>
-<pre>
-String url = "jdbc:h2:~/test;CIPHER=AES";
-String user = "sa";
-String pwds = "filepwd userpwd";
-conn = DriverManager.
-    getConnection(url, user, pwds);
-</pre>
-
-<h3>Encrypting or Decrypting a Database</h3>
-<p>
-To encrypt an existing database, use the <code>ChangeFileEncryption</code> tool.
-This tool can also decrypt an encrypted database, or change the file encryption key.
-The tool is available from within the H2 Console in the tools section, or you can run it from the command line.
-The following command line will encrypt the database <code>test</code> in the user home directory
-with the file password <code>filepwd</code> and the encryption algorithm AES:
-</p>
-<pre>
-java -cp h2*.jar org.h2.tools.ChangeFileEncryption -dir ~ -db test -cipher AES -encrypt filepwd
-</pre>
-
-<h2 id="database_file_locking">Database File Locking</h2>
-<p>
-Whenever a database is opened, a lock file is created to signal other processes
-that the database is in use. If database is closed, or if the process that opened
-the database terminates, this lock file is deleted.
-</p><p>
-The following file locking methods are implemented:
-</p>
-<ul>
-<li>The default method is <code>FILE</code> and uses a watchdog thread to
-protect the database file. The watchdog reads the lock file each second.
-</li><li>The second method is <code>SOCKET</code> and opens a server socket.
-The socket method does not require reading the lock file every second.
-The socket method should only be used if the database files
-are only accessed by one (and always the same) computer.
-</li><li>The third method is <code>FS</code>.
-This will use native file locking using <code>FileChannel.lock</code>.
-</li><li>It is also possible to open the database without file locking;
-in this case it is up to the application to protect the database files.
-Failing to do so will result in a corrupted database.
-Using the method <code>NO</code> forces the database to not create a lock file at all.
-Please note that this is unsafe as another process is able to open the same database,
-possibly leading to data corruption.</li></ul>
-<p>
-To open the database with a different file locking method, use the parameter
-<code>FILE_LOCK</code>.
-The following code opens the database with the 'socket' locking method:
-</p>
-<pre>
-String url = "jdbc:h2:~/test;FILE_LOCK=SOCKET";
-</pre>
-<p>
-For more information about the algorithms, see
-<a href="advanced.html#file_locking_protocols">Advanced / File Locking Protocols</a>.
-</p>
-
-<h2 id="database_only_if_exists">Opening a Database Only if it Already Exists</h2>
-<p>
-By default, when an application calls <code>DriverManager.getConnection(url, ...)</code>
-with <a href="features.html#database_url">embedded</a> URL and the database specified in the URL does not yet exist,
-a new (empty) database is created.
-In some situations, it is better to restrict creating new databases, and only allow to open
-existing databases. To do this, add <code>;IFEXISTS=TRUE</code>
-to the database URL. In this case, if the database does not already exist, an exception is thrown when
-trying to connect. The connection only succeeds when the database already exists.
-The complete URL may look like this:
-</p>
-<pre>
-String url = "jdbc:h2:/data/sample;IFEXISTS=TRUE";
-</pre>
-
-<h2 id="closing_a_database">Closing a Database</h2>
-
-<h3>Delayed Database Closing</h3>
-<p>
-Usually, a database is closed when the last connection to it is closed. In some situations
-this slows down the application, for example when it is not possible to keep at least one connection open.
-The automatic closing of a database can be delayed or disabled with the SQL statement
-<code>SET DB_CLOSE_DELAY &lt;seconds&gt;</code>.
-The parameter &lt;seconds&gt; specifies the number of seconds to keep
-a database open after the last connection to it was closed. The following statement
-will keep a database open for 10 seconds after the last connection was closed:
-</p>
-<pre>
-SET DB_CLOSE_DELAY 10
-</pre>
-<p>
-The value -1 means the database is not closed automatically.
-The value 0 is the default and means the database is closed when the last connection is closed.
-This setting is persistent and can be set by an administrator only.
-It is possible to set the value in the database URL: <code>jdbc:h2:~/test;DB_CLOSE_DELAY=10</code>.
-</p>
-
-<h3 id="do_not_close_on_exit">Don't Close a Database when the VM Exits</h3>
-<p>
-By default, a database is closed when the last connection is closed. However, if it is never closed,
-the database is closed when the virtual machine exits normally, using a shutdown hook.
-In some situations, the database should not be closed in this case, for example because the
-database is still used at virtual machine shutdown (to store the shutdown process in the database for example).
-For those cases, the automatic closing of the database can be disabled in the database URL.
-The first connection (the one that is opening the database) needs to
-set the option in the database URL (it is not possible to change the setting afterwards).
-The database URL to disable database closing on exit is:
-</p>
-<pre>
-String url = "jdbc:h2:~/test;DB_CLOSE_ON_EXIT=FALSE";
-</pre>
-
-<h2 id="execute_sql_on_connection">Execute SQL on Connection</h2>
-<p>
-Sometimes, particularly for in-memory databases, it is useful to be able to execute DDL or DML
-commands automatically when a client connects to a database. This functionality is enabled via
-the INIT property. Note that multiple commands may be passed to INIT, but the semicolon delimiter
-must be escaped, as in the example below.
-</p>
-<pre>
-String url = "jdbc:h2:mem:test;INIT=runscript from '~/create.sql'\\;runscript from '~/init.sql'";
-</pre>
-<p>
-Please note the double backslash is only required in a Java or properties file.
-In a GUI, or in an XML file, only one backslash is required:
-</p>
-<pre>
-&lt;property name="url" value=
-"jdbc:h2:mem:test;INIT=create schema if not exists test\;runscript from '~/sql/init.sql'"
-/&gt;
-</pre>
-<p>
-Backslashes within the init script (for example within a runscript statement, to specify the folder names in Windows)
-need to be escaped as well (using a second backslash). It might be simpler to avoid backslashes in folder names for this reason;
-use forward slashes instead.
-</p>
-
-<h2 id="ignore_unknown_settings">Ignore Unknown Settings</h2>
-<p>
-Some applications (for example OpenOffice.org Base) pass some additional parameters
-when connecting to the database. Why those parameters are passed is unknown.
-The parameters <code>PREFERDOSLIKELINEENDS</code> and
-<code>IGNOREDRIVERPRIVILEGES</code> are such examples;
-they are simply ignored to improve the compatibility with OpenOffice.org. If an application
-passes other parameters when connecting to the database, usually the database throws an exception
-saying the parameter is not supported. It is possible to ignored such parameters by adding
-<code>;IGNORE_UNKNOWN_SETTINGS=TRUE</code> to the database URL.
-</p>
-
-<h2 id="other_settings">Changing Other Settings when Opening a Connection</h2>
-<p>
-In addition to the settings already described,
-other database settings can be passed in the database URL.
-Adding <code>;setting=value</code> at the end of a database URL is the
-same as executing the statement <code>SET setting value</code> just after
-connecting. For a list of supported settings, see <a href="grammar.html">SQL Grammar</a>
-or the <a href="http://www.h2database.com/javadoc/org/h2/engine/DbSettings.html">DbSettings</a> javadoc.
-</p>
-
-<h2 id="custom_access_mode">Custom File Access Mode</h2>
-<p>
-Usually, the database opens the database file with the access mode
-<code>rw</code>, meaning read-write (except for read only databases,
-where the mode <code>r</code> is used).
-To open a database in read-only mode if the database file is not read-only, use
-<code>ACCESS_MODE_DATA=r</code>.
-Also supported are <code>rws</code> and <code>rwd</code>.
-This setting must be specified in the database URL:
-</p>
-<pre>
-String url = "jdbc:h2:~/test;ACCESS_MODE_DATA=rws";
-</pre>
-<p>
-For more information see <a href="advanced.html#durability_problems">Durability Problems</a>.
-On many operating systems the access mode <code>rws</code> does not guarantee that the data is written to the disk.
-</p>
-
-<h2 id="multiple_connections">Multiple Connections</h2>
-
-<h3>Opening Multiple Databases at the Same Time</h3>
-<p>
-An application can open multiple databases at the same time, including multiple
-connections to the same database. The number of open database is only limited by the memory available.
-</p>
-
-<h3>Multiple Connections to the Same Database: Client/Server</h3>
-<p>
-If you want to access the same database at the same time from different processes or computers,
-you need to use the client / server mode. In this case, one process acts as the server, and the
-other processes (that could reside on other computers as well) connect to the server via TCP/IP
-(or TLS over TCP/IP for improved security).
-</p>
-
-<h3>Multithreading Support</h3>
-<p>
-This database is multithreading-safe.
-If an application is multi-threaded, it does not need to worry about synchronizing access to the database.
-An application should normally use one connection per thread.
-This database synchronizes access to the same connection, but other databases may not do this.
-To get higher concurrency, you need to use multiple connections.
-</p>
-<p>
-An application can use multiple threads that access the same database at the same time.
-With default MVStore engine threads that use different connections can use the database concurrently.
-With PageStore engine requests to the same database are synchronized,
-that means that if one thread executes a long running query, the other threads need to wait.
-Concurrent database usage may be enabled for PageStore or disabled for MVStore
-with <code>MULTI_THREADED</code> setting.
-Note that multi-threaded mode for PageStore engine is not tested well and has some issues;
-it should be used with caution.
-</p>
-
-<h3>Locking, Lock-Timeout, Deadlocks</h3>
-<p>
-Please note MVCC is enabled in version 1.4.x by default, when using the MVStore.
-In this case, table level locking is not used.
-
-If <a href="advanced.html#mvcc">multi-version concurrency</a> is not used,
-the database uses table level locks to give each connection a consistent state of the data.
-There are two kinds of locks: read locks (shared locks) and write locks (exclusive locks).
-All locks are released when the transaction commits or rolls back.
-When using the default transaction isolation level 'read committed', read locks are already released after each statement.
-</p><p>
-If a connection wants to reads from a table, and there is no write lock on the table,
-then a read lock is added to the table. If there is a write lock, then this connection waits
-for the other connection to release the lock. If a connection cannot get a lock for a specified time,
-then a lock timeout exception is thrown.
-</p><p>
-Usually, <code>SELECT</code> statements will generate read locks. This includes subqueries.
-Statements that modify data use write locks. It is also possible to lock a table exclusively without modifying data,
-using the statement <code>SELECT ... FOR UPDATE</code>.
-The statements <code>COMMIT</code> and
-<code>ROLLBACK</code> releases all open locks.
-The commands <code>SAVEPOINT</code> and
-<code>ROLLBACK TO SAVEPOINT</code> don't affect locks.
-The locks are also released when the autocommit mode changes, and for connections with
-autocommit set to true (this is the default), locks are released after each statement.
-The following statements generate locks:
-</p>
-<table class="main">
-    <tr>
-        <th>Type of Lock</th>
-        <th>SQL Statement</th>
-    </tr>
-    <tr>
-        <td>Read</td>
-        <td class="notranslate">SELECT * FROM TEST;<br />
-        CALL SELECT MAX(ID) FROM TEST;<br />
-        SCRIPT;</td>
-    </tr>
-    <tr>
-        <td>Write</td>
-        <td class="notranslate">SELECT * FROM TEST WHERE 1=0 FOR UPDATE;</td>
-    </tr>
-    <tr>
-        <td>Write</td>
-        <td class="notranslate">INSERT INTO TEST VALUES(1, 'Hello');<br />
-        INSERT INTO TEST SELECT * FROM TEST;<br />
-        UPDATE TEST SET NAME='Hi';<br />
-        DELETE FROM TEST;</td>
-    </tr>
-    <tr>
-        <td>Write</td>
-        <td class="notranslate">ALTER TABLE TEST ...;<br />
-        CREATE INDEX ... ON TEST ...;<br />
-        DROP INDEX ...;</td>
-    </tr>
-</table>
-<p>
-The number of seconds until a lock timeout exception is thrown can be
-set separately for each connection using the SQL command
-<code>SET LOCK_TIMEOUT &lt;milliseconds&gt;</code>.
-The initial lock timeout (that is the timeout used for new connections) can be set using the SQL command
-<code>SET DEFAULT_LOCK_TIMEOUT &lt;milliseconds&gt;</code>. The default lock timeout is persistent.
-</p>
-
-<h3>Avoiding Deadlocks</h3>
-<p>
-To avoid deadlocks, ensure that all transactions lock the tables in the same order
-(for example in alphabetical order), and avoid upgrading read locks to write locks.
-Both can be achieved using explicitly locking tables using <code>SELECT ... FOR UPDATE</code>.
-</p><p>
-Note that delete, insert and update operations issue table level locks with PageStore engine,
-but does not issue them with default MVStore engine.
-</p>
-
-<h2 id="database_file_layout">Database File Layout</h2>
-<p>
-The following files are created for persistent databases:
-</p>
-<table class="main">
-<tr><th>File Name</th><th>Description</th><th>Number of Files</th></tr>
-<tr><td class="notranslate">
-    test.h2.db
-</td><td>
-    Database file.<br />
-    Contains the transaction log, indexes, and data for all tables.<br />
-    Format: <code>&lt;database&gt;.h2.db</code>
-</td><td>
-    1 per database
-</td></tr>
-<tr><td class="notranslate">
-    test.lock.db
-</td><td>
-    Database lock file.<br />
-    Automatically (re-)created while the database is in use.<br />
-    Format: <code>&lt;database&gt;.lock.db</code>
-</td><td>
-    1 per database (only if in use)
-</td></tr>
-<tr><td class="notranslate">
-    test.trace.db
-</td><td>
-    Trace file (if the trace option is enabled).<br />
-    Contains trace information.<br />
-    Format: <code>&lt;database&gt;.trace.db</code><br />
-    Renamed to <code>&lt;database&gt;.trace.db.old</code> is too big.
-</td><td>
-    0 or 1 per database
-</td></tr>
-<tr><td class="notranslate">
-    test.lobs.db/*
-</td><td>
-    Directory containing one file for each<br />
-    BLOB or CLOB value larger than a certain size.<br />
-    Format: <code>&lt;id&gt;.t&lt;tableId&gt;.lob.db</code>
-</td><td>
-    1 per large object
-</td></tr>
-<tr><td class="notranslate">
-    test.123.temp.db
-</td><td>
-    Temporary file.<br />
-    Contains a temporary blob or a large result set.<br />
-    Format: <code>&lt;database&gt;.&lt;id&gt;.temp.db</code>
-</td><td>
-    1 per object
-</td></tr>
-</table>
-
-<h3>Moving and Renaming Database Files</h3>
-<p>
-Database name and location are not stored inside the database files.
-</p><p>
-While a database is closed, the files can be moved to another directory, and they can
-be renamed as well (as long as all files of the same database start with the same
-name and the respective extensions are unchanged).
-</p><p>
-As there is no platform specific data in the files, they can be moved to other operating systems
-without problems.
-</p>
-
-<h3>Backup</h3>
-<p>
-When the database is closed, it is possible to backup the database files.
-</p><p>
-To backup data while the database is running,
-the SQL commands <code>SCRIPT</code> and <code>BACKUP</code> can be used.
-</p>
-
-<h2 id="logging_recovery">Logging and Recovery</h2>
-<p>
-Whenever data is modified in the database and those changes are committed, the changes are written
-to the transaction log (except for in-memory objects). The changes to the main data area itself are usually written
-later on, to optimize disk access. If there is a power failure, the main data area is not up-to-date,
-but because the changes are in the transaction log, the next time the database is opened, the changes
-are re-applied automatically.
-</p>
-
-<h2 id="compatibility">Compatibility</h2>
-<p>
-All database engines behave a little bit different. Where possible, H2 supports the ANSI SQL standard,
-and tries to be compatible to other databases. There are still a few differences however:
-</p>
-<p>
-In MySQL text columns are case insensitive by default, while in H2 they are case sensitive. However
-H2 supports case insensitive columns as well. To create the tables with case insensitive texts, append
-<code>IGNORECASE=TRUE</code> to the database URL
-(example: <code>jdbc:h2:~/test;IGNORECASE=TRUE</code>).
-</p>
-
-<h3>Compatibility Modes</h3>
-<p>
-For certain features, this database can emulate the behavior of specific databases.
-However, only a small subset of the differences between databases are implemented in this way.
-Here is the list of currently supported modes and the differences to the regular mode:
-</p>
-
-<h3>DB2 Compatibility Mode</h3>
-<p>
-To use the IBM DB2 mode, use the database URL <code>jdbc:h2:~/test;MODE=DB2</code>
-or the SQL statement <code>SET MODE DB2</code>.
-</p>
-<ul><li>For aliased columns, <code>ResultSetMetaData.getColumnName()</code>
-    returns the alias name and <code>getTableName()</code> returns
-    <code>null</code>.
-</li><li>Concatenating <code>NULL</code> with another value
-    results in the other value.
-</li><li>Support the pseudo-table SYSIBM.SYSDUMMY1.
-</li><li>Timestamps with dash between date and time are supported.
-</li><li>Datetime value functions return the same value within a command.
-</li></ul>
-
-<h3>Derby Compatibility Mode</h3>
-<p>
-To use the Apache Derby mode, use the database URL <code>jdbc:h2:~/test;MODE=Derby</code>
-or the SQL statement <code>SET MODE Derby</code>.
-</p>
-<ul><li>For aliased columns, <code>ResultSetMetaData.getColumnName()</code>
-    returns the alias name and <code>getTableName()</code> returns
-    <code>null</code>.
-</li><li>For unique indexes, <code>NULL</code> is distinct.
-    That means only one row with <code>NULL</code> in one of the columns is allowed.
-</li><li>Concatenating <code>NULL</code> with another value
-    results in the other value.
-</li><li>Support the pseudo-table SYSIBM.SYSDUMMY1.
-</li><li>Datetime value functions return the same value within a command.
-</li></ul>
-
-<h3>HSQLDB Compatibility Mode</h3>
-<p>
-To use the HSQLDB mode, use the database URL <code>jdbc:h2:~/test;MODE=HSQLDB</code>
-or the SQL statement <code>SET MODE HSQLDB</code>.
-</p>
-<ul><li>For aliased columns, <code>ResultSetMetaData.getColumnName()</code>
-    returns the alias name and <code>getTableName()</code> returns
-    <code>null</code>.
-</li><li>When converting the scale of decimal data, the number is only converted if the new scale is
-    smaller than the current scale. Usually, the scale is converted and 0s are added if required.
-</li><li>For unique indexes, <code>NULL</code> is distinct.
-    That means only one row with <code>NULL</code> in one of the columns is allowed.
-</li><li>Text can be concatenated using '+'.
-</li><li>Datetime value functions return the same value within a command.
-</li></ul>
-
-<h3>MS SQL Server Compatibility Mode</h3>
-<p>
-To use the MS SQL Server mode, use the database URL <code>jdbc:h2:~/test;MODE=MSSQLServer</code>
-or the SQL statement <code>SET MODE MSSQLServer</code>.
-</p>
-<ul><li>For aliased columns, <code>ResultSetMetaData.getColumnName()</code>
-    returns the alias name and <code>getTableName()</code> returns
-    <code>null</code>.
-</li><li>Identifiers may be quoted using square brackets as in <code>[Test]</code>.
-</li><li>For unique indexes, <code>NULL</code> is distinct.
-    That means only one row with <code>NULL</code> in one of the columns is allowed.
-</li><li>Concatenating <code>NULL</code> with another value
-    results in the other value.
-</li><li>Text can be concatenated using '+'.
-</li><li>MONEY data type is treated like NUMERIC(19, 4) data type. SMALLMONEY data type is treated like NUMERIC(10, 4)
-    data type.
-</li><li><code>IDENTITY</code> can be used for automatic id generation on column level.
-</li><li>Table hints are discarded. Example: <code>SELECT * FROM table WITH (NOLOCK)</code>.
-</li><li>Datetime value functions return the same value within a command.
-</li></ul>
-
-<h3>MySQL Compatibility Mode</h3>
-<p>
-To use the MySQL mode, use the database URL <code>jdbc:h2:~/test;MODE=MySQL;DATABASE_TO_LOWER=TRUE</code>.
-Use this mode for compatibility with MariaDB too.
-When case-insensitive identifiers are needed append <code>;CASE_INSENSITIVE_IDENTIFIERS=TRUE</code> to URL.
-Do not change value of DATABASE_TO_LOWER after creation of database.
-</p>
-<ul><li>When inserting data, if a column is defined to be <code>NOT NULL</code>
-    and <code>NULL</code> is inserted,
-    then a 0 (or empty string, or the current timestamp for timestamp columns) value is used.
-    Usually, this operation is not allowed and an exception is thrown.
-</li><li>Creating indexes in the <code>CREATE TABLE</code> statement is allowed using
-    <code>INDEX(..)</code> or <code>KEY(..)</code>.
-    Example: <code>create table test(id int primary key, name varchar(255), key idx_name(name));</code>
-</li><li>When converting a floating point number to an integer, the fractional
-    digits are not truncated, but the value is rounded.
-</li><li>Concatenating <code>NULL</code> with another value
-    results in the other value.
-</li><li>ON DUPLICATE KEY UPDATE is supported in INSERT statements, due to this feature VALUES has special non-standard
-    meaning is some contexts.
-</li><li>INSERT IGNORE is partially supported and may be used to skip rows with duplicate keys if ON DUPLICATE KEY
-    UPDATE is not specified.
-</li><li>REGEXP_REPLACE() uses \ for back-references for compatibility with MariaDB.
-</li><li>Datetime value functions return the same value within a command.
-</li></ul>
-<p>
-Text comparison in MySQL is case insensitive by default, while in H2 it is case sensitive (as in most other databases).
-H2 does support case insensitive text comparison, but it needs to be set separately,
-using <code>SET IGNORECASE TRUE</code>.
-This affects comparison using <code>=, LIKE, REGEXP</code>.
-</p>
-
-<h3>Oracle Compatibility Mode</h3>
-<p>
-To use the Oracle mode, use the database URL <code>jdbc:h2:~/test;MODE=Oracle</code>
-or the SQL statement <code>SET MODE Oracle</code>.
-</p>
-<ul><li>For aliased columns, <code>ResultSetMetaData.getColumnName()</code>
-    returns the alias name and <code>getTableName()</code> returns
-    <code>null</code>.
-</li><li>When using unique indexes, multiple rows with <code>NULL</code>
-    in all columns are allowed, however it is not allowed to have multiple rows with the
-    same values otherwise.
-</li><li>Concatenating <code>NULL</code> with another value
-    results in the other value.
-</li><li>Empty strings are treated like <code>NULL</code> values.
-</li><li>REGEXP_REPLACE() uses \ for back-references.
-</li><li>DATE data type is treated like TIMESTAMP(0) data type.
-</li><li>Datetime value functions return the same value within a command.
-</li></ul>
-
-<h3>PostgreSQL Compatibility Mode</h3>
-<p>
-To use the PostgreSQL mode, use the database URL <code>jdbc:h2:~/test;MODE=PostgreSQL;DATABASE_TO_LOWER=TRUE</code>.
-Do not change value of DATABASE_TO_LOWER after creation of database.
-</p>
-<ul><li>For aliased columns, <code>ResultSetMetaData.getColumnName()</code>
-    returns the alias name and <code>getTableName()</code> returns
-    <code>null</code>.
-</li><li>When converting a floating point number to an integer, the fractional
-    digits are not be truncated, but the value is rounded.
-</li><li>The system columns <code>CTID</code> and
-    <code>OID</code> are supported.
-</li><li>LOG(x) is base 10 in this mode.
-</li><li>REGEXP_REPLACE():
-    <ul>
-    <li>uses \ for back-references;</li>
-    <li>does not throw an exception when the <code>flagsString</code> parameter contains a 'g';</li>
-    <li>replaces only the first matched substring in the absence of the 'g' flag in the <code>flagsString</code> parameter.</li>
-    </ul>
-</li><li>Fixed-width strings are padded with spaces.
-</li><li>MONEY data type is treated like NUMERIC(19, 2) data type.
-</li><li>Datetime value functions return the same value within a transaction.
-</li><li>ARRAY_SLICE() out of bounds parameters are silently corrected.
-</li><li>EXTRACT function with DOW field returns (0-6), Sunday is 0.
-</li></ul>
-
-<h3>Ignite Compatibility Mode</h3>
-<p>
-To use the Ignite mode, use the database URL <code>jdbc:h2:~/test;MODE=Ignite</code>
-or the SQL statement <code>SET MODE Ignite</code>.
-</p>
-<ul><li>Creating indexes in the <code>CREATE TABLE</code> statement is allowed using
-    <code>INDEX(..)</code> or <code>KEY(..)</code>.
-    Example: <code>create table test(id int primary key, name varchar(255), key idx_name(name));</code>
-</li><li>AFFINITY KEY and SHARD KEY keywords may be used in index definition.
-</li><li>Datetime value functions return the same value within a transaction.
-</li></ul>
-
-<h2 id="auto_reconnect">Auto-Reconnect</h2>
-<p>
-The auto-reconnect feature causes the JDBC driver to reconnect to
-the database if the connection is lost. The automatic re-connect only
-occurs when auto-commit is enabled; if auto-commit is disabled, an exception is thrown.
-To enable this mode, append <code>;AUTO_RECONNECT=TRUE</code> to the database URL.
-</p>
-<p>
-Re-connecting will open a new session. After an automatic re-connect,
-variables and local temporary tables definitions (excluding data) are re-created.
-The contents of the system table <code>INFORMATION_SCHEMA.SESSION_STATE</code>
-contains all client side state that is re-created.
-</p>
-<p>
-If another connection uses the database in exclusive mode (enabled using <code>SET EXCLUSIVE 1</code>
-or <code>SET EXCLUSIVE 2</code>), then this connection will try to re-connect until the exclusive mode ends.
-</p>
-
-<h2 id="auto_mixed_mode">Automatic Mixed Mode</h2>
-<p>
-Multiple processes can access the same database without having to start the server manually.
-To do that, append <code>;AUTO_SERVER=TRUE</code> to the database URL.
-You can use the same database URL independent of whether the database is already open or not.
-This feature doesn't work with in-memory databases. Example database URL:
-</p>
-<pre>
-jdbc:h2:/data/test;AUTO_SERVER=TRUE
-</pre>
-<p>
-Use the same URL for all connections to this database. Internally, when using this mode,
-the first connection to the database is made in embedded mode, and additionally a server
-is started internally (as a daemon thread). If the database is already open in another process,
-the server mode is used automatically. The IP address and port of the server are stored in the file
-<code>.lock.db</code>, that's why in-memory databases can't be supported.
-</p>
-<p>
-The application that opens the first connection to the database uses the embedded mode,
-which is faster than the server mode. Therefore the main application should open
-the database first if possible. The first connection automatically starts a server on a random port.
-This server allows remote connections, however only to this database (to ensure that,
-the client reads <code>.lock.db</code> file and sends the random key that is stored there to the server).
-When the first connection is closed, the server stops. If other (remote) connections are still
-open, one of them will then start a server (auto-reconnect is enabled automatically).
-</p>
-<p>
-All processes need to have access to the database files.
-If the first connection is closed (the connection that started the server), open transactions of other connections will be rolled back
-(this may not be a problem if you don't disable autocommit).
-Explicit client/server connections (using <code>jdbc:h2:tcp://</code> or <code>ssl://</code>) are not supported.
-This mode is not supported for in-memory databases.
-</p>
-<p>
-Here is an example how to use this mode. Application 1 and 2 are not necessarily started
-on the same computer, but they need to have access to the database files. Application 1
-and 2 are typically two different processes (however they could run within the same process).
-</p>
-<pre>
-// Application 1:
-DriverManager.getConnection("jdbc:h2:/data/test;AUTO_SERVER=TRUE");
-
-// Application 2:
-DriverManager.getConnection("jdbc:h2:/data/test;AUTO_SERVER=TRUE");
-</pre>
-<p>
-When using this feature, by default the server uses any free TCP port.
-The port can be set manually using <code>AUTO_SERVER_PORT=9090</code>.
-</p>
-
-<h2 id="page_size">Page Size</h2>
-<p>
-The page size for new databases is 2 KB (2048), unless the page size is set
-explicitly in the database URL using <code>PAGE_SIZE=</code> when
-the database is created. The page size of existing databases can not be changed,
-so this property needs to be set when the database is created.
-</p>
-
-<h2 id="trace_options">Using the Trace Options</h2>
-<p>
-To find problems in an application, it is sometimes good to see what database operations
-where executed. This database offers the following trace features:
-</p>
-<ul>
-<li>Trace to <code>System.out</code> and/or to a file
-</li><li>Support for trace levels <code>OFF, ERROR, INFO, DEBUG</code>
-</li><li>The maximum size of the trace file can be set
-</li><li>It is possible to generate Java source code from the trace file
-</li><li>Trace can be enabled at runtime by manually creating a file
-</li></ul>
-
-<h3>Trace Options</h3>
-<p>
-The simplest way to enable the trace option is setting it in the database URL.
-There are two settings, one for <code>System.out</code>
-(<code>TRACE_LEVEL_SYSTEM_OUT</code>) tracing,
-and one for file tracing (<code>TRACE_LEVEL_FILE</code>).
-The trace levels are
-0 for <code>OFF</code>,
-1 for  <code>ERROR</code> (the default),
-2 for <code>INFO</code>, and
-3 for <code>DEBUG</code>.
-A database URL with both levels set to <code>DEBUG</code> is:
-</p>
-<pre>
-jdbc:h2:~/test;TRACE_LEVEL_FILE=3;TRACE_LEVEL_SYSTEM_OUT=3
-</pre>
-<p>
-The trace level can be changed at runtime by executing the SQL command
-<code>SET TRACE_LEVEL_SYSTEM_OUT level</code> (for <code>System.out</code> tracing)
-or <code>SET TRACE_LEVEL_FILE level</code> (for file tracing).
-Example:
-</p>
-<pre>
-SET TRACE_LEVEL_SYSTEM_OUT 3
-</pre>
-
-<h3>Setting the Maximum Size of the Trace File</h3>
-<p>
-When using a high trace level, the trace file can get very big quickly.
-The default size limit is 16 MB, if the trace file exceeds this limit, it is renamed to
-<code>.old</code> and a new file is created.
-If another such file exists, it is deleted.
-To limit the size to a certain number of megabytes, use
-<code>SET TRACE_MAX_FILE_SIZE mb</code>.
-Example:
-</p>
-<pre>
-SET TRACE_MAX_FILE_SIZE 1
-</pre>
-
-<h3>Java Code Generation</h3>
-<p>
-When setting the trace level to <code>INFO</code> or <code>DEBUG</code>,
-Java source code is generated as well. This simplifies reproducing problems. The trace file looks like this:
-</p>
-<pre>
-...
-12-20 20:58:09 jdbc[0]:
-/**/dbMeta3.getURL();
-12-20 20:58:09 jdbc[0]:
-/**/dbMeta3.getTables(null, "", null, new String[]{"TABLE", "VIEW"});
-...
-</pre>
-<p>
-To filter the Java source code, use the <code>ConvertTraceFile</code> tool as follows:
-</p>
-<pre>
-java -cp h2*.jar org.h2.tools.ConvertTraceFile
-    -traceFile "~/test.trace.db" -javaClass "Test"
-</pre>
-<p>
-The generated file <code>Test.java</code> will contain the Java source code.
-The generated source code may be too large to compile (the size of a Java method is limited).
-If this is the case, the source code needs to be split in multiple methods.
-The password is not listed in the trace file and therefore not included in the source code.
-</p>
-
-<h2 id="other_logging">Using Other Logging APIs</h2>
-<p>
-By default, this database uses its own native 'trace' facility. This facility is called 'trace' and not
-'log' within this database to avoid confusion with the transaction log. Trace messages can be
-written to both file and <code>System.out</code>.
-In most cases, this is sufficient, however sometimes it is better to use the same
-facility as the application, for example Log4j. To do that, this database support SLF4J.
-</p>
-<p>
-<a href="https://www.slf4j.org/">SLF4J</a> is a simple facade for various logging APIs
-and allows to plug in the desired implementation at deployment time.
-SLF4J supports implementations such as Logback, Log4j, Jakarta Commons Logging (JCL),
-Java logging, x4juli, and Simple Log.
-</p>
-<p>
-To enable SLF4J, set the file trace level to 4 in the database URL:
-</p>
-<pre>
-jdbc:h2:~/test;TRACE_LEVEL_FILE=4
-</pre>
-<p>
-Changing the log mechanism is not possible after the database is open, that means
-executing the SQL statement <code>SET TRACE_LEVEL_FILE 4</code>
-when the database is already open will not have the desired effect.
-To use SLF4J, all required jar files need to be in the classpath.
-The logger name is <code>h2database</code>.
-If it does not work, check the file <code>&lt;database&gt;.trace.db</code> for error messages.
-</p>
-
-<h2 id="read_only">Read Only Databases</h2>
-<p>
-If the database files are read-only, then the database is read-only as well.
-It is not possible to create new tables, add or modify data in this database.
-Only <code>SELECT</code> and <code>CALL</code> statements are allowed.
-To create a read-only database, close the database.
-Then, make the database file read-only.
-When you open the database now, it is read-only.
-There are two ways an application can find out whether database is read-only:
-by calling <code>Connection.isReadOnly()</code>
-or by executing the SQL statement <code>CALL READONLY()</code>.
-</p>
-<p>
-Using the <a href="#custom_access_mode">Custom Access Mode</a> <code>r</code>
-the database can also be opened in read-only mode, even if the database file is not read only.
-</p>
-
-<h2 id="database_in_zip">Read Only Databases in Zip or Jar File</h2>
-<p>
-To create a read-only database in a zip file, first create a regular persistent database, and then create a backup.
-The database must not have pending changes, that means you need to close all connections to the database first.
-To speed up opening the read-only database and running queries, the database should be closed using <code>SHUTDOWN DEFRAG</code>.
-If you are using a database named <code>test</code>, an easy way to create a zip file is using the
-<code>Backup</code> tool. You can start the tool from the command line, or from within the
-H2 Console (Tools - Backup). Please note that the database must be closed when the backup
-is created. Therefore, the SQL statement <code>BACKUP TO</code> can not be used.
-</p>
-<p>
-When the zip file is created, you can open the database in the zip file using the following database URL:
-</p>
-<pre>
-jdbc:h2:zip:~/data.zip!/test
-</pre>
-<p>
-Databases in zip files are read-only. The performance for some queries will be slower than when using
-a regular database, because random access in zip files is not supported (only streaming). How much this
-affects the performance depends on the queries and the data. The database
-is not read in memory; therefore large databases are supported as well. The same indexes are used as when using
-a regular database.
-</p>
-<p>
-If the database is larger than a few megabytes, performance is much better if the database file is split into multiple smaller files,
-because random access in compressed files is not possible.
-See also the sample application <a href="https://github.com/h2database/h2database/tree/master/h2/src/test/org/h2/samples/ReadOnlyDatabaseInZip.java">ReadOnlyDatabaseInZip</a>.
-</p>
-
-<h3>Opening a Corrupted Database</h3>
-<p>
-If a database cannot be opened because the boot info (the SQL script that is run at startup)
-is corrupted, then the database can be opened by specifying a database event listener.
-The exceptions are logged, but opening the database will continue.
-</p>
-
-<h2 id="computed_columns">Computed Columns / Function Based Index</h2>
-<p>
-A computed column is a column whose value is calculated before storing.
-The formula is evaluated when the row is inserted, and re-evaluated every time the row is updated.
-One use case is to automatically update the last-modification time:
-</p>
-<pre>
-CREATE TABLE TEST(ID INT, NAME VARCHAR, LAST_MOD TIMESTAMP AS NOW());
-</pre>
-<p>
-Function indexes are not directly supported by this database, but they can be emulated
-by using computed columns. For example, if an index on the upper-case version of
-a column is required, create a computed column with the upper-case version of the original column,
-and create an index for this column:
-</p>
-<pre>
-CREATE TABLE ADDRESS(
-    ID INT PRIMARY KEY,
-    NAME VARCHAR,
-    UPPER_NAME VARCHAR AS UPPER(NAME)
-);
-CREATE INDEX IDX_U_NAME ON ADDRESS(UPPER_NAME);
-</pre>
-<p>
-When inserting data, it is not required (and not allowed) to specify a value for the upper-case
-version of the column, because the value is generated. But you can use the
-column when querying the table:
-</p>
-<pre>
-INSERT INTO ADDRESS(ID, NAME) VALUES(1, 'Miller');
-SELECT * FROM ADDRESS WHERE UPPER_NAME='MILLER';
-</pre>
-
-<h2 id="multi_dimensional">Multi-Dimensional Indexes</h2>
-<p>
-A tool is provided to execute efficient multi-dimension (spatial) range queries.
-This database does not support a specialized spatial index (R-Tree or similar).
-Instead, the B-Tree index is used. For each record, the multi-dimensional key
-is converted (mapped) to a single dimensional (scalar) value.
-This value specifies the location on a space-filling curve.
-</p><p>
-Currently, Z-order (also called N-order or Morton-order) is used;
-Hilbert curve could also be used, but the implementation is more complex.
-The algorithm to convert the multi-dimensional value is called bit-interleaving.
-The scalar value is indexed using a B-Tree index (usually using a computed column).
-</p><p>
-The method can result in a drastic performance improvement
-over just using an index on the first column. Depending on the
-data and number of dimensions, the improvement is usually higher than factor 5.
-The tool generates a SQL query from a specified multi-dimensional range.
-The method used is not database dependent, and the tool can easily be ported to other databases.
-For an example how to use the tool, please have a look at the sample code provided
-in <code>TestMultiDimension.java</code>.
-</p>
-
-<h2 id="user_defined_functions">User-Defined Functions and Stored Procedures</h2>
-<p>
-In addition to the built-in functions, this database supports user-defined Java functions.
-In this database, Java functions can be used as stored procedures as well.
-A function must be declared (registered) before it can be used.
-A function can be defined using source code, or as a reference to
-a compiled class that is available in the classpath. By default, the
-function aliases are stored in the current schema.
-</p>
-
-<h3>Referencing a Compiled Method</h3>
-<p>
-When referencing a method, the class must already be compiled and
-included in the classpath where the database is running.
-Only static Java methods are supported; both the class and the method must be public.
-Example Java class:
-</p>
-<pre>
-package acme;
-import java.math.*;
-public class Function {
-    public static boolean isPrime(int value) {
-        return new BigInteger(String.valueOf(value)).isProbablePrime(100);
-    }
-}
-</pre>
-<p>
-The Java function must be registered in the database by calling <code>CREATE ALIAS ... FOR</code>:
-</p>
-<pre>
-CREATE ALIAS IS_PRIME FOR "acme.Function.isPrime";
-</pre>
-<p>
-For a complete sample application, see <code>src/test/org/h2/samples/Function.java</code>.
-</p>
-
-<h3>Declaring Functions as Source Code</h3>
-<p>
-When defining a function alias with source code, the database tries to compile
-the source code using the Sun Java compiler (the class <code>com.sun.tools.javac.Main</code>)
-if the <code>tools.jar</code> is in the classpath. If not, <code>javac</code> is run as a separate process.
-Only the source code is stored in the database; the class is compiled each time the database is re-opened.
-Source code is usually passed as dollar quoted text to avoid escaping problems, however single quotes can be used as well.
-Example:
-</p>
-<pre>
-CREATE ALIAS NEXT_PRIME AS $$
-String nextPrime(String value) {
-    return new BigInteger(value).nextProbablePrime().toString();
-}
-$$;
-</pre>
-<p>
-By default, the three packages <code>java.util, java.math, java.sql</code> are imported.
-The method name (<code>nextPrime</code> in the example above) is ignored.
-Method overloading is not supported when declaring functions as source code, that means only one method may be declared for an alias.
-If different import statements are required, they must be declared at the beginning
-and separated with the tag <code>@CODE</code>:
-</p>
-<pre>
-CREATE ALIAS IP_ADDRESS AS $$
-import java.net.*;
-@CODE
-String ipAddress(String host) throws Exception {
-    return InetAddress.getByName(host).getHostAddress();
-}
-$$;
-</pre>
-<p>
-The following template is used to create a complete Java class:
-</p>
-<pre>
-package org.h2.dynamic;
-&lt; import statements before the tag @CODE; if not set:
-import java.util.*;
-import java.math.*;
-import java.sql.*;
-&gt;
-public class &lt;aliasName&gt; {
-    public static &lt;sourceCode&gt;
-}
-</pre>
-
-<h3>Method Overloading</h3>
-<p>
-Multiple methods may be bound to a SQL function if the class is already compiled and included in the classpath.
-Each Java method must have a different number of arguments.
-Method overloading is not supported when declaring functions as source code.
-</p>
-
-<h3>Function Data Type Mapping</h3>
-<p>
-Functions that accept non-nullable parameters such as <code>int</code>
-will not be called if one of those parameters is <code>NULL</code>.
-Instead, the result of the function is <code>NULL</code>.
-If the function should be called if a parameter is <code>NULL</code>, you need
-to use <code>java.lang.Integer</code> instead.
-</p>
-<p>
-SQL types are mapped to Java classes and vice-versa as in the JDBC API. For details, see <a href="datatypes.html">Data Types</a>.
-There are a few special cases: <code>java.lang.Object</code> is mapped to
-<code>OTHER</code> (a serialized object). Therefore,
-<code>java.lang.Object</code> can not be used
-to match all SQL types (matching all SQL types is not supported). The second special case is <code>Object[]</code>:
-arrays of any class are mapped to <code>ARRAY</code>.
-Objects of type <code>org.h2.value.Value</code> (the internal value class) are passed through without conversion.
-</p>
-
-<h3>Functions That Require a Connection</h3>
-<p>
-If the first parameter of a Java function is a <code>java.sql.Connection</code>, then the connection
-to database is provided. This connection does not need to be closed before returning.
-When calling the method from within the SQL statement, this connection parameter
-does not need to be (can not be) specified.
-</p>
-
-<h3>Functions Throwing an Exception</h3>
-<p>
-If a function throws an exception, then the current statement is rolled back
-and the exception is thrown to the application.
-SQLException are directly re-thrown to the calling application;
-all other exceptions are first converted to a SQLException.
-</p>
-
-<h3>Functions Returning a Result Set</h3>
-<p>
-Functions may returns a result set. Such a function can be called with the <code>CALL</code> statement:
-</p>
-<pre>
-public static ResultSet query(Connection conn, String sql) throws SQLException {
-    return conn.createStatement().executeQuery(sql);
-}
-
-CREATE ALIAS QUERY FOR "org.h2.samples.Function.query";
-CALL QUERY('SELECT * FROM TEST');
-</pre>
-
-<h3>Using SimpleResultSet</h3>
-<p>
-A function can create a result set using the <code>SimpleResultSet</code> tool:
-</p>
-<pre>
-import org.h2.tools.SimpleResultSet;
-...
-public static ResultSet simpleResultSet() throws SQLException {
-    SimpleResultSet rs = new SimpleResultSet();
-    rs.addColumn("ID", Types.INTEGER, 10, 0);
-    rs.addColumn("NAME", Types.VARCHAR, 255, 0);
-    rs.addRow(0, "Hello");
-    rs.addRow(1, "World");
-    return rs;
-}
-
-CREATE ALIAS SIMPLE FOR "org.h2.samples.Function.simpleResultSet";
-CALL SIMPLE();
-</pre>
-
-<h3>Using a Function as a Table</h3>
-<p>
-A function that returns a result set can be used like a table.
-However, in this case the function is called at least twice:
-first while parsing the statement to collect the column names
-(with parameters set to <code>null</code> where not known at compile time).
-And then, while executing the statement to get the data (maybe multiple times if this is a join).
-If the function is called just to get the column list, the URL of the connection passed to the function is
-<code>jdbc:columnlist:connection</code>. Otherwise, the URL of the connection is
-<code>jdbc:default:connection</code>.
-</p>
-<pre>
-public static ResultSet getMatrix(Connection conn, Integer size)
-        throws SQLException {
-    SimpleResultSet rs = new SimpleResultSet();
-    rs.addColumn("X", Types.INTEGER, 10, 0);
-    rs.addColumn("Y", Types.INTEGER, 10, 0);
-    String url = conn.getMetaData().getURL();
-    if (url.equals("jdbc:columnlist:connection")) {
-        return rs;
-    }
-    for (int s = size.intValue(), x = 0; x &lt; s; x++) {
-        for (int y = 0; y &lt; s; y++) {
-            rs.addRow(x, y);
-        }
-    }
-    return rs;
-}
-
-CREATE ALIAS MATRIX FOR "org.h2.samples.Function.getMatrix";
-SELECT * FROM MATRIX(4) ORDER BY X, Y;
-</pre>
-
-
-<h2 id="pluggable_tables">Pluggable or User-Defined Tables</h2>
-<p>
-For situations where you need to expose other data-sources to the SQL engine as a table,
-there are "pluggable tables".
-For some examples, have a look at the code in <code>org.h2.test.db.TestTableEngines</code>.
-</p>
-<p>
-In order to create your own TableEngine, you need to implement the <code>org.h2.api.TableEngine</code> interface e.g.
-something like this:
-</p>
-<pre>
-package acme;
-public static class MyTableEngine implements org.h2.api.TableEngine {
-
-    private static class MyTable extends org.h2.table.TableBase {
-        .. rather a lot of code here...
-    }
-
-    public EndlessTable createTable(CreateTableData data) {
-        return new EndlessTable(data);
-    }
-}
-</pre>
-<p>
-and then create the table from SQL like this:
-</p>
-<pre>
-CREATE TABLE TEST(ID INT, NAME VARCHAR)
-    ENGINE "acme.MyTableEngine";
-</pre>
-<p>
-It is also possible to pass in parameters to the table engine, like so:
-</p>
-<pre>
-CREATE TABLE TEST(ID INT, NAME VARCHAR) ENGINE "acme.MyTableEngine" WITH "param1", "param2";
-</pre>
-<p>
-In which case the parameters are passed down in the tableEngineParams field of the CreateTableData object.
-</p>
-<p>
-It is also possible to specify default table engine params on schema creation:
-</p>
-<pre>
-CREATE SCHEMA TEST_SCHEMA WITH "param1", "param2";
-</pre>
-<p>
-Params from the schema are used when CREATE TABLE issued on this schema does not have its own engine params specified.
-</p>
-
-<h2 id="triggers">Triggers</h2>
-<p>
-This database supports Java triggers that are called before or after a row is updated, inserted or deleted.
-Triggers can be used for complex consistency checks, or to update related data in the database.
-It is also possible to use triggers to simulate materialized views.
-For a complete sample application, see <code>src/test/org/h2/samples/TriggerSample.java</code>.
-A Java trigger must implement the interface <code>org.h2.api.Trigger</code>. The trigger class must be available
-in the classpath of the database engine (when using the server mode, it must be in the classpath
-of the server).
-</p>
-<pre>
-import org.h2.api.Trigger;
-...
-public class TriggerSample implements Trigger {
-
-    public void init(Connection conn, String schemaName, String triggerName,
-            String tableName, boolean before, int type) {
-        // initialize the trigger object is necessary
-    }
-
-    public void fire(Connection conn,
-            Object[] oldRow, Object[] newRow)
-            throws SQLException {
-        // the trigger is fired
-    }
-
-    public void close() {
-        // the database is closed
-    }
-
-    public void remove() {
-        // the trigger was dropped
-    }
-
-}
-</pre>
-<p>
-The connection can be used to query or update data in other tables.
-The trigger then needs to be defined in the database:
-</p>
-<pre>
-CREATE TRIGGER INV_INS AFTER INSERT ON INVOICE
-    FOR EACH ROW CALL "org.h2.samples.TriggerSample"
-</pre>
-<p>
-The trigger can be used to veto a change by throwing a <code>SQLException</code>.
-</p>
-<p>
-As an alternative to implementing the <code>Trigger</code> interface,
-an application can extend the abstract class <code>org.h2.tools.TriggerAdapter</code>.
-This will allows to use the <code>ResultSet</code> interface within trigger implementations.
-In this case, only the <code>fire</code> method needs to be implemented:
-</p>
-<pre>
-import org.h2.tools.TriggerAdapter;
-...
-public class TriggerSample extends TriggerAdapter {
-
-    public void fire(Connection conn, ResultSet oldRow, ResultSet newRow)
-            throws SQLException {
-        // the trigger is fired
-    }
-
-}
-</pre>
-
-<h2 id="compacting">Compacting a Database</h2>
-<p>
-Empty space in the database file re-used automatically. When closing the database,
-the database is automatically compacted for up to 200 milliseconds by default. To compact more,
-use the SQL statement SHUTDOWN COMPACT. However re-creating the database may further
-reduce the database size because this will re-build the indexes.
-Here is a sample function to do this:
-</p>
-<pre>
-public static void compact(String dir, String dbName,
-        String user, String password) throws Exception {
-    String url = "jdbc:h2:" + dir + "/" + dbName;
-    String file = "data/test.sql";
-    Script.execute(url, user, password, file);
-    DeleteDbFiles.execute(dir, dbName, true);
-    RunScript.execute(url, user, password, file, null, false);
-}
-</pre>
-<p>
-See also the sample application <code>org.h2.samples.Compact</code>.
-The commands <code>SCRIPT / RUNSCRIPT</code> can be used as well to create a backup
-of a database and re-build the database from the script.
-</p>
-
-<h2 id="cache_settings">Cache Settings</h2>
-<p>
-The database keeps most frequently used data in the main memory.
-The amount of memory used for caching can be changed using the setting
-<code>CACHE_SIZE</code>. This setting can be set in the database connection URL
-(<code>jdbc:h2:~/test;CACHE_SIZE=131072</code>), or it can be changed at runtime using
-<code>SET CACHE_SIZE size</code>.
-The size of the cache, as represented by <code>CACHE_SIZE</code> is measured in KB, with each KB being 1024 bytes.
-This setting has no effect for in-memory databases.
-For persistent databases, the setting is stored in the database and re-used when the database is opened
-the next time. However, when opening an existing database, the cache size is set to at most
-half the amount of memory available for the virtual machine (Runtime.getRuntime().maxMemory()),
-even if the cache size setting stored in the database is larger; however the setting stored in the database
-is kept. Setting the cache size in the database URL or explicitly using <code>SET CACHE_SIZE</code>
-overrides this value (even if larger than the physical memory).
-To get the current used maximum cache size, use the query
-<code>SELECT * FROM INFORMATION_SCHEMA.SETTINGS WHERE NAME = 'info.CACHE_MAX_SIZE'</code>
-</p><p>
-An experimental scan-resistant cache algorithm "Two Queue" (2Q) is available.
-To enable it, append <code>;CACHE_TYPE=TQ</code> to the database URL.
-The cache might not actually improve performance.
-If you plan to use it, please run your own test cases first.
-</p><p>
-Also included is an experimental second level soft reference cache.
-Rows in this cache are only garbage collected on low memory.
-By default the second level cache is disabled.
-To enable it, use the prefix <code>SOFT_</code>.
-Example: <code>jdbc:h2:~/test;CACHE_TYPE=SOFT_LRU</code>.
-The cache might not actually improve performance.
-If you plan to use it, please run your own test cases first.
-</p><p>
-To get information about page reads and writes, and the current caching algorithm in use,
-call <code>SELECT * FROM INFORMATION_SCHEMA.SETTINGS</code>. The number of pages read / written
-is listed.
-</p>
-<h2 id="external_authentication">External authentication (Experimental)</h2>
-<p>
-External authentication allows to optionally validate user credentials externally (JAAS,LDAP,custom classes).
-Is also possible to temporary assign roles to externally authenticated users.  <b>This feature is experimental and subject to change</b>
-</p>
-<p>Master user cannot be externally authenticated</p>
-<p>
-To enable external authentication on a database execute statement <code>SET AUTHENTICATOR TRUE</code>. This setting in persisted on the database.
-</p>
-<p>
-To connect on a database by using external credentials client must append <code>AUTHREALM=H2</code> to the database URL. <code>H2</code>
-is the identifier of the authentication realm (see later).
-</p>
-<p>External authentication requires to send password to the server. For this reason is works only on local connection or remote over ssl</p>
-<p>
-By default external authentication is performed through JAAS login interface (configuration name is <code>h2</code>).
-To configure JAAS add argument <code>-Djava.security.auth.login.config=jaas.conf</code>
-Here an example of <a href="https://docs.oracle.com/javase/7/docs/technotes/guides/security/jgss/tutorials/LoginConfigFile.html">
-JAAS login configuration file</a> content:
-</p>
-<pre>
-h2 {
-    com.sun.security.auth.module.LdapLoginModule REQUIRED \
-    userProvider="ldap://127.0.0.1:10389" authIdentity="uid={USERNAME},ou=people,dc=example,dc=com" \
-    debug=true useSSL=false ;
-};
-</pre>
-<p>
-Is it possible to specify custom authentication settings by using
-JVM argument <code>-Dh2auth.configurationFile={urlOfH2Auth.xml}</code>. Here an example of h2auth.xml file content:
-</p>
-<pre>
-&lt;h2Auth allowUserRegistration="false" createMissingRoles="true"&gt;
-
-    &lt;!-- realm: DUMMY authenticate users named DUMMY[0-9] with a static password --&gt;
-    &lt;realm name="DUMMY"
-    validatorClass="org.h2.security.auth.impl.FixedPasswordCredentialsValidator"&gt;
-        &lt;property name="userNamePattern" value="DUMMY[0-9]" /&gt;
-        &lt;property name="password" value="mock" /&gt;
-    &lt;/realm&gt;
-
-    &lt;!-- realm LDAPEXAMPLE:perform credentials validation on LDAP --&gt;
-    &lt;realm name="LDAPEXAMPLE"
-    validatorClass="org.h2.security.auth.impl.LdapCredentialsValidator"&gt;
-        &lt;property name="bindDnPattern" value="uid=%u,ou=people,dc=example,dc=com" /&gt;
-        &lt;property name="host" value="127.0.0.1" /&gt;
-        &lt;property name="port" value="10389" /&gt;
-        &lt;property name="secure" value="false" /&gt;
-    &lt;/realm&gt;
-
-    &lt;!-- realm JAAS: perform credentials validation by using JAAS api --&gt;
-    &lt;realm name="JAAS"
-    validatorClass="org.h2.security.auth.impl.JaasCredentialsValidator"&gt;
-        &lt;property name="appName" value="H2" /&gt;
-    &lt;/realm&gt;
-
-    &lt;!--Assign to each user role @{REALM} --&gt;
-    &lt;userToRolesMapper class="org.h2.security.auth.impl.AssignRealmNameRole"/&gt;
-
-    &lt;!--Assign to each user role REMOTEUSER --&gt;
-    &lt;userToRolesMapper class="org.h2.security.auth.impl.StaticRolesMapper"&gt;
-        &lt;property name="roles" value="REMOTEUSER"/&gt;
-    &lt;/userToRolesMapper&gt;
-&lt;/h2Auth&gt;
-</pre>
-<p>
-Custom credentials validators must implement the interface
-<code>org.h2.api.CredentialsValidator</code>
-</p>
-<p>
-Custom criteria for role assignments must implement the interface
-<code>org.h2.api.UserToRoleMapper</code>
-</p>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
-
diff --git a/modules/h2/src/docsrc/html/fragments.html b/modules/h2/src/docsrc/html/fragments.html
deleted file mode 100644
index 3a2aa0c..0000000
--- a/modules/h2/src/docsrc/html/fragments.html
+++ /dev/null
@@ -1,130 +0,0 @@
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html><head>
-    <meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-    <meta name="viewport" content="width=device-width, initial-scale=1" />
-    <title>Fragments</title>
-
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="highlight()" onscroll="scroll()">
-
-<table class="nav" onmousemove="return mouseMove(event)"><tr class="nav"><td class="nav" valign="top">
-<div id = "searchMenu" style="width: 180px; overflow: hidden;">
-<div class="menu" style="white-space:nowrap;">
-<img src="images/h2-logo-2.png"
-    alt="H2 database logo"
-    onclick="document.location='main.html'"
-    width="136" height="74"/>
-&nbsp;&nbsp;<span id = "goTop" onclick="window.scrollTo(0,0)" style="color: #fff; position:fixed; font-size: 20px; cursor: pointer;">&#x25b2;</span>
-</div>
-
-<form action="submit" onsubmit="return goFirst();">
-<table width="100%" class="search">
-    <tr class="search">
-        <td class="search" colspan="2">
-<!-- translate
-<a href="http://translate.google.com/translate?u=http%3A%2F%2Fh2database.com"
-    onclick="javascript:startTranslate();return false;">Translate</a>
-<div id = "translate" style="display:none"><div id = "google_translate_element"></div></div>
-translate -->
-        </td>
-    </tr>
-    <tr class="search">
-        <td class="search" colspan="2">
-        <b><label for="search">Search:</label></b>
-        </td>
-    </tr>
-    <tr class="search">
-        <td class="search" colspan="2">
-            <input id = "search" name="search" type="text" size="16" maxlength="100" onkeyup="listWords(this.value, '')" /><br />
-            <input type="reset" id = "clear" style="display:none;" value="Clear" onclick="listWords('', '');" />
-        </td>
-    </tr>
-    <tr class="search" style="display:none;" >
-        <td class="search" style="width: 1%; vertical-align: middle;">
-            <input id = "highlight" type="checkbox" checked="checked" onclick="highlightCurrent(this.checked, search.value)" />
-        </td>
-        <td class="search" style="width: 99%; padding: 0px; vertical-align: middle;">
-            <label for="highlight">Highlight keyword(s)</label>
-        </td>
-    </tr>
-    <tr class="search">
-        <td class="search" colspan="2">
-            <table id = "result" style="border: 0px;">
-                <tr style="display:none"><td></td></tr>
-            </table>
-        </td>
-    </tr>
-</table>
-</form>
-<div class="menu">
-<b><a href="main.html">Home</a></b><br />
-<a href="download.html">Download</a><br />
-<a href="cheatSheet.html">Cheat Sheet</a><br />
-<br />
-<b>Documentation</b><br />
-<a href="quickstart.html">Quickstart</a><br />
-<a href="installation.html">Installation</a><br />
-<a href="tutorial.html">Tutorial</a><br />
-<a href="features.html">Features</a><br />
-<a href="performance.html">Performance</a><br />
-<a href="advanced.html">Advanced</a><br />
-<br />
-<b>Reference</b><br />
-<a href="commands.html">Commands</a><br />
-<a href="functions.html">Functions</a><br />
-<a href="datatypes.html">Data Types</a><br />
-<a href="grammar.html">SQL Grammar</a><br />
-<a href="systemtables.html">System Tables</a><br />
-<a href="../javadoc/index.html">Javadoc</a><br />
-<a href="../h2.pdf">PDF (1.5 MB)</a><br />
-<br />
-<b>Support</b><br />
-<a href="faq.html">FAQ</a><br />
-<a href="sourceError.html">Error Analyzer</a><br />
-<a href="https://groups.google.com/group/h2-database">Google Group (English)</a><br />
-<a href="https://groups.google.co.jp/group/h2-database-jp">Google Group (Japanese)</a><br />
-<a href="https://groups.google.com/group/h2-cn">Google Group (Chinese)</a><br />
-<br />
-<b>Appendix</b><br />
-<a href="history.html">History &amp; Roadmap</a><br />
-<a href="license.html">License</a><br />
-<a href="build.html">Build</a><br />
-<a href="links.html">Links</a><br />
-<a href="mvstore.html">MVStore</a><br />
-<a href="architecture.html">Architecture</a><br />
-<br />
-
-</div>
-</div>
-</td>
-
-<td class="nav" style="cursor: e-resize;" onmousedown="return mouseDown(event)" onmouseup="return mouseUp(event)">&nbsp;</td>
-<td class="nav"><div class="content">
-
-<!-- } -->
-
-<!-- [close] { -->
-</div></td></tr></table>
-<script type="text/javascript" src="index.js"></script>
-<script type="text/javascript" src="search.js"></script>
-<script type="text/javascript">
-function startTranslate() {
-    document.getElementById('translate').style.display='';
-    var script=document.createElement('script');
-    script.setAttribute("type","text/javascript");
-    script.setAttribute("src", "http://translate.google.com/translate_a/element.js?cb=googleTranslateElementInit");
-    document.getElementsByTagName("head")[0].appendChild(script);
-}
-function googleTranslateElementInit() {
-    new google.translate.TranslateElement({pageLanguage: 'en'}, 'google_translate_element');
-}
-</script>
-
-<!-- } -->
-
-</body></html>
\ No newline at end of file
diff --git a/modules/h2/src/docsrc/html/frame.html b/modules/h2/src/docsrc/html/frame.html
deleted file mode 100644
index ffa95da..0000000
--- a/modules/h2/src/docsrc/html/frame.html
+++ /dev/null
@@ -1,40 +0,0 @@
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html><head>
-    <meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-    <meta name="viewport" content="width=device-width, initial-scale=1" />
-    <title>H2 Database Engine</title>
-    <link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<script type="text/javascript">
-location.href = 'main.html';
-</script>
-</head>
-<body style="margin: 20px;">
-
-<h1>H2 Database Engine</h1>
-<p>
-Welcome to H2, the free SQL database. The main feature of H2 are:
-</p>
-<ul>
-<li>It is free to use for everybody, source code is included
-</li><li>Written in Java, but also available as native executable
-</li><li>JDBC and (partial) ODBC API
-</li><li>Embedded and client/server modes
-</li><li>Clustering is supported
-</li><li>A web client is included
-</li></ul>
-
-<h2>No Javascript</h2>
-<p>
-If you are not automatically redirected to the main page, then
-Javascript is currently disabled or your browser does not support Javascript.
-Some features (for example the integrated search) require Javascript.
-</p><p>
-Please enable Javascript, or go ahead without it:
-<a href="main.html" style="font-size: 16px; font-weight: bold">H2 Database Engine</a>
-</p>
-
-</body></html>
\ No newline at end of file
diff --git a/modules/h2/src/docsrc/html/functions.html b/modules/h2/src/docsrc/html/functions.html
deleted file mode 100644
index 785fed9..0000000
--- a/modules/h2/src/docsrc/html/functions.html
+++ /dev/null
@@ -1,324 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Functions
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>Functions</h1>
-<h2 id="functions_index">Index</h2>
-<h3>Aggregate Functions</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="functionsAggregate">
-    <a href="#${item.link}" >${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="functionsAggregate-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsAggregate-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsAggregate-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<h3>Numeric Functions</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="functionsNumeric">
-    <a href="#${item.link}" >${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="functionsNumeric-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsNumeric-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsNumeric-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<h3>String Functions</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="functionsString">
-    <a href="#${item.link}" >${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="functionsString-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsString-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsString-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<h3>Time and Date Functions</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="functionsTimeDate">
-    <a href="#${item.link}" >${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="functionsTimeDate-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsTimeDate-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsTimeDate-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<h3>System Functions</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="functionsSystem">
-    <a href="#${item.link}" >${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="functionsSystem-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsSystem-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsSystem-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<h3>Window Functions</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="functionsWindow">
-    <a href="#${item.link}" >${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="functionsWindow-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsWindow-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="functionsWindow-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<!-- railroad-start -->
-<h2>Details</h2>
-<p>Click on the header to switch between railroad diagram and BNF.</p>
-<!-- railroad-end -->
-
-<h2>Aggregate Functions</h2>
-<c:forEach var="item" items="functionsAggregate">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">${item.example}</p>
-</c:forEach>
-
-<h2>Numeric Functions</h2>
-<c:forEach var="item" items="functionsNumeric">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">${item.example}</p>
-</c:forEach>
-
-<h2>String Functions</h2>
-<c:forEach var="item" items="functionsString">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">${item.example}</p>
-</c:forEach>
-
-<h2>Time and Date Functions</h2>
-<c:forEach var="item" items="functionsTimeDate">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">${item.example}</p>
-</c:forEach>
-
-<h2>System Functions</h2>
-<c:forEach var="item" items="functionsSystem">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">${item.example}</p>
-</c:forEach>
-
-<h2>Window Functions</h2>
-<c:forEach var="item" items="functionsWindow">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">${item.example}</p>
-</c:forEach>
-
-<!--[if lte IE 7]><script language="javascript">switchBnf(null);</script><![endif]-->
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
-
diff --git a/modules/h2/src/docsrc/html/grammar.html b/modules/h2/src/docsrc/html/grammar.html
deleted file mode 100644
index 7cc2380..0000000
--- a/modules/h2/src/docsrc/html/grammar.html
+++ /dev/null
@@ -1,178 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-SQL Grammar
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>SQL Grammar</h1>
-<h2 id="grammar_index">Index</h2>
-<h3>Literals</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="literals">
-    <a href="#${item.link}">${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="literals-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="literals-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="literals-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<h3>Datetime fields</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="datetimeFields">
-    <a href="#${item.link}">${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="datetimeFields-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="datetimeFields-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="datetimeFields-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<h3>Other Grammar</h3>
-<!-- syntax-start
-<p class="notranslate">
-<c:forEach var="item" items="otherGrammar">
-    <a href="#${item.link}" >${item.topic}</a><br />
-</c:forEach>
-</p>
-syntax-end -->
-<!-- railroad-start -->
-<table class="notranslate index">
-    <tr>
-        <td class="index">
-            <c:forEach var="item" items="otherGrammar-0">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="otherGrammar-1">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td><td class="index">
-            <c:forEach var="item" items="otherGrammar-2">
-                <a href="#${item.link}" >${item.topic}</a><br />
-            </c:forEach>
-        </td>
-    </tr>
-</table>
-<!-- railroad-end -->
-
-<!-- railroad-start -->
-<h2>Details</h2>
-<p>Click on the header to switch between railroad diagram and BNF.</p>
-<!-- railroad-end -->
-
-<h2>Literals</h2>
-<c:forEach var="item" items="literals">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">
-${item.example}</p>
-</c:forEach>
-
-<h2>Datetime fields</h2>
-<c:forEach var="item" items="datetimeFields">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">
-${item.example}</p>
-</c:forEach>
-
-<h2>Other Grammar</h2>
-<c:forEach var="item" items="otherGrammar">
-<h3 id="${item.link}" class="notranslate" onclick="switchBnf(this)">${item.topic}</h3>
-<!-- railroad-start -->
-<pre name="bnf" style="display: none">
-${item.syntax}
-</pre>
-<div name="railroad">
-${item.railroad}
-</div>
-<!-- railroad-end -->
-<!-- syntax-start
-<pre>
-${item.syntax}
-</pre>
-syntax-end -->
-<p>${item.text}</p>
-<p>Example:</p>
-<p class="notranslate">${item.example}</p>
-</c:forEach>
-
-<!--[if lte IE 7]><script language="javascript">switchBnf(null);</script><![endif]-->
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
diff --git a/modules/h2/src/docsrc/html/history.html b/modules/h2/src/docsrc/html/history.html
deleted file mode 100644
index dc398f4..0000000
--- a/modules/h2/src/docsrc/html/history.html
+++ /dev/null
@@ -1,182 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-History
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>History and Roadmap</h1>
-<a href="#changelog">
-    Change Log</a><br />
-<a href="#roadmap">
-    Roadmap</a><br />
-<a href="#history">
-    History of this Database Engine</a><br />
-<a href="#why_java">
-    Why Java</a><br />
-<a href="#supporters">
-    Supporters</a><br />
-
-<h2 id="changelog">Change Log</h2>
-<p>
-The up-to-date change log is available at
-<a href="http://www.h2database.com/html/changelog.html">
-http://www.h2database.com/html/changelog.html
-</a>
-</p>
-
-<h2 id="roadmap">Roadmap</h2>
-<p>
-The current roadmap is available at
-<a href="http://www.h2database.com/html/roadmap.html">
-http://www.h2database.com/html/roadmap.html
-</a>
-</p>
-
-<h2 id="history">History of this Database Engine</h2>
-<p>
-The development of H2 was started in May 2004,
-but it was first published on December 14th 2005.
-The original author of H2, Thomas Mueller, is also the original developer of Hypersonic SQL.
-In 2001, he joined PointBase Inc. where he wrote PointBase Micro, a commercial Java SQL database.
-At that point, he had to discontinue Hypersonic SQL. The HSQLDB Group was formed
-to continued to work on the Hypersonic SQL codebase.
-The name H2 stands for Hypersonic 2, however H2 does not share code with
-Hypersonic SQL or HSQLDB. H2 is built from scratch.
-</p>
-
-<h2 id="why_java">Why Java</h2>
-<p>
-The main reasons to use a Java database are:
-</p>
-<ul>
-<li>Very simple to integrate in Java applications
-</li><li>Support for many different platforms
-</li><li>More secure than native applications (no buffer overflows)
-</li><li>User defined functions (or triggers) run very fast
-</li><li>Unicode support
-</li></ul>
-<p>
-Some think Java is too slow for low level operations,
-but this is no longer true. Garbage collection for example is
-now faster than manual memory management.
-</p><p>
-Developing Java code is faster than developing C or C++ code. When using Java,
-most time can be spent on improving the algorithms instead of
-porting the code to different platforms or doing memory management.
-Features such as Unicode and network libraries are already built-in.
-In Java, writing secure code is easier because buffer overflows can not occur.
-Features such as reflection can be used for randomized testing.
-</p><p>
-Java is future proof: a lot of companies support Java. Java is now open source.
-</p><p>
-To increase the portability and ease of use, this software depends on
-very few libraries. Features that are not available in open source
-Java implementations (such as Swing) are not used, or only used for optional features.
-</p>
-
-<h2 id="supporters">Supporters</h2>
-<p>
-Many thanks for those who reported bugs, gave valuable feedback,
-spread the word, and translated this project.
-</p>
-<p>
-Also many thanks to the donors.
-To become a donor, use PayPal (at the very bottom of the main web page).
-Donators are:
-</p>
-<ul>
-<li>Martin Wildam, Austria
-</li><li><a href="http://www.tagtraum.com">tagtraum industries incorporated, USA</a>
-</li><li><a href="http://www.timewriter.com">TimeWriter, Netherlands</a>
-</li><li><a href="http://cognitect.com">Cognitect, USA</a>
-</li><li><a href="http://www.code42.com">Code 42 Software, Inc., Minneapolis</a>
-</li><li><a href="http://www.codelutin.com">Code Lutin, France</a>
-</li><li><a href="http://www.netsuxxess.de">NetSuxxess GmbH, Germany</a>
-</li><li><a href="http://pokercopilot.com">Poker Copilot, Steve McLeod, Germany</a>
-</li><li><a href="http://skycash.com">SkyCash, Poland</a>
-</li><li><a href="http://lumber-mill.co.jp">Lumber-mill, Inc., Japan</a>
-</li><li><a href="http://www.stockmarketeye.com">StockMarketEye, USA</a>
-</li><li><a href="http://www.eckenfelder.de">Eckenfelder GmbH &amp; Co.KG, Germany</a>
-</li><li>Jun Iyama, Japan
-</li><li>Steven Branda, USA
-</li><li>Anthony Goubard, Netherlands
-</li><li>Richard Hickey, USA
-</li><li>Alessio Jacopo D'Adamo, Italy
-</li><li>Ashwin Jayaprakash, USA
-</li><li>Donald Bleyl, USA
-</li><li>Frank Berger, Germany
-</li><li>Florent Ramiere, France
-</li><li>Antonio Casqueiro, Portugal
-</li><li>Oliver Computing LLC, USA
-</li><li>Harpal Grover Consulting Inc., USA
-</li><li>Elisabetta Berlini, Italy
-</li><li>William Gilbert, USA
-</li><li>Antonio Dieguez Rojas, Chile
-</li><li><a href="http://ontologyworks.com">Ontology Works, USA</a>
-</li><li>Pete Haidinyak, USA
-</li><li>William Osmond, USA
-</li><li>Joachim Ansorg, Germany
-</li><li>Oliver Soerensen, Germany
-</li><li>Christos Vasilakis, Greece
-</li><li>Fyodor Kupolov, Denmark
-</li><li>Jakob Jenkov, Denmark
-</li><li>St&eacute;phane Chartrand, Switzerland
-</li><li>Glenn Kidd, USA
-</li><li>Gustav Trede, Sweden
-</li><li>Joonas Pulakka, Finland
-</li><li>Bjorn Darri Sigurdsson, Iceland
-</li><li>Gray Watson, USA
-</li><li>Erik Dick, Germany
-</li><li>Pengxiang Shao, China
-</li><li>Bilingual Marketing Group, USA
-</li><li>Philippe Marschall, Switzerland
-</li><li>Knut Staring, Norway
-</li><li>Theis Borg, Denmark
-</li><li>Mark De Mendonca Duske, USA
-</li><li>Joel A. Garringer, USA
-</li><li>Olivier Chafik, France
-</li><li>Rene Schwietzke, Germany
-</li><li>Jalpesh Patadia, USA
-</li><li>Takanori Kawashima, Japan
-</li><li>Terrence JC Huang, China
-</li><li><a href="http://www.FairGo128.com">JiaDong Huang, Australia</a>
-</li><li>Laurent van Roy, Belgium
-</li><li>Qian Chen, China
-</li><li>Clinton Hyde, USA
-</li><li>Kritchai Phromros, Thailand
-</li><li>Alan Thompson, USA
-</li><li>Ladislav Jech, Czech Republic
-</li><li>Dimitrijs Fedotovs, Latvia
-</li><li>Richard Manley-Reeve, United Kingdom
-</li><li>Daniel Cyr, ThirdHalf.com, LLC, USA
-</li><li>Peter J&uuml;nger, Germany
-</li><li>Dan Keegan, USA
-</li><li>Rafel Israels, Germany
-</li><li>Fabien Todescato, France
-</li><li>Cristan Meijer, Netherlands
-</li><li>Adam McMahon, USA
-</li><li>F&aacute;bio Gomes Lisboa Gomes, Brasil
-</li><li>Lyderic Landry, England
-</li><li>Mederp, Morocco
-</li><li>Joaquim Golay, Switzerland
-</li><li>Clemens Quoss, Germany
-</li><li>Kervin Pierre, USA
-</li><li>Jake Bellotti, Australia
-</li><li>Arun Chittanoor, USA
-</li></ul>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
-
diff --git a/modules/h2/src/docsrc/html/images/connection-mode-embedded-2.png b/modules/h2/src/docsrc/html/images/connection-mode-embedded-2.png
deleted file mode 100644
index 7da33a3..0000000
Binary files a/modules/h2/src/docsrc/html/images/connection-mode-embedded-2.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/connection-mode-embedded.png b/modules/h2/src/docsrc/html/images/connection-mode-embedded.png
deleted file mode 100644
index ffbccfc..0000000
Binary files a/modules/h2/src/docsrc/html/images/connection-mode-embedded.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/connection-mode-mixed-2.png b/modules/h2/src/docsrc/html/images/connection-mode-mixed-2.png
deleted file mode 100644
index fd4afcd..0000000
Binary files a/modules/h2/src/docsrc/html/images/connection-mode-mixed-2.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/connection-mode-mixed.png b/modules/h2/src/docsrc/html/images/connection-mode-mixed.png
deleted file mode 100644
index a3a3970..0000000
Binary files a/modules/h2/src/docsrc/html/images/connection-mode-mixed.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/connection-mode-remote-2.png b/modules/h2/src/docsrc/html/images/connection-mode-remote-2.png
deleted file mode 100644
index b45dbb8..0000000
Binary files a/modules/h2/src/docsrc/html/images/connection-mode-remote-2.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/connection-mode-remote.png b/modules/h2/src/docsrc/html/images/connection-mode-remote.png
deleted file mode 100644
index 50bba17..0000000
Binary files a/modules/h2/src/docsrc/html/images/connection-mode-remote.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/console-2.png b/modules/h2/src/docsrc/html/images/console-2.png
deleted file mode 100644
index a713644..0000000
Binary files a/modules/h2/src/docsrc/html/images/console-2.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/console.png b/modules/h2/src/docsrc/html/images/console.png
deleted file mode 100644
index 39a7ef5..0000000
Binary files a/modules/h2/src/docsrc/html/images/console.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/db-16.png b/modules/h2/src/docsrc/html/images/db-16.png
deleted file mode 100644
index d5340e5..0000000
Binary files a/modules/h2/src/docsrc/html/images/db-16.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/db-64-t.png b/modules/h2/src/docsrc/html/images/db-64-t.png
deleted file mode 100644
index 3680773..0000000
Binary files a/modules/h2/src/docsrc/html/images/db-64-t.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/download-2.png b/modules/h2/src/docsrc/html/images/download-2.png
deleted file mode 100644
index 00e506a..0000000
Binary files a/modules/h2/src/docsrc/html/images/download-2.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/download.png b/modules/h2/src/docsrc/html/images/download.png
deleted file mode 100644
index 51748dc..0000000
Binary files a/modules/h2/src/docsrc/html/images/download.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/h2-logo-2.png b/modules/h2/src/docsrc/html/images/h2-logo-2.png
deleted file mode 100644
index d8025aa..0000000
Binary files a/modules/h2/src/docsrc/html/images/h2-logo-2.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/h2-logo.png b/modules/h2/src/docsrc/html/images/h2-logo.png
deleted file mode 100644
index 76402f0..0000000
Binary files a/modules/h2/src/docsrc/html/images/h2-logo.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/h2-logo_square.png b/modules/h2/src/docsrc/html/images/h2-logo_square.png
deleted file mode 100644
index 2714448..0000000
Binary files a/modules/h2/src/docsrc/html/images/h2-logo_square.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/icon_disconnect.gif b/modules/h2/src/docsrc/html/images/icon_disconnect.gif
deleted file mode 100644
index 2ece8d8..0000000
Binary files a/modules/h2/src/docsrc/html/images/icon_disconnect.gif and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/language_de.png b/modules/h2/src/docsrc/html/images/language_de.png
deleted file mode 100644
index 0109c35..0000000
Binary files a/modules/h2/src/docsrc/html/images/language_de.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/language_en.gif b/modules/h2/src/docsrc/html/images/language_en.gif
deleted file mode 100644
index a48f4ad..0000000
Binary files a/modules/h2/src/docsrc/html/images/language_en.gif and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/language_ja.gif b/modules/h2/src/docsrc/html/images/language_ja.gif
deleted file mode 100644
index 5e1d040..0000000
Binary files a/modules/h2/src/docsrc/html/images/language_ja.gif and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/mail-support.png b/modules/h2/src/docsrc/html/images/mail-support.png
deleted file mode 100644
index 8ff5349..0000000
Binary files a/modules/h2/src/docsrc/html/images/mail-support.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/paypal-donate.png b/modules/h2/src/docsrc/html/images/paypal-donate.png
deleted file mode 100644
index 793ef52..0000000
Binary files a/modules/h2/src/docsrc/html/images/paypal-donate.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/performance.png b/modules/h2/src/docsrc/html/images/performance.png
deleted file mode 100644
index 368fbf7..0000000
Binary files a/modules/h2/src/docsrc/html/images/performance.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/quickstart-1.png b/modules/h2/src/docsrc/html/images/quickstart-1.png
deleted file mode 100644
index 276680c..0000000
Binary files a/modules/h2/src/docsrc/html/images/quickstart-1.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/quickstart-2.png b/modules/h2/src/docsrc/html/images/quickstart-2.png
deleted file mode 100644
index ee9fd9d..0000000
Binary files a/modules/h2/src/docsrc/html/images/quickstart-2.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/quickstart-3.png b/modules/h2/src/docsrc/html/images/quickstart-3.png
deleted file mode 100644
index fba9e42..0000000
Binary files a/modules/h2/src/docsrc/html/images/quickstart-3.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/quickstart-4.png b/modules/h2/src/docsrc/html/images/quickstart-4.png
deleted file mode 100644
index 08a02b5be..0000000
Binary files a/modules/h2/src/docsrc/html/images/quickstart-4.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/quickstart-5.png b/modules/h2/src/docsrc/html/images/quickstart-5.png
deleted file mode 100644
index b2f007d..0000000
Binary files a/modules/h2/src/docsrc/html/images/quickstart-5.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/quickstart-6.png b/modules/h2/src/docsrc/html/images/quickstart-6.png
deleted file mode 100644
index e981477..0000000
Binary files a/modules/h2/src/docsrc/html/images/quickstart-6.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/images/screenshot.png b/modules/h2/src/docsrc/html/images/screenshot.png
deleted file mode 100644
index 9d7d7e6..0000000
Binary files a/modules/h2/src/docsrc/html/images/screenshot.png and /dev/null differ
diff --git a/modules/h2/src/docsrc/html/installation.html b/modules/h2/src/docsrc/html/installation.html
deleted file mode 100644
index 65c3f82..0000000
--- a/modules/h2/src/docsrc/html/installation.html
+++ /dev/null
@@ -1,122 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-Installation
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>Installation</h1>
-
-<a href="#requirements">
-    Requirements</a><br />
-<a href="#supported_platforms">
-    Supported Platforms</a><br />
-<a href="#installing">
-    Installing the Software</a><br />
-<a href="#directory_structure">
-    Directory Structure</a><br />
-
-<h2 id="requirements">Requirements</h2>
-<p>
-To run this database, the following software stack is known to work.
-Other software most likely also works, but is not tested as much.
-</p>
-
-<h3>Database Engine</h3>
-<ul><li>Windows XP or Vista, Mac OS X, or Linux
-</li><li>Oracle Java 7 or newer
-</li><li>Recommended Windows file system: NTFS (FAT32 only supports files up to 4 GB)
-</li></ul>
-
-<h3>H2 Console</h3>
-<ul><li>Mozilla Firefox
-</li></ul>
-
-<h2 id="supported_platforms">Supported Platforms</h2>
-<p>
-As this database is written in Java, it can run on many different platforms.
-It is tested with Java 7.
-Currently, the database is developed and tested on Windows 8
-and Mac OS X using Java 7, but it also works in many other operating systems
-and using other Java runtime environments.
-All major operating systems (Windows XP, Windows Vista, Windows 7, Mac OS, Ubuntu,...) are supported.
-</p>
-
-<h2 id="installing">Installing the Software</h2>
-<p>
-To install the software, run the installer or unzip it to a directory of your choice.
-</p>
-
-<h2 id="directory_structure">Directory Structure</h2>
-<p>
-After installing, you should get the following directory structure:
-</p>
-<table class="main">
-    <tr>
-        <th>Directory</th>
-        <th>Contents</th>
-    </tr>
-    <tr>
-        <td class="notranslate">bin</td>
-        <td>JAR and batch files</td>
-    </tr>
-    <tr>
-        <td class="notranslate">docs</td>
-        <td>Documentation</td>
-    </tr>
-    <tr>
-        <td class="notranslate">docs/html</td>
-        <td>HTML pages</td>
-    </tr>
-    <tr>
-        <td class="notranslate">docs/javadoc</td>
-        <td>Javadoc files</td>
-    </tr>
-    <tr>
-        <td class="notranslate">ext</td>
-        <td>External dependencies (downloaded when building)</td>
-    </tr>
-    <tr>
-        <td class="notranslate">service</td>
-        <td>Tools to run the database as a Windows Service</td>
-    </tr>
-    <tr>
-        <td class="notranslate">src</td>
-        <td>Source files</td>
-    </tr>
-    <tr>
-        <td class="notranslate">src/docsrc</td>
-        <td>Documentation sources</td>
-    </tr>
-    <tr>
-        <td class="notranslate">src/installer</td>
-        <td>Installer, shell, and release build script</td>
-    </tr>
-    <tr>
-        <td class="notranslate">src/main</td>
-        <td>Database engine source code</td>
-    </tr>
-    <tr>
-        <td class="notranslate">src/test</td>
-        <td>Test source code</td>
-    </tr>
-    <tr>
-        <td class="notranslate">src/tools</td>
-        <td>Tools and database adapters source code</td>
-    </tr>
-</table>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
-
diff --git a/modules/h2/src/docsrc/html/license.html b/modules/h2/src/docsrc/html/license.html
deleted file mode 100644
index d928bb1..0000000
--- a/modules/h2/src/docsrc/html/license.html
+++ /dev/null
@@ -1,404 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-License
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>License</h1>
-
-<a href="#summary">
-    Summary and License FAQ</a><br />
-<a href="#mpl2">
-    Mozilla Public License Version 2.0</a><br />
-<a href="#eclipse_license">
-    Eclipse Public License - Version 1.0</a><br />
-<a href="#eccn">
-    Export Control Classification Number (ECCN)</a><br />
-
-<h2 id="summary">Summary and License FAQ</h2>
-<p>
-H2 is dual licensed and available under the MPL 2.0 (<a href="http://www.mozilla.org/MPL/2.0">Mozilla Public License Version 2.0</a>)
-or under the EPL 1.0  (<a href="http://opensource.org/licenses/eclipse-1.0.php">Eclipse Public License</a>).
-There is a license FAQ for both the MPL and the EPL.
-</p>
-<ul>
-<li>You can use H2 for free.
-</li><li>You can integrate it into your applications (including in commercial applications) and distribute it.
-</li><li>Files containing only your code are not covered by this license (it is 'commercial friendly').
-</li><li>Modifications to the H2 source code must be published.
-</li><li>You don't need to provide the source code of H2 if you did not modify anything.
-</li><li>If you distribute a binary that includes H2, you need to add a disclaimer of liability - see the example below.
-</li></ul>
-
-<p>
-However, nobody is allowed to rename H2, modify it a little, and sell it as a database engine without telling the customers it is in fact H2.
-This happened to HSQLDB: a company called 'bungisoft' copied HSQLDB, renamed it to 'RedBase', and tried to sell it,
-hiding the fact that it was in fact just HSQLDB. It seems 'bungisoft' does not exist any more, but you can use the
-<a href="http://www.archive.org">Wayback Machine</a> and visit old web pages of <code>http://www.bungisoft.com</code>.
-</p><p>
-About porting the source code to another language (for example C# or C++): converted source code (even if done manually) stays under the same
-copyright and license as the original code. The copyright of the ported source code does not (automatically) go to the person who ported the code.
-</p>
-
-<p>
-If you distribute a binary that includes H2, you need to add the license and a disclaimer of liability
-(as you should do for your own code). You should add a disclaimer for each open source library you use.
-For example, add a file <code>3rdparty_license.txt</code> in the directory where the jar files are,
-and list all open source libraries, each one with its license and disclaimer.
-For H2, a simple solution is to copy the following text below. You may also include a copy of the complete license.
-</p>
-<pre>
-This software contains unmodified binary redistributions for
-H2 database engine (http://www.h2database.com/),
-which is dual licensed and available under the MPL 2.0
-(Mozilla Public License) or under the EPL 1.0 (Eclipse Public License).
-An original copy of the license agreement can be found at:
-http://www.h2database.com/html/license.html
-</pre>
-
-<h2 id="mpl2">Mozilla Public License Version 2.0</h2>
-
-<h3>1. Definitions</h3>
-<p>1.1. "Contributor" means each individual or legal entity that creates, contributes to the creation of, or owns Covered Software.</p>
-<p>1.2. "Contributor Version" means the combination of the Contributions of others (if any) used by a Contributor and that particular Contributor's Contribution.</p>
-<p>1.3. "Contribution" means Covered Software of a particular Contributor.</p>
-<p>1.4. "Covered Software" means Source Code Form to which the initial Contributor has attached the notice in Exhibit A, the Executable Form of such Source Code Form, and Modifications of such Source Code Form, in each case including portions thereof.</p>
-<p>1.5. "Incompatible With Secondary Licenses" means</p>
-<p>a. that the initial Contributor has attached the notice described in Exhibit B to the Covered Software; or</p>
-<p>b. that the Covered Software was made available under the terms of version 1.1 or earlier of the License, but not also under the terms of a Secondary License.</p>
-<p>1.6. "Executable Form" means any form of the work other than Source Code Form.</p>
-<p>1.7. "Larger Work" means a work that combines Covered Software with other material, in a separate file or files, that is not Covered Software.</p>
-<p>1.8. "License" means this document.</p>
-<p>1.9. "Licensable" means having the right to grant, to the maximum extent possible, whether at the time of the initial grant or subsequently, any and all of the rights conveyed by this License.</p>
-<p>1.10. "Modifications" means any of the following:</p>
-<p>a. any file in Source Code Form that results from an addition to, deletion from, or modification of the contents of Covered Software; or</p>
-<p>b. any new file in Source Code Form that contains any Covered Software.</p>
-<p>1.11. "Patent Claims" of a Contributor means any patent claim(s), including without limitation, method, process, and apparatus claims, in any patent Licensable by such Contributor that would be infringed, but for the grant of the License, by the making, using, selling, offering for sale, having made, import, or transfer of either its Contributions or its Contributor Version.</p>
-<p>1.12. "Secondary License" means either the GNU General Public License, Version 2.0, the GNU Lesser General Public License, Version 2.1, the GNU Affero General Public License, Version 3.0, or any later versions of those licenses.</p>
-<p>1.13. "Source Code Form" means the form of the work preferred for making modifications.</p>
-<p>1.14. "You" (or "Your") means an individual or a legal entity exercising rights under this License. For legal entities, "You" includes any entity that controls, is controlled by, or is under common control with You. For purposes of this definition, "control" means (a) the power, direct or indirect, to cause the direction or management of such entity, whether by contract or otherwise, or (b) ownership of more than fifty percent (50%) of the outstanding shares or beneficial ownership of [...]
-
-<h3>2. License Grants and Conditions</h3>
-<h4>2.1. Grants</h4>
-<p>Each Contributor hereby grants You a world-wide, royalty-free, non-exclusive license:</p>
-<ol type="a">
-<li><p>under intellectual property rights (other than patent or trademark) Licensable by such Contributor to use, reproduce, make available, modify, display, perform, distribute, and otherwise exploit its Contributions, either on an unmodified basis, with Modifications, or as part of a Larger Work; and</p></li>
-<li><p>under Patent Claims of such Contributor to make, use, sell, offer for sale, have made, import, and otherwise transfer either its Contributions or its Contributor Version.</p></li>
-</ol>
-<h4>2.2. Effective Date</h4>
-<p>The licenses granted in Section&nbsp;2.1 with respect to any Contribution become effective for each Contribution on the date the Contributor first distributes such Contribution.</p>
-<h4>2.3. Limitations on Grant Scope</h4>
-<p>The licenses granted in this Section&nbsp;2 are the only rights granted under this License. No additional rights or licenses will be implied from the distribution or licensing of Covered Software under this License. Notwithstanding Section&nbsp;2.1(b) above, no patent license is granted by a Contributor:</p>
-<ol type="a">
-<li><p>for any code that a Contributor has removed from Covered Software; or</p></li>
-<li><p>for infringements caused by: (i) Your and any other third party's modifications of Covered Software, or (ii) the combination of its Contributions with other software (except as part of its Contributor Version); or</p></li>
-<li><p>under Patent Claims infringed by Covered Software in the absence of its Contributions.</p></li>
-</ol>
-<p>This License does not grant any rights in the trademarks, service marks, or logos of any Contributor (except as may be necessary to comply with the notice requirements in Section&nbsp;3.4).</p>
-<h4>2.4. Subsequent Licenses</h4>
-<p>No Contributor makes additional grants as a result of Your choice to distribute the Covered Software under a subsequent version of this License (see Section&nbsp;10.2) or under the terms of a Secondary License (if permitted under the terms of Section&nbsp;3.3).</p>
-<h4>2.5. Representation</h4>
-<p>Each Contributor represents that the Contributor believes its Contributions are its original creation(s) or it has sufficient rights to grant the rights to its Contributions conveyed by this License.</p>
-<h4>2.6. Fair Use</h4>
-<p>This License is not intended to limit any rights You have under applicable copyright doctrines of fair use, fair dealing, or other equivalents.</p>
-<h4>2.7. Conditions</h4>
-<p>Sections 3.1, 3.2, 3.3, and 3.4 are conditions of the licenses granted in Section&nbsp;2.1.</p>
-<h3>3. Responsibilities</h3>
-<h4>3.1. Distribution of Source Form</h4>
-<p>All distribution of Covered Software in Source Code Form, including any Modifications that You create or to which You contribute, must be under the terms of this License. You must inform recipients that the Source Code Form of the Covered Software is governed by the terms of this License, and how they can obtain a copy of this License. You may not attempt to alter or restrict the recipients' rights in the Source Code Form.</p>
-<h4>3.2. Distribution of Executable Form</h4>
-<p>If You distribute Covered Software in Executable Form then:</p>
-<ol type="a">
-<li><p>such Covered Software must also be made available in Source Code Form, as described in Section&nbsp;3.1, and You must inform recipients of the Executable Form how they can obtain a copy of such Source Code Form by reasonable means in a timely manner, at a charge no more than the cost of distribution to the recipient; and</p></li>
-<li><p>You may distribute such Executable Form under the terms of this License, or sublicense it under different terms, provided that the license for the Executable Form does not attempt to limit or alter the recipients' rights in the Source Code Form under this License.</p></li>
-</ol>
-<h4>3.3. Distribution of a Larger Work</h4>
-<p>You may create and distribute a Larger Work under terms of Your choice, provided that You also comply with the requirements of this License for the Covered Software. If the Larger Work is a combination of Covered Software with a work governed by one or more Secondary Licenses, and the Covered Software is not Incompatible With Secondary Licenses, this License permits You to additionally distribute such Covered Software under the terms of such Secondary License(s), so that the recipient [...]
-<h4>3.4. Notices</h4>
-<p>You may not remove or alter the substance of any license notices (including copyright notices, patent notices, disclaimers of warranty, or limitations of liability) contained within the Source Code Form of the Covered Software, except that You may alter any license notices to the extent required to remedy known factual inaccuracies.</p>
-<h4>3.5. Application of Additional Terms</h4>
-<p>You may choose to offer, and to charge a fee for, warranty, support, indemnity or liability obligations to one or more recipients of Covered Software. However, You may do so only on Your own behalf, and not on behalf of any Contributor. You must make it absolutely clear that any such warranty, support, indemnity, or liability obligation is offered by You alone, and You hereby agree to indemnify every Contributor for any liability incurred by such Contributor as a result of warranty, s [...]
-<h3>4. Inability to Comply Due to Statute or Regulation</h3>
-<p>If it is impossible for You to comply with any of the terms of this License with respect to some or all of the Covered Software due to statute, judicial order, or regulation then You must: (a) comply with the terms of this License to the maximum extent possible; and (b) describe the limitations and the code they affect. Such description must be placed in a text file included with all distributions of the Covered Software under this License. Except to the extent prohibited by statute o [...]
-<h3>5. Termination</h3>
-<p>5.1. The rights granted under this License will terminate automatically if You fail to comply with any of its terms. However, if You become compliant, then the rights granted under this License from a particular Contributor are reinstated (a) provisionally, unless and until such Contributor explicitly and finally terminates Your grants, and (b) on an ongoing basis, if such Contributor fails to notify You of the non-compliance by some reasonable means prior to 60 days after You have co [...]
-<p>5.2. If You initiate litigation against any entity by asserting a patent infringement claim (excluding declaratory judgment actions, counter-claims, and cross-claims) alleging that a Contributor Version directly or indirectly infringes any patent, then the rights granted to You by any and all Contributors for the Covered Software under Section&nbsp;2.1 of this License shall terminate.</p>
-<p>5.3. In the event of termination under Sections&nbsp;5.1 or 5.2 above, all end user license agreements (excluding distributors and resellers) which have been validly granted by You or Your distributors under this License prior to termination shall survive termination.</p>
-<h3>6. Disclaimer of Warranty</h3>
-<p>Covered Software is provided under this License on an "as is" basis, without warranty of any kind, either expressed, implied, or statutory, including, without limitation, warranties that the Covered Software is free of defects, merchantable, fit for a particular purpose or non-infringing. The entire risk as to the quality and performance of the Covered Software is with You. Should any Covered Software prove defective in any respect, You (not any Contributor) assume the cost of any nec [...]
-<h3>7. Limitation of Liability</h3>
-<p>Under no circumstances and under no legal theory, whether tort (including negligence), contract, or otherwise, shall any Contributor, or anyone who distributes Covered Software as permitted above, be liable to You for any direct, indirect, special, incidental, or consequential damages of any character including, without limitation, damages for lost profits, loss of goodwill, work stoppage, computer failure or malfunction, or any and all other commercial damages or losses, even if such [...]
-<h3>8. Litigation</h3>
-<p>Any litigation relating to this License may be brought only in the courts of a jurisdiction where the defendant maintains its principal place of business and such litigation shall be governed by laws of that jurisdiction, without reference to its conflict-of-law provisions. Nothing in this Section shall prevent a party's ability to bring cross-claims or counter-claims.</p>
-<h3>9. Miscellaneous</h3>
-<p>This License represents the complete agreement concerning the subject matter hereof. If any provision of this License is held to be unenforceable, such provision shall be reformed only to the extent necessary to make it enforceable. Any law or regulation which provides that the language of a contract shall be construed against the drafter shall not be used to construe this License against a Contributor.</p>
-<h3>10. Versions of the License</h3>
-<h4>10.1. New Versions</h4>
-<p>Mozilla Foundation is the license steward. Except as provided in Section&nbsp;10.3, no one other than the license steward has the right to modify or publish new versions of this License. Each version will be given a distinguishing version number.</p>
-<h4>10.2. Effect of New Versions</h4>
-<p>You may distribute the Covered Software under the terms of the version of the License under which You originally received the Covered Software, or under the terms of any subsequent version published by the license steward.</p>
-<h4>10.3. Modified Versions</h4>
-<p>If you create software not governed by this License, and you want to create a new license for such software, you may create and use a modified version of this License if you rename the license and remove any references to the name of the license steward (except to note that such modified license differs from this License).</p>
-<h4>10.4. Distributing Source Code Form that is Incompatible With Secondary Licenses</h4>
-<p>If You choose to distribute Source Code Form that is Incompatible With Secondary Licenses under the terms of this version of the License, the notice described in Exhibit B of this License must be attached.</p>
-<h3>Exhibit A - Source Code Form License Notice</h3>
-<pre>
-This Source Code Form is subject to the terms of the Mozilla
-Public License, v. 2.0. If a copy of the MPL was not distributed
-with this file, you can obtain one at http://mozilla.org/MPL/2.0
-</pre>
-<p>If it is not possible or desirable to put the notice in a particular file, then You may include the notice in a location (such as a LICENSE file in a relevant directory) where a recipient would be likely to look for such a notice.</p>
-<p>You may add additional accurate notices of copyright ownership.</p>
-<h3>Exhibit B - "Incompatible With Secondary Licenses" Notice</h3>
-<pre>
-This Source Code Form is "Incompatible With Secondary Licenses",
-as defined by the Mozilla Public License, v. 2.0.
-</pre>
-
-<h2 id="eclipse_license">Eclipse Public License - Version 1.0</h2>
-<p>
-THE ACCOMPANYING PROGRAM IS PROVIDED UNDER THE TERMS OF THIS ECLIPSE
-PUBLIC LICENSE ("AGREEMENT"). ANY USE, REPRODUCTION OR DISTRIBUTION OF
-THE PROGRAM CONSTITUTES RECIPIENT'S ACCEPTANCE OF THIS AGREEMENT.
-</p>
-
-<h3>1. DEFINITIONS</h3>
-<p>
-"Contribution" means:
-</p><p>
-a) in the case of the initial Contributor, the initial code and documentation
-distributed under this Agreement, and
-</p><p>
-b) in the case of each subsequent Contributor:
-</p><p>
-i) changes to the Program, and
-</p><p>
-ii) additions to the Program;
-</p><p>
-where such changes and/or additions to the Program originate from and are
-distributed by that particular Contributor. A Contribution 'originates' from a
-Contributor if it was added to the Program by such Contributor itself or anyone
-acting on such Contributor's behalf. Contributions do not include additions to
-the Program which: (i) are separate modules of software distributed in conjunction
-with the Program under their own license agreement, and (ii) are not derivative
-works of the Program.
-</p><p>
-"Contributor" means any person or entity that distributes the Program.
-</p><p>
-"Licensed Patents " mean patent claims licensable by a Contributor which are
-necessarily infringed by the use or sale of its Contribution alone or when combined
-with the Program.
-</p><p>
-"Program" means the Contributions distributed in accordance with this Agreement.
-</p><p>
-"Recipient" means anyone who receives the Program under this Agreement,
-including all Contributors.
-</p>
-
-<h3>2. GRANT OF RIGHTS</h3>
-<p>
-a) Subject to the terms of this Agreement, each Contributor hereby grants Recipient
-a non-exclusive, worldwide, royalty-free copyright license to reproduce, prepare
-derivative works of, publicly display, publicly perform, distribute and sublicense the
-Contribution of such Contributor, if any, and such derivative works, in source code
-and object code form.
-</p><p>
-b) Subject to the terms of this Agreement, each Contributor hereby grants
-Recipient a non-exclusive, worldwide, royalty-free patent license under Licensed
-Patents to make, use, sell, offer to sell, import and otherwise transfer the
-Contribution of such Contributor, if any, in source code and object code form.
-This patent license shall apply to the combination of the Contribution and the
-Program if, at the time the Contribution is added by the Contributor, such addition
-of the Contribution causes such combination to be covered by the Licensed
-Patents. The patent license shall not apply to any other combinations which
-include the Contribution. No hardware per se is licensed hereunder.
-</p><p>
-c) Recipient understands that although each Contributor grants the licenses to
-its Contributions set forth herein, no assurances are provided by any Contributor
-that the Program does not infringe the patent or other intellectual property
-rights of any other entity. Each Contributor disclaims any liability to Recipient
-for claims brought by any other entity based on infringement of intellectual
-property rights or otherwise. As a condition to exercising the rights and licenses
-granted hereunder, each Recipient hereby assumes sole responsibility to secure
-any other intellectual property rights needed, if any. For example, if a third party
-patent license is required to allow Recipient to distribute the Program, it is
-Recipient's responsibility to acquire that license before distributing the Program.
-</p><p>
-d) Each Contributor represents that to its knowledge it has sufficient copyright
-rights in its Contribution, if any, to grant the copyright license set forth in this
-Agreement.
-</p>
-
-<h3>3. REQUIREMENTS</h3>
-<p>
-A Contributor may choose to distribute the Program in object code form
-under its own license agreement, provided that:
-</p><p>
-a) it complies with the terms and conditions of this Agreement; and
-</p><p>
-b) its license agreement:
-</p><p>
-i) effectively disclaims on behalf of all Contributors all warranties and conditions,
-express and implied, including warranties or conditions of title and
-non-infringement, and implied warranties or conditions of merchantability and
-fitness for a particular purpose;
-</p><p>
-ii) effectively excludes on behalf of all Contributors all liability for damages,
-including direct, indirect, special, incidental and consequential damages,
-such as lost profits;
-</p><p>
-iii) states that any provisions which differ from this Agreement are offered by
-that Contributor alone and not by any other party; and
-</p><p>
-iv) states that source code for the Program is available from such Contributor,
-and informs licensees how to obtain it in a reasonable manner on or through
-a medium customarily used for software exchange.
-</p><p>
-When the Program is made available in source code form:
-</p><p>
-a) it must be made available under this Agreement; and
-</p><p>
-b) a copy of this Agreement must be included with each copy of the Program.
-</p><p>
-Contributors may not remove or alter any copyright notices contained within
-the Program.
-</p><p>
-Each Contributor must identify itself as the originator of its Contribution,
-if any, in a manner that reasonably allows subsequent Recipients to identify
-the originator of the Contribution.
-</p>
-
-<h3>4. COMMERCIAL DISTRIBUTION</h3>
-<p>
-Commercial distributors of software may accept certain responsibilities with
-respect to end users, business partners and the like. While this license is
-intended to facilitate the commercial use of the Program, the Contributor
-who includes the Program in a commercial product offering should do so
-in a manner which does not create potential liability for other Contributors.
-Therefore, if a Contributor includes the Program in a commercial product
-offering, such Contributor ("Commercial Contributor") hereby agrees to
-defend and indemnify every other Contributor ("Indemnified Contributor")
-against any losses, damages and costs (collectively "Losses") arising from
-claims, lawsuits and other legal actions brought by a third party against the
-Indemnified Contributor to the extent caused by the acts or omissions of
-such Commercial Contributor in connection with its distribution of the
-Program in a commercial product offering. The obligations in this section
-do not apply to any claims or Losses relating to any actual or alleged
-intellectual property infringement. In order to qualify, an Indemnified
-Contributor must: a) promptly notify the Commercial Contributor in writing
-of such claim, and b) allow the Commercial Contributor to control, and
-cooperate with the Commercial Contributor in, the defense and any related
-settlement negotiations. The Indemnified Contributor may participate in
-any such claim at its own expense.
-</p><p>
-For example, a Contributor might include the Program in a commercial
-product offering, Product X. That Contributor is then a Commercial
-Contributor. If that Commercial Contributor then makes performance
-claims, or offers warranties related to Product X, those performance
-claims and warranties are such Commercial Contributor's responsibility
-alone. Under this section, the Commercial Contributor would have to
-defend claims against the other Contributors related to those performance
-claims and warranties, and if a court requires any other Contributor to pay
-any damages as a result, the Commercial Contributor must pay those damages.
-</p>
-
-<h3>5. NO WARRANTY</h3>
-<p>
-EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, THE PROGRAM
-IS PROVIDED ON AN "AS IS" BASIS, WITHOUT WARRANTIES OR
-CONDITIONS OF ANY KIND, EITHER EXPRESS OR IMPLIED INCLUDING,
-WITHOUT LIMITATION, ANY WARRANTIES OR CONDITIONS OF TITLE,
-NON-INFRINGEMENT, MERCHANTABILITY OR FITNESS FOR A PARTICULAR
-PURPOSE. Each Recipient is solely responsible for determining the
-appropriateness of using and distributing the Program and assumes all
-risks associated with its exercise of rights under this Agreement, including
-but not limited to the risks and costs of program errors, compliance with
-applicable laws, damage to or loss of data, programs or equipment, and
-unavailability or interruption of operations.
-</p>
-
-<h3>6. DISCLAIMER OF LIABILITY</h3>
-<p>
-EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, NEITHER
-RECIPIENT NOR ANY CONTRIBUTORS SHALL HAVE ANY LIABILITY FOR
-ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR
-CONSEQUENTIAL DAMAGES (INCLUDING WITHOUT LIMITATION LOST
-PROFITS), HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY,
-WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING
-NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE
-USE OR DISTRIBUTION OF THE PROGRAM OR THE EXERCISE OF ANY
-RIGHTS GRANTED HEREUNDER, EVEN IF ADVISED OF THE POSSIBILITY
-OF SUCH DAMAGES.
-</p>
-
-<h3>7. GENERAL</h3>
-<p>
-If any provision of this Agreement is invalid or unenforceable under applicable
-law, it shall not affect the validity or enforceability of the remainder of the
-terms of this Agreement, and without further action by the parties hereto,
-such provision shall be reformed to the minimum extent necessary to make
-such provision valid and enforceable.
-</p><p>
-If Recipient institutes patent litigation against any entity (including a cross-claim
-or counterclaim in a lawsuit) alleging that the Program itself (excluding
-combinations of the Program with other software or hardware) infringes such
-Recipient's patent(s), then such Recipient's rights granted under Section
-2(b) shall terminate as of the date such litigation is filed.
-</p><p>
-All Recipient's rights under this Agreement shall terminate if it fails to comply
-with any of the material terms or conditions of this Agreement and does
-not cure such failure in a reasonable period of time after becoming aware
-of such noncompliance. If all Recipient's rights under this Agreement
-terminate, Recipient agrees to cease use and distribution of the Program
-as soon as reasonably practicable. However, Recipient's obligations under
-this Agreement and any licenses granted by Recipient relating to the
-Program shall continue and survive.
-</p><p>
-Everyone is permitted to copy and distribute copies of this Agreement, but
-in order to avoid inconsistency the Agreement is copyrighted and may only
-be modified in the following manner. The Agreement Steward reserves the
-right to publish new versions (including revisions) of this Agreement from
-time to time. No one other than the Agreement Steward has the right to
-modify this Agreement. The Eclipse Foundation is the initial Agreement
-Steward. The Eclipse Foundation may assign the responsibility to serve as
-the Agreement Steward to a suitable separate entity. Each new version of
-the Agreement will be given a distinguishing version number. The Program
-(including Contributions) may always be distributed subject to the version
-of the Agreement under which it was received. In addition, after a new
-version of the Agreement is published, Contributor may elect to distribute
-the Program (including its Contributions) under the new version. Except as
-expressly stated in Sections 2(a) and 2(b) above, Recipient receives no rights
-or licenses to the intellectual property of any Contributor under this
-Agreement, whether expressly, by implication, estoppel or otherwise.
-All rights in the Program not expressly granted under this Agreement are
-reserved.
-</p><p>
-This Agreement is governed by the laws of the State of New York
-and the intellectual property laws of the United States of America.
-No party to this Agreement will bring a legal action under this Agreement more
-than one year after the cause of action arose. Each party waives its rights
-to a jury trial in any resulting litigation.
-</p>
-
-<h2 id="eccn">Export Control Classification Number (ECCN)</h2>
-<p>
-As far as we know, the <a href="http://www.bis.doc.gov/licensing/exportingbasics.htm">U.S. Export Control Classification Number (ECCN)</a> for this software is <code>5D002</code>.
-However, for legal reasons, we can make no warranty that this information is correct.
-For details, see also the <a href="http://www.apache.org/licenses/exports/">Apache Software Foundation Export Classifications page</a>.
-</p>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
-
diff --git a/modules/h2/src/docsrc/html/links.html b/modules/h2/src/docsrc/html/links.html
deleted file mode 100644
index 9750456..0000000
--- a/modules/h2/src/docsrc/html/links.html
+++ /dev/null
@@ -1,708 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-H2 In Use and Links
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>Links</h1>
-<p>
-If you want to add a link, please send it to the support email address or post it to the group.
-</p>
-<a href="#quotes">
-    Quotes</a><br />
-<a href="#books">
-    Books</a><br />
-<a href="#extensions">
-    Extensions</a><br />
-<a href="#blog">
-    Blog Articles, Videos</a><br />
-<a href="#tools">
-    Database Frontends / Tools</a><br />
-<a href="#projects">
-    Products and Projects</a><br />
-
-<h2 id="quotes">Quotes</h2>
-<p>
-<a href="http://groups.google.com/group/h2-database/browse_thread/thread/adee024b8af85931/1edbc4a601146ec6">
-Quote</a>:
-"This is by far the easiest and fastest database that I have ever used.
-Originally the web application that I am working on is using SQL server.
-But, in less than 15 minutes I had H2 up and working with little recoding of the SQL.
-Thanks..... "
-</p>
-
-<h2 id="books">Books</h2>
-<a href="http://code.google.com/p/seaminaction/wiki/GettingStarted">
-Seam In Action</a>
-
-<h2 id="extensions">Extensions</h2>
-<a href="http://grails.org/H2+Database+Plugin">
-Grails H2 Database Plugin</a>
-<br />
-<a href="http://code.google.com/p/h2osgi">
-h2osgi: OSGi for the H2 Database</a>
-<br />
-<a href="http://code.google.com/p/h2sharp">
-H2Sharp: ADO.NET interface for the H2 database engine</a>
-<br />
-<a href="http://www.h2gis.org">
-A spatial extension of the H2 database.</a>
-
-<h2 id="blog">Blog Articles, Videos</h2>
-<a href="http://www.youtube.com/watch?v=mlWM0r3SKkg">
-Youtube: Minecraft 1.7.3 / How to install Bukkit Server with xAuth and H2</a><br />
-<a href="http://blog.zvikico.com/2009/12/analyzing-csvs-with-h2.html">
-Analyzing CSVs with H2 in under 10 minutes (2009-12-07)</a><br />
-<a href="http://sbdevel.wordpress.com/2009/06/15/efficient-sorting-and-iteration-on-large-databases">
-Efficient sorting and iteration on large databases (2009-06-15)</a><br />
-<a href="http://blog.flexive.org/2008/12/05/porting-flexive-to-the-h2-database">
-Porting Flexive to the H2 Database (2008-12-05)</a><br />
-<a href="http://blogs.sun.com/theaquarium/entry/h2_database_with_glassfish">
-H2 Database with GlassFish (2008-11-24)</a><br />
-<a href="http://zvikico.typepad.com/problog/2008/04">
-H2 Database - Performance Tracing (2008-04-30)</a><br />
-<a href="http://www.encorewiki.org/display/encore/Open+Source+Databases+Comparison">
-Open Source Databases Comparison (2007-09-11)</a><br />
-<a href="http://thecodist.com/fiche/thecodist/article/the-open-source-frameworks-i-use">
-The Codist: The Open Source Frameworks I Use (2007-07-23)</a><br />
-<a href="http://thecodist.com/fiche/thecodist/article/sql-injections-how-not-to-get-stuck">
-The Codist:  SQL Injections: How Not To Get Stuck (2007-05-08)</a><br />
-<a href="http://blogs.sun.com/coldrick/entry/new_version_of_h2_database">
-David Coldrick's Weblog: New Version of H2 Database Released (2007-01-06)</a><br />
-<a href="http://thecodist.com/fiche/thecodist/article/write-your-own-database-again-an-interview-with-the-author-of-h2-thomas-mueller">
-The Codist: Write Your Own Database, Again (2006-11-13)</a><br />
-
-<h2>Project Pages</h2>
-<a href="http://www.ohloh.net/projects/3924?p=H2+Database+Engine">
-Ohloh</a><br />
-<a href="http://freshmeat.net/projects/h2">
-Freshmeat Project Page</a><br />
-<a href="http://en.wikipedia.org/wiki/H2_%28DBMS%29">
-Wikipedia</a><br />
-<a href="http://java-source.net/open-source/database-engines/h2">
-Java Source Net</a><br />
-<a href="http://packman.links2linux.org/package/h2">
-Linux Package Manager</a><br />
-
-<h2 id="tools">Database Frontends / Tools</h2>
-
-<p><a href="http://www.alvila.com/DataFlyer">
-Dataflyer</a><br />
-A tool to browse databases and export data.
-</p>
-
-<p><a href="http://www.dbsolo.com">
-DB Solo</a><br />
-SQL query tool.
-</p>
-
-<p><a href="http://www.dbvis.com">
-DbVisualizer</a><br />
-Database tool.
-</p>
-
-<p><a href="http://executequery.org">
-Execute Query</a><br />
-Database utility written in Java.
-</p>
-
-<p><a href="http://flywaydb.org">
-Flyway</a><br />
-The agile database migration framework for Java.
-</p>
-
-<p><a href="http://www.flexive.org">
-[fleXive]</a><br />
-JavaEE 5 open source framework for the development of complex and evolving (web-)applications.
-</p>
-
-<p><a href="https://github.com/arykov/jdbc-console">
-JDBC Console</a><br />
-This small webapp gives an ability to execute SQL against datasources bound in container's JNDI.
-Based on H2 Console.
-</p>
-
-<p><a href="http://henplus.sourceforge.net">
-HenPlus</a><br />
-HenPlus is a SQL shell written in Java.
-</p>
-
-<p><a href="http://github.com/maginatics/jdbclint">
-JDBC lint</a><br />
-Helps write correct and efficient code when using the JDBC API.
-</p>
-
-<p><a href="http://www.openoffice.org">
-OpenOffice</a><br />
-Base is OpenOffice.org's database application. It provides access to relational data sources.
-</p>
-
-<p><a href="http://www.razorsql.com">
-RazorSQL</a><br />
-An SQL query tool, database browser, SQL editor, and database administration tool.
-</p>
-
-<p><a href="http://sqldeveloper.solyp.com/index.html">
-SQL Developer</a><br />
-Universal Database Frontend.
-</p>
-
-<p><a href="http://sql-workbench.net">
-SQL Workbench/J</a><br />
-Free DBMS-independent SQL tool.
-</p>
-
-<p><a href="http://www.squirrelsql.org">
-SQuirreL SQL Client</a><br />
-Graphical tool to view the structure of a database, browse the data, issue SQL commands etc.
-</p>
-
-<p><a href="http://dbcopyplugin.sf.net">
-SQuirreL DB Copy Plugin</a><br />
-Tool to copy data from one database to another.
-</p>
-
-<h2 id="projects">Products and Projects</h2>
-
-<p><a href="http://www.accuprocess.com">
-AccuProcess</a><br />
-Visual business process modeling and simulation software for business users.
-</p>
-
-<p><a href="http://www.adeptiabpm.com">
-Adeptia BPM</a><br />
-A Business Process Management (BPM) suite to quickly and easily automate business processes and workflows.
-</p>
-
-<p><a href="http://www.adeptia.com">
-Adeptia Integration</a><br />
-Process-centric, services-based application integration suite.
-</p>
-
-<p><a href="http://aejaks.sf.net">
-Aejaks</a><br />
-A server-side scripting environment to build AJAX enabled web applications.
-</p>
-
-<p><a href="http://www.axiomstack.com">
-Axiom Stack</a><br />
-A web framework that let's you write dynamic web applications with Zen-like simplicity.
-</p>
-
-<p><a href="http://cayenne.apache.org">
-Apache Cayenne</a><br />
-Open source persistence framework providing object-relational mapping (ORM) and remoting services.
-</p>
-
-<p><a href="http://jackrabbit.apache.org">
-Apache Jackrabbit</a><br />
-Open source implementation of the Java Content Repository API (JCR).
-</p>
-
-<p><a href="http://incubator.apache.org/openjpa">
-Apache OpenJPA</a><br />
-Open source implementation of the Java Persistence API (JPA).
-</p>
-
-<p><a href="http://appfuse.org">
-AppFuse</a><br />
-Helps building web applications.
-</p>
-
-<p><a href="http://www.bgblitz.com">
-BGBlitz</a><br />
-The Swiss army knife of Backgammon.
-</p>
-
-<p><a href="http://wiki.bonita.ow2.org/xwiki/bin/view/Main">
-Bonita</a><br />
-Open source workflow solution for handing long-running, user-oriented processes
-providing out of the box workflow and business process management features.
-</p>
-
-<p><a href="http://bmarks-portlet.sourceforge.net">
-Bookmarks Portlet</a><br />
-JSR 168 compliant bookmarks management portlet application.
-</p>
-
-<p><a href="http://www.claros.org">
-Claros inTouch</a><br />
-Ajax communication suite with mail, addresses, notes, IM, and rss reader.
-</p>
-
-<p><a href="http://crashplan.com/business">
-CrashPlan PRO Server</a><br />
-Easy and cross platform backup solution for business and service providers.
-</p>
-
-<p><a href="http://www.datanucleus.org">
-DataNucleus</a><br />
-Java persistent objects.
-</p>
-
-<p><a href="http://dbunit.wikidot.com">
-DbUnit</a><br />
-A JUnit extension (also usable with Ant) targeted for database-driven projects.
-</p>
-
-<p><a href="http://www.diffkit.org">
-DiffKit</a><br />
-DiffKit is a tool for comparing two tables of data, field-by-field.
-DiffKit is like the Unix diff utility, but for tables instead of lines of text.
-</p>
-
-<p><a href="http://www.martincordova.com">
-Dinamica Framework</a><br />
-Ajax/J2EE framework for RAD development (mainly oriented toward hispanic markets).
-</p>
-
-<p><a href="http://dhis2.org">
-District Health Information Software 2 (DHIS)</a><br />
-The DHIS 2 is a tool for collection, validation, analysis, and presentation of aggregate statistical data,
-tailored (but not limited) to integrated health information management activities.
-</p>
-
-<p><a href="http://www.avaje.org">
-Ebean ORM Persistence Layer</a><br />
-Open source Java Object Relational Mapping tool.
-</p>
-
-<p><a href="http://wiki.eclipse.org/CDO">
-Eclipse CDO</a><br />
-The CDO (Connected Data Objects) Model Repository is a distributed shared model framework for EMF models,
-and a fast server-based O/R mapping solution.
-</p>
-
-<p><a href="http://fabric3.codehaus.org">
-Fabric3</a><br />
-Fabric3 is a project implementing a federated service network based on the Service Component Architecture specification (http://www.osoa.org).
-</p>
-
-<p><a href="http://code.google.com/p/fit4data">
-FIT4Data</a><br />
-A testing framework for data management applications built on the Java implementation of FIT.
-</p>
-
-<p><a href="http://www.fluxcorp.com">
-Flux</a><br />
-Java job scheduler, file transfer, workflow, and BPM.
-</p>
-
-<p><a href="http://geoserver.org">
-GeoServer</a><br />
-GeoServer is a Java-based software server that allows users to view and edit geospatial data. Using open standards set forth by the Open Geospatial Consortium (OGC), GeoServer allows for great flexibility in map creation and data sharing.
-</p>
-
-<p><a href="http://code.google.com/p/gbif-providertoolkit">
-GBIF Integrated Publishing Toolkit (IPT)</a><br />
-The GBIF IPT is an open source, Java based web application that connects and serves
-three types of biodiversity data: taxon primary occurrence data,
-taxon checklists and general resource metadata.
-</p>
-
-<p><a href="http://ggc.sourceforge.net">
-GNU Gluco Control</a><br />
-Helps you to manage your diabetes.
-</p>
-
-<p><a href="http://www.goldenstudios.or.id">
-Golden T Studios</a><br />
-Fun-to-play games with a simple interface.
-</p>
-
-<p><a href="http://www.gridgain.com">
-GridGain</a><br />
-GridGain is easy to use Cloud Application Platform that enables development of
-highly scalable distributed Java and Scala applications
-that auto-scale on any grid or cloud infrastructure.
-</p>
-
-<p><a href="http://www.gs.sjts.co.jp">
-Group Session</a><br />
-Open source web groupware.
-</p>
-
-<p><a href="http://ha-jdbc.sourceforge.net">
-HA-JDBC</a><br />
-High-Availability JDBC: A JDBC proxy that provides light-weight, transparent, fault tolerant clustering capability to any underlying JDBC driver.
-</p>
-
-<p><a href="http://hibernate.org">
-Hibernate</a><br />
-Relational persistence for idiomatic Java (O-R mapping tool).
-</p>
-
-<p><a href="http://www.willuhn.de/projects/hibiscus">
-Hibicius</a><br />
-Online Banking Client for the HBCI protocol.
-</p>
-
-<p><a href="http://www.believeit.ltd.uk">
-ImageMapper</a><br />
-ImageMapper frees users from having to use file browsers to view their images.
-They get fast access to images and easy cataloguing of them via a user friendly
-interface.
-</p>
-
-<p><a href="http://jamwiki.org">
-JAMWiki</a><br />
-Java-based Wiki engine.
-</p>
-
-<p><a href="http://jaspa.upv.es">
-Jaspa</a><br />
-Java Spatial. Jaspa potentially brings around 200 spatial functions.
-</p>
-
-<p><a href="http://code.google.com/p/javasimon">
-Java Simon</a><br />
-Simple Monitoring API.
-</p>
-
-<p><a href="http://www.jboss.org/jbossjbpm">
-JBoss jBPM</a><br />
-A platform for executable process languages ranging from business process management (BPM) over workflow to service orchestration.
-</p>
-
-<p><a href="http://jboss.org/jopr">
-JBoss Jopr</a><br />
-An enterprise management solution for JBoss middleware projects and other application technologies.
-</p>
-
-<p><a href="http://jgeocoder.sourceforge.net">
-JGeocoder</a><br />
-Free Java geocoder. Geocoding is the process of estimating a latitude and longitude for a given location.
-</p>
-
-<p><a href="http://www.jgrass.org">
-JGrass</a><br />
-Java Geographic Resources Analysis Support System.
-Free, multi platform, open source GIS based on the GIS framework of uDig.
-</p>
-
-<p><a href="http://jena.sourceforge.net">
-Jena</a><br />
-Java framework for building Semantic Web applications.
-</p>
-
-<p><a href="http://jmatter.org">
-JMatter</a><br />
-Framework for constructing workgroup business applications based on the Naked Objects Architectural Pattern.
-</p>
-
-<p><a href="http://www.jooq.org">
-jOOQ (Java Object Oriented Querying)</a><br />
-jOOQ is a fluent API for typesafe SQL query construction and execution
-</p>
-
-<p><a href="http://code.google.com/p/liftweb">
-Liftweb</a><br />
-A Scala-based, secure, developer friendly web framework.
-</p>
-
-<p><a href="http://liquibase.org">
-LiquiBase</a><br />
-A tool to manage database changes and refactorings.
-</p>
-
-<p><a href="http://luntbuild.javaforge.com">
-Luntbuild</a><br />
-Build automation and management tool.
-</p>
-
-<p><a href="http://code.google.com/p/localdb">
-localdb</a><br />
-A tool that locates the full file path of the folder containing the database files.
-</p>
-
-<p><a href="http://pfgrc.jcvi.org/index.php/bioinformatics/magnolia.html">
-Magnolia</a><br />
-Microarray Data Management and Export System for PFGRC
-(Pathogen Functional Genomics Resource Center) Microarrays.
-</p>
-
-<p><a href="http://www.source-code.biz/snippets/java/8.htm">
-MiniConnectionPoolManager</a><br />
-A lightweight standalone JDBC connection pool manager.
-</p>
-
-<p><a href="http://jenkov.com/mrpersister/index.html">
-Mr. Persister</a><br />
-Simple, small and fast object relational mapping.
-</p>
-
-<p><a href="http://myna.emptybrain.info">
-Myna Application Server</a><br />
-Java web app that provides dynamic web content and Java libraries access from JavaScript.
-</p>
-
-<p><a href="http://www.codewave.de/mytunesrss.php">
-MyTunesRss</a><br />
-MyTunesRSS lets you listen to your music wherever you are.
-</p>
-
-<p><a href="http://www.ncats.nih.gov/research/tools/preclinical/preclinical-research-tools.html">
-NCGC CurveFit</a><br />
-From: NIH Chemical Genomics Center, National Institutes of Health, USA.
-An open source application in the life sciences research field. This
-application handles chemical structures and biological responses of
-thousands of compounds with the potential to handle million+ compounds.
-It utilizes an embedded H2 database to enable flexible query/retrieval
-of all data including advanced chemical substructure and similarity
-searching. The application highlights an automated curve fitting and
-classification algorithm that outperforms commercial packages in the
-field. Commercial alternatives are typically small desktop software
-that handle a few dose response curves at a time. A couple of
-commercial packages that do handle several thousand curves are very
-expensive tools (&gt;60k USD) that require manual curation of analysis
-by the user; require a license to Oracle; lack advanced
-query/retrieval; and the ability to handle chemical structures.
-</p>
-
-<p><a href="http://www.nuxeo.org">
-Nuxeo</a><br />
-Standards-based, open source platform for building ECM applications.
-</p>
-
-<p><a href="http://www.nwiresoftware.com">
-nWire</a><br />
-Eclipse plug-in which expedites Java development.
-It's main purpose is to help developers find code quicker and easily
-understand how it relates to the rest of the application, thus,
-understand the application structure.
-</p>
-
-<p><a href="http://www.ontologyworks.com">
-Ontology Works</a><br />
-This company provides semantic technologies including deductive
-information repositories (the Ontology Works Knowledge Servers),
-semantic information fusion and semantic federation of legacy
-databases, ontology-based domain modeling, and management of the
-distributed enterprise.
-</p>
-
-<p><a href="http://www.ontoprise.de">
-Ontoprise OntoBroker</a><br />
-SemanticWeb-Middleware. It supports all W3C Semantic Web recommendations:
-OWL, RDF, RDFS, SPARQL, and F-Logic.
-</p>
-
-<p><a href="http://www.openanzo.org">
-Open Anzo</a><br />
-Semantic Application Server.
-</p>
-
-<p><a href="http://www.opengroove.org">
-OpenGroove</a><br />
-OpenGroove is a groupware program that allows users to synchronize data.
-</p>
-
-<p><a href="http://code.google.com/p/opensocial-development-environment">
-OpenSocial Development Environment (OSDE)</a><br />
-Development tool for OpenSocial application.
-</p>
-
-<p><a href="http://www.orionserver.com">
-Orion</a><br />
-J2EE Application Server.
-</p>
-
-<p><a href="http://fluid-forms.com/FluidLibs">
-P5H2</a><br />
-A library for the <a href="http://www.processing.org">Processing</a> programming language and environment.
-</p>
-
-<p><a href="http://www.phase-6.de">
-Phase-6</a><br />
-A computer based learning software.
-</p>
-
-<p><a href="http://code.google.com/p/pickle4j">
-Pickle</a><br />
-Pickle is a Java library containing classes for persistence, concurrency, and logging.
-</p>
-
-<p><a href="http://www.pimansoft.com">
-Piman</a><br />
-Water treatment projects data management.
-</p>
-
-<p><a href="http://www.polepos.org">
-PolePosition</a><br />
-Open source database benchmark.
-</p>
-
-<p><a href="http://poormans.sourceforge.net/index.html">
-Poormans</a><br />
-Very basic CMS running as a SWT application and generating static html pages.
-</p>
-
-<p><a href="http://www.railo-technologies.com">
-Railo</a><br />
-Railo is an alternative engine for the Cold Fusion Markup Language, that compiles code
-programmed in CFML into Java bytecode and executes it on a servlet engine.
-</p>
-
-<p><a href="http://www.razuna.com">
-Razuna</a><br />
-Open source Digital Asset Management System with integrated Web Content Management.
-</p>
-
-<p><a href="http://www.rifers.org">
-RIFE</a><br />
-A full-stack web application framework with tools and APIs to implement most common web features.
-</p>
-
-<p><a href="http://scriptella.javaforge.com">
-Sava</a><br />
-Open-source web-based content management system.
-</p>
-
-<p><a href="http://scriptella.javaforge.com">
-Scriptella</a><br />
-ETL (Extract-Transform-Load) and script execution tool.
-</p>
-
-<p><a href="http://www.seasar.org">
-Sesar</a><br />
-Dependency Injection Container with Aspect Oriented Programming.
-</p>
-
-<p><a href="http://semmle.com">
-SemmleCode</a><br />
-Eclipse plugin to help you improve software quality.
-</p>
-
-<p><a href="http://sequalite.sourceforge.net">
-SeQuaLite</a><br />
-A free, light-weight, java data access framework.
-</p>
-
-<p><a href="http://code.google.com/p/shapelogic">
-ShapeLogic</a><br />
-Toolkit for declarative programming, image processing and computer vision.
-</p>
-
-<p><a href="http://www.shellbook.com">
-Shellbook</a><br />
-Desktop publishing application.
-</p>
-
-<p><a href="http://www.intellibo.com">
-Signsoft intelliBO</a><br />
-Persistence middleware supporting the JDO specification.
-</p>
-
-<p><a href="http://www.simpleorm.org">
-SimpleORM</a><br />
-Simple Java Object Relational Mapping.
-</p>
-
-<p><a href="http://symmetricds.codehaus.org">
-SymmetricDS</a><br />
-A web-enabled, database independent, data synchronization/replication software.
-</p>
-
-<p><a href="http://www.smartfoxserver.com">
-SmartFoxServer</a><br />
-Platform for developing multiuser applications and games with Macromedia Flash.
-</p>
-
-<p><a href="http://code.google.com/p/sbff">
-Social Bookmarks Friend Finder</a><br />
-A GUI application that allows you to find users with similar bookmarks to the user specified (for delicious.com).
-</p>
-
-<p><a href="http://www.sormula.org">
-sormula</a><br />
-Simple object relational mapping.
-</p>
-
-<p><a href="http://www.springfuse.com">
-Springfuse</a><br />
-Code generation For Spring, Spring MVC &amp; Hibernate.
-</p>
-
-<p><a href="http://sqlorm.sourceforge.net/index.html">
-SQLOrm</a><br />
-Java Object Relation Mapping.
-</p>
-
-<p><a href="http://csv-jdbc.com">
-StelsCSV and StelsXML</a><br />
-StelsCSV is a CSV JDBC type 4 driver that allows to perform SQL queries and other JDBC operations on text files.
-StelsXML is a XML JDBC type 4 driver that allows to perform SQL queries and other JDBC operations on XML files.
-Both use H2 as the SQL engine.
-</p>
-
-<p><a href="http://www.intertec.ch/storybook">
-StorYBook</a><br />
-A summary-based tool for novelist and script writers. It helps to keep the overview over the various traces a story has.
-</p>
-
-<p><a href="http://www.streamcruncher.com">
-StreamCruncher</a><br />
-Event (stream) processing kernel.
-</p>
-
-<p><a href="http://www.suse.com/products/suse-manager">
-SUSE Manager, part of Linux Enterprise Server 11</a><br />
-The SUSE Manager
-<a href="http://www.suse.com/blogs/suse-manager-eases-the-buden-of-compliance">
-eases the burden of compliance</a> with regulatory requirements and corporate policies.
-</p>
-
-<p><a href="http://www.gabealbert.info/tunebackup">
-Tune Backup</a><br />
-Easy-to-use backup solution for your iTunes library.
-</p>
-
-<p><a href="http://www.timewriter.com">
-TimeWriter</a><br />
-TimeWriter is a very flexible program for time administration / time tracking.
-The older versions used dBase tables.
-The new version 5 is completely rewritten, now using the H2 database.
-TimeWriter is delivered in Dutch and English.
-</p>
-
-<p><a href="http://www.weblica.ch">
-weblica</a><br />
-Desktop CMS.
-</p>
-
-<p><a href="http://www.webofweb.net">
-Web of Web</a><br />
-Collaborative and realtime interactive media platform for the web.
-</p>
-
-<p><a href="http://code.google.com/p/werkzeugkasten">
-Werkzeugkasten</a><br />
-Minimum Java Toolset.
-</p>
-
-<p><a href="http://vpda.org/">
-VPDA</a><br />
-View providers driven applications is a Java based application framework
-for building applications composed from server components - view providers.
-</p>
-
-<p><a href="http://sourceforge.net/projects/volunteerbase">
-Volunteer database</a><br />
-A database front end to register volunteers, partnership and donation for a Non Profit organization.
-</p>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
-
diff --git a/modules/h2/src/docsrc/html/main.html b/modules/h2/src/docsrc/html/main.html
deleted file mode 100644
index 620b120..0000000
--- a/modules/h2/src/docsrc/html/main.html
+++ /dev/null
@@ -1,46 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head>
-<meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<meta name="description" content="H2 is free SQL database written in Java"/>
-<title>
-H2 Database Engine
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>H2 Database Engine</h1>
-<p>
-Welcome to H2, the free Java SQL database engine.
-</p>
-
-<p>
-<a href="quickstart.html" style="font-size: 16px; font-weight: bold">Quickstart</a>
-<br />
-Get a fast overview.
-</p>
-
-<p>
-<a href="tutorial.html" style="font-size: 16px; font-weight: bold">Tutorial</a>
-<br />
-Go through the samples.
-</p>
-
-<p>
-<a href="features.html" style="font-size: 16px; font-weight: bold">Features</a>
-<br />
-See what this database can do and how to use these features.
-</p>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
-
diff --git a/modules/h2/src/docsrc/html/mainWeb.html b/modules/h2/src/docsrc/html/mainWeb.html
deleted file mode 100644
index a563112..0000000
--- a/modules/h2/src/docsrc/html/mainWeb.html
+++ /dev/null
@@ -1,195 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head>
-<meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<meta name="description" content="H2 is free SQL database written in Java" />
-<title>
-H2 Database Engine
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<link rel="alternate" type="application/atom+xml" title="H2 Newsfeed (Atom)" href="http://www.h2database.com/html/newsfeed-atom.xml" />
-<link rel="alternate" type="application/rss+xml" title="H2 Newsfeed (RSS)" href="http://www.h2database.com/html/newsfeed-rss.xml" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>H2 Database Engine</h1>
-<p>
-Welcome to H2, the Java SQL database. The main features of H2 are:
-</p>
-<ul>
-<li>Very fast, open source, JDBC API
-</li><li>Embedded and server modes; in-memory databases
-</li><li>Browser based Console application
-</li><li>Small footprint: around 2 MB jar file size
-</li></ul>
-
-<table style="border: 0px; width: 470px;">
-    <tr><td style="border: 0px; background-color: #eee;">
-        <table style="border: 0px; margin: 0px 7px 12px 7px;">
-            <tr><td style="border: 0px; background-color: #eee;" colspan="2">
-                <h2 style="margin-top: 1em;">Download</h2>
-                Version ${version} (${versionDate})
-            </td></tr>
-            <tr><td style="border: 0px; background-color: #eee;">
-                <a href="http://www.h2database.com/h2-setup-${versionDate}.exe"><img src="images/download-2.png" alt="Download this database" width="22" height="22"/></a>
-            </td><td style="vertical-align: middle; border: 0px; background-color: #eee;">
-                <a href="http://www.h2database.com/h2-setup-${versionDate}.exe">Windows Installer (5 MB)</a>
-            </td></tr>
-            <tr><td style="border: 0px; background-color: #eee;">
-                <a href="http://www.h2database.com/h2-${versionDate}.zip"><img src="images/download-2.png" alt="Download this database" width="22" height="22"/></a>
-            </td><td style="vertical-align: middle; border: 0px; background-color: #eee;">
-                <a href="http://www.h2database.com/h2-${versionDate}.zip">All Platforms (zip, 8 MB)</a>
-            </td></tr>
-            <tr><td style="border: 0px; background-color: #eee;" colspan="2">
-                <a href="download.html">All Downloads</a>
-            </td></tr>
-        </table>
-    </td>
-    <td style="border: 0px;">&nbsp;&nbsp;&nbsp;</td>
-    <td style="border: 0px; background-color: #eee;">
-        <table style="border: 0px; margin: 0px 7px 12px 7px;">
-            <tr><td style="border: 0px; background-color: #eee;">
-                <h2 style="margin-top: 1em;">Support</h2>
-                <p>
-                    <a href="https://stackoverflow.com/questions/tagged/h2">Stack Overflow (tag H2)</a><br /><br />
-                    <a href="https://groups.google.com/forum/#!forum/h2-database">Google Group English</a>,
-                    <a href="https://groups.google.com/forum/#!forum/h2-database-jp">Japanese</a><br /><br />
-                    For non-technical issues, use: <br />
-                    <script type="text/javascript">
-                    <!--
-                    var c = 'support ';
-                    var d = 'd&#98;';
-                    var e = 'at ';
-                    var f = '.&#99;&#111;&#109;';
-                    var g = 'h2database';
-                    document.write(d + c + '<!-'+'- x -' + '->' + e + '<span style="display:none"> (no sp<!-'+'- -'+'->am please) </span>' + g + f);
-                    //-->
-                    </script>
-                </p>
-            </td></tr>
-        </table>
-    </td></tr>
-
-<tr><td colspan="3" style="border: 0px; padding: 5px 0px 15px 0px;">
-    <h2 style="margin-top: 1em;">Features</h2>
-    <table style="width: 470px;"><tr class="notranslate">
-        <th></th>
-        <th>H2</th>
-        <th><a href="http://db.apache.org/derby">Derby</a></th>
-        <th><a href="http://hsqldb.org">HSQLDB</a></th>
-        <th><a href="https://www.mysql.com/">MySQL</a></th>
-        <th><a href="https://www.postgresql.org/">PostgreSQL</a></th>
-        </tr><tr>
-        <td>Pure Java</td>
-        <td class="compareY">Yes</td>
-        <td class="compareY">Yes</td>
-        <td class="compareY">Yes</td>
-        <td class="compareN">No</td>
-        <td class="compareN">No</td>
-        </tr><tr>
-        <td>Memory Mode</td>
-        <td class="compareY">Yes</td>
-        <td class="compareY">Yes</td>
-        <td class="compareY">Yes</td>
-        <td class="compareN">No</td>
-        <td class="compareN">No</td>
-        </tr><tr>
-        <td>Encrypted Database</td>
-        <td class="compareY">Yes</td>
-        <td class="compareY">Yes</td>
-        <td class="compareY">Yes</td>
-        <td class="compareN">No</td>
-        <td class="compareN">No</td>
-        </tr><tr>
-        <td>ODBC Driver</td>
-        <td class="compareY">Yes</td>
-        <td class="compareN">No</td>
-        <td class="compareN">No</td>
-        <td class="compareY">Yes</td>
-        <td class="compareY">Yes</td>
-        </tr><tr>
-        <td>Fulltext Search</td>
-        <td class="compareY">Yes</td>
-        <td class="compareN">No</td>
-        <td class="compareN">No</td>
-        <td class="compareY">Yes</td>
-        <td class="compareY">Yes</td>
-        </tr><tr>
-        <td>Multi Version Concurrency</td>
-        <td class="compareY">Yes</td>
-        <td class="compareN">No</td>
-        <td class="compareY">Yes</td>
-        <td class="compareY">Yes</td>
-        <td class="compareY">Yes</td>
-        </tr><tr>
-        <td>Footprint (embedded)</td>
-        <td>~2 MB</td>
-        <td>~3 MB</td>
-        <td>~1.5 MB</td>
-        <td>&#8212;</td>
-        <td>&#8212;</td>
-        </tr><tr>
-        <td>Footprint (client)</td>
-        <td>~500 KB</td>
-        <td>~600 KB</td>
-        <td>~1.5 MB</td>
-        <td>~1 MB</td>
-        <td>~700 KB</td>
-        </tr>
-    </table>
-</td></tr>
-
-<tr><td colspan="3" style="border: 0px; background-color: #eee;">
-    <table style="border: 0px; margin: 0px 7px 0px 7px;">
-        <tr><td style="border: 0px; background-color: #eee;">
-            <h2 style="margin-top: 1em;">News</h2>
-            <p>
-            <b>Newsfeeds:</b>
-            <a href="http://www.h2database.com/html/newsfeed-atom.xml">Full text (Atom)</a>
-            or <a href="http://www.h2database.com/html/newsfeed-rss.xml">Header only (RSS)</a>.
-            </p><p>
-                <b>Email Newsletter:</b> Subscribe to
-                <a href="https://groups.google.com/forum/#!forum/h2database-news/join">
-                H2 Database News (Google account required)</a>
-                to get informed about new releases.
-                Your email address is only used in this context.
-            </p>
-        </td></tr>
-    </table>
-</td></tr>
-
-<tr><td colspan="3" style="border: 0px">&nbsp;</td></tr>
-
-<tr><td colspan="3" style="border: 0px; background-color: #eee;">
-    <table style="border: 0px; margin: 0px 7px 5px 7px;">
-        <tr><td style="border: 0px; background-color: #eee;">
-            <h2 style="margin-top: 1em;">Contribute</h2>
-            <p>
-            You can contribute to the development of H2 by sending feedback and bug
-            reports, or translate the H2 Console application (for details, start the H2 Console
-            and select Options / Translate).
-            To donate money, click on the PayPal button below. You will be listed as a <a href="http://h2database.com/html/history.html#supporters">supporter</a>:
-            </p>
-            <form action="https://www.paypal.com/cgi-bin/webscr" method="post">
-            <p>
-            <input type="hidden" name="cmd" value="_s-xclick"/>
-            <input type="image" src="images/paypal-donate.png" width="108" height="108" name="submit" alt="PayPal icon"/>
-            <input type="hidden" name="encrypted" value="-----BEGIN PKCS7-----MIIHNwYJKoZIhvcNAQcEoIIHKDCCByQCAQExggEwMIIBLAIBADCBlDCBjjELMAkGA1UEBhMCVVMxCzAJBgNVBAgTAkNBMRYwFAYDVQQHEw1Nb3VudGFpbiBWaWV3MRQwEgYDVQQKEwtQYXlQYWwgSW5jLjETMBEGA1UECxQKbGl2ZV9jZXJ0czERMA8GA1UEAxQIbGl2ZV9hcGkxHDAaBgkqhkiG9w0BCQEWDXJlQHBheXBhbC5jb20CAQAwDQYJKoZIhvcNAQEBBQAEgYBT5YHCnqqyWDNUoD0DGudVB/0gMr1D2iOAKr/X+zR9VGBMeZsBtgmJphsbszGxXXEGxwzIVAv/ys+8TKW/uvk9UvZcDqFbCvupXmVIv3dp143N1xHsyLQGGHd8aFNraqCF7fdFoQ8GHz [...]
-            </p>
-            </form>
-        </td></tr>
-    </table>
-</td></tr>
-
-</table>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
diff --git a/modules/h2/src/docsrc/html/mvstore.html b/modules/h2/src/docsrc/html/mvstore.html
deleted file mode 100644
index 660828e..0000000
--- a/modules/h2/src/docsrc/html/mvstore.html
+++ /dev/null
@@ -1,749 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head>
-<meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-<meta name="viewport" content="width=device-width, initial-scale=1" />
-<title>
-MVStore
-</title>
-<link rel="stylesheet" type="text/css" href="stylesheet.css" />
-<!-- [search] { -->
-<script type="text/javascript" src="navigation.js"></script>
-</head><body onload="frameMe();">
-<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
-<!-- } -->
-
-<h1>MVStore</h1>
-<a href="#overview">
-    Overview</a><br />
-<a href="#example_code">
-    Example Code</a><br />
-<a href="#store_builder">
-    Store Builder</a><br />
-<a href="#r_tree">
-    R-Tree</a><br />
-
-<a href="#features">
-    Features</a><br />
-<a href="#maps">- Maps</a><br />
-<a href="#versions">- Versions</a><br />
-<a href="#transactions">- Transactions</a><br />
-<a href="#inMemory">- In-Memory Performance and Usage</a><br />
-<a href="#dataTypes">- Pluggable Data Types</a><br />
-<a href="#blob">- BLOB Support</a><br />
-<a href="#pluggableMap">- R-Tree and Pluggable Map Implementations</a><br />
-<a href="#caching">- Concurrent Operations and Caching</a><br />
-<a href="#logStructured">- Log Structured Storage</a><br />
-<a href="#offHeap">- Off-Heap and Pluggable Storage</a><br />
-<a href="#fileSystem">- File System Abstraction, File Locking and Online Backup</a><br />
-<a href="#encryption">- Encrypted Files</a><br />
-<a href="#tools">- Tools</a><br />
-<a href="#exceptionHandling">- Exception Handling</a><br />
-<a href="#storageEngine">- Storage Engine for H2</a><br />
-
-<a href="#fileFormat">
-    File Format</a><br />
-
-<a href="#differences">
-    Similar Projects and Differences to Other Storage Engines</a><br />
-<a href="#current_state">
-    Current State</a><br />
-<a href="#requirements">
-    Requirements</a><br />
-
-<h2 id="overview">Overview</h2>
-<p>
-The MVStore is a persistent, log structured key-value store.
-It is planned to be the next storage subsystem of H2,
-but it can also be used directly within an application, without using JDBC or SQL.
-</p>
-<ul><li>MVStore stands for "multi-version store".
-</li><li>Each store contains a number of maps that can be accessed using the <code>java.util.Map</code> interface.
-</li><li>Both file-based persistence and in-memory operation are supported.
-</li><li>It is intended to be fast, simple to use, and small.
-</li><li>Concurrent read and write operations are supported.
-</li><li>Transactions are supported (including concurrent transactions and 2-phase commit).
-</li><li>The tool is very modular.
-    It supports pluggable data types and serialization,
-    pluggable storage (to a file, to off-heap memory),
-    pluggable map implementations (B-tree, R-tree, concurrent B-tree currently),
-    BLOB storage,
-    and a file system abstraction to support encrypted files and zip files.
-</li></ul>
-
-<h2 id="example_code">Example Code</h2>
-<p>
-The following sample code shows how to use the tool:
-</p>
-<pre>
-import org.h2.mvstore.*;
-
-// open the store (in-memory if fileName is null)
-MVStore s = MVStore.open(fileName);
-
-// create/get the map named "data"
-MVMap&lt;Integer, String&gt; map = s.openMap("data");
-
-// add and read some data
-map.put(1, "Hello World");
-System.out.println(map.get(1));
-
-// close the store (this will persist changes)
-s.close();
-</pre>
-
-<h2 id="store_builder">Store Builder</h2>
-<p>
-The <code>MVStore.Builder</code> provides a fluid interface
-to build a store if configuration options are needed.
-Example usage:
-</p>
-<pre>
-MVStore s = new MVStore.Builder().
-    fileName(fileName).
-    encryptionKey("007".toCharArray()).
-    compress().
-    open();
-</pre>
-<p>
-The list of available options is:
-</p>
-<ul><li>autoCommitBufferSize: the size of the write buffer.
-</li><li>autoCommitDisabled: to disable auto-commit.
-</li><li>backgroundExceptionHandler: a handler for
-    exceptions that could occur while writing in the background.
-</li><li>cacheSize: the cache size in MB.
-</li><li>compress: compress the data when storing
-    using a fast algorithm (LZF).
-</li><li>compressHigh: compress the data when storing
-    using a slower algorithm (Deflate).
-</li><li>encryptionKey: the key for file encryption.
-</li><li>fileName: the name of the file, for file based stores.
-</li><li>fileStore: the storage implementation to use.
-</li><li>pageSplitSize: the point where pages are split.
-</li><li>readOnly: open the file in read-only mode.
-</li></ul>
-
-<h2 id="r_tree">R-Tree</h2>
-<p>
-The <code>MVRTreeMap</code> is an R-tree implementation
-that supports fast spatial queries. It can be used as follows:
-</p>
-<pre>
-// create an in-memory store
-MVStore s = MVStore.open(null);
-
-// open an R-tree map
-MVRTreeMap&lt;String&gt; r = s.openMap("data",
-        new MVRTreeMap.Builder&lt;String&gt;());
-
-// add two key-value pairs
-// the first value is the key id (to make the key unique)
-// then the min x, max x, min y, max y
-r.add(new SpatialKey(0, -3f, -2f, 2f, 3f), "left");
-r.add(new SpatialKey(1, 3f, 4f, 4f, 5f), "right");
-
-// iterate over the intersecting keys
-Iterator&lt;SpatialKey&gt; it =
-        r.findIntersectingKeys(new SpatialKey(0, 0f, 9f, 3f, 6f));
-for (SpatialKey k; it.hasNext();) {
-    k = it.next();
-    System.out.println(k + ": " + r.get(k));
-}
-s.close();
-</pre>
-<p>
-The default number of dimensions is 2. To use a different number of dimensions,
-call <code>new MVRTreeMap.Builder&lt;String&gt;().dimensions(3)</code>.
-The minimum number of dimensions is 1, the maximum is 32.
-</p>
-
-<h2 id="features">Features</h2>
-
-<h3 id="maps">Maps</h3>
-<p>
-Each store contains a set of named maps.
-A map is sorted by key, and supports the common lookup operations,
-including access to the first and last key, iterate over some or all keys, and so on.
-</p><p>
-Also supported, and very uncommon for maps, is fast index lookup:
-the entries of the map can be efficiently accessed like a random-access list
-(get the entry at the given index), and the index of a key can be calculated efficiently.
-That also means getting the median of two keys is very fast,
-and a range of keys can be counted very quickly.
-The iterator supports fast skipping.
-This is possible because internally, each map is organized in the form of a counted B+-tree.
-</p><p>
-In database terms, a map can be used like a table, where the key of the map is the primary key of the table,
-and the value is the row. A map can also represent an index, where the key of the map is the key
-of the index, and the value of the map is the primary key of the table (for non-unique indexes,
-the key of the map must also contain the primary key).
-</p>
-
-<h3 id="versions">Versions</h3>
-<p>
-A version is a snapshot of all the data of all maps at a given point in time.
-Creating a snapshot is fast: only those pages that are changed after a snapshot are copied.
-This behavior is also called COW (copy on write).
-Old versions are readable.
-Rollback to an old version is supported.
-</p><p>
-The following sample code show how to create a store, open a map, add some data,
-and access the current and an old version:
-</p>
-<pre>
-// create/get the map named "data"
-MVMap&lt;Integer, String&gt; map = s.openMap("data");
-
-// add some data
-map.put(1, "Hello");
-map.put(2, "World");
-
-// get the current version, for later use
-long oldVersion = s.getCurrentVersion();
-
-// from now on, the old version is read-only
-s.commit();
-
-// more changes, in the new version
-// changes can be rolled back if required
-// changes always go into "head" (the newest version)
-map.put(1, "Hi");
-map.remove(2);
-
-// access the old data (before the commit)
-MVMap&lt;Integer, String&gt; oldMap =
-        map.openVersion(oldVersion);
-
-// print the old version (can be done
-// concurrently with further modifications)
-// this will print "Hello" and "World":
-System.out.println(oldMap.get(1));
-System.out.println(oldMap.get(2));
-
-// print the newest version ("Hi")
-System.out.println(map.get(1));
-</pre>
-
-<h3 id="transactions">Transactions</h3>
-<p>
-To support multiple concurrent open transactions, a transaction utility is included,
-the <code>TransactionStore</code>.
-The tool supports "read committed" transaction isolation
-with savepoints, two-phase commit, and other features typically available in a database.
-There is no limit on the size of a transaction
-(the log is written to disk for large or long running transactions).
-</p><p>
-Internally, this utility stores the old versions of changed entries in a separate map, similar to a transaction log,
-except that entries of a closed transaction are removed, and the log is usually not stored for short transactions.
-For common use cases, the storage overhead of this utility is very small compared to the overhead of a regular transaction log.
-</p>
-
-<h3 id="inMemory">In-Memory Performance and Usage</h3>
-<p>
-Performance of in-memory operations is about 50% slower than
-<code>java.util.TreeMap</code>.
-</p><p>
-The memory overhead for large maps is slightly better than for the regular
-map implementations, but there is a higher overhead per map.
-For maps with less than about 25 entries, the regular map implementations need less memory.
-</p><p>
-If no file name is specified, the store operates purely in memory.
-Except for persisting data, all features are supported in this mode
-(multi-versioning, index lookup, R-tree and so on).
-If a file name is specified, all operations occur in memory (with the same
-performance characteristics) until data is persisted.
-</p><p>
-As in all map implementations, keys need to be immutable, that means
-changing the key object after an entry has been added is not allowed.
-If a file name is specified, the value may also not be changed after
-adding an entry, because it might be serialized
-(which could happen at any time when autocommit is enabled).
-</p>
-
-<h3 id="dataTypes">Pluggable Data Types</h3>
-<p>
-Serialization is pluggable. The default serialization currently supports many common data types,
-and uses Java serialization for other objects. The following classes are currently directly supported:
-<code>Boolean, Byte, Short, Character, Integer, Long, Float, Double, BigInteger, BigDecimal,
-String, UUID, Date</code> and arrays (both primitive arrays and object arrays).
-For serialized objects, the size estimate is adjusted using an exponential moving average.
-</p><p>
-Parameterized data types are supported
-(for example one could build a string data type that limits the length).
-</p><p>
-The storage engine itself does not have any length limits, so that keys, values,
-pages, and chunks can be very big (as big as fits in memory).
-Also, there is no inherent limit to the number of maps and chunks.
-Due to using a log structured storage, there is no special case handling for large keys or pages.
-</p>
-
-<h3 id="blob">BLOB Support</h3>
-<p>
-There is a mechanism that stores large binary objects by splitting them into smaller blocks.
-This allows to store objects that don't fit in memory.
-Streaming as well as random access reads on such objects are supported.
-This tool is written on top of the store, using only the map interface.
-</p>
-
-<h3 id="pluggableMap">R-Tree and Pluggable Map Implementations</h3>
-<p>
-The map implementation is pluggable.
-In addition to the default <code>MVMap</code> (multi-version map),
-there is a multi-version R-tree map implementation for spatial operations.
-</p>
-
-<h3 id="caching">Concurrent Operations and Caching</h3>
-<p>
-Concurrent reads and writes are supported.
-All such read operations can occur in parallel. Concurrent reads from the page cache,
-as well as concurrent reads from the file system are supported.
-Write operations first read the relevant pages from disk to memory
-(this can happen concurrently), and only then modify the data.
-The in-memory parts of write operations are synchronized.
-Writing changes to the file can occur concurrently to modifying the data,
-as writing operates on a snapshot.
-</p><p>
-Caching is done on the page level.
-The page cache is a concurrent LIRS cache, which should be resistant against scan operations.
-</p><p>
-For fully scalable concurrent write operations to a map (in-memory and to disk),
-the map could be split into multiple maps in different stores ('sharding').
-The plan is to add such a mechanism later when needed.
-</p>
-
-<h3 id="logStructured">Log Structured Storage</h3>
-<p>
-Internally, changes are buffered in memory, and once enough changes have accumulated,
-they are written in one continuous disk write operation.
-Compared to traditional database storage engines,
-this should improve write performance for file systems and storage systems
-that do not efficiently support small random writes, such as Btrfs, as well as SSDs.
-(According to a test, write throughput of a common SSD increases with write block size,
-until a block size of 2 MB, and then does not further increase.)
-By default, changes are automatically written when more than a number of pages are modified,
-and once every second in a background thread, even if only little data was changed.
-Changes can also be written explicitly by calling <code>commit()</code>.
-</p><p>
-When storing, all changed pages are serialized,
-optionally compressed using the LZF algorithm,
-and written sequentially to a free area of the file.
-Each such change set is called a chunk.
-All parent pages of the changed B-trees are stored in this chunk as well,
-so that each chunk also contains the root of each changed map
-(which is the entry point for reading this version of the data).
-There is no separate index: all data is stored as a list of pages.
-Per store, there is one additional map that contains the metadata (the list of
-maps, where the root page of each map is stored, and the list of chunks).
-</p><p>
-There are usually two write operations per chunk:
-one to store the chunk data (the pages), and one to update the file header (so it points to the latest chunk).
-If the chunk is appended at the end of the file, the file header is only written at the end of the chunk.
-There is no transaction log, no undo log,
-and there are no in-place updates (however, unused chunks are overwritten by default).
-</p><p>
-Old data is kept for at least 45 seconds (configurable),
-so that there are no explicit sync operations required to guarantee data consistency.
-An application can also sync explicitly when needed.
-To reuse disk space, the chunks with the lowest amount of live data are compacted
-(the live data is stored again in the next chunk).
-To improve data locality and disk space usage, the plan is to automatically defragment and compact data.
-</p><p>
-Compared to traditional storage engines (that use a transaction log, undo log, and main storage area),
-the log structured storage is simpler, more flexible, and typically needs less disk operations per change,
-as data is only written once instead of twice or 3 times, and because the B-tree pages are
-always full (they are stored next to each other) and can be easily compressed.
-But temporarily, disk space usage might actually be a bit higher than for a regular database,
-as disk space is not immediately re-used (there are no in-place updates).
-</p>
-
-<h3 id="offHeap">Off-Heap and Pluggable Storage</h3>
-<p>
-Storage is pluggable. Unless pure in-memory operation is used, the default storage is to a single file.
-</p>
-<p>
-An off-heap storage implementation is available. This storage keeps the data in the off-heap memory,
-meaning outside of the regular garbage collected heap. This allows to use very large in-memory
-stores without having to increase the JVM heap, which would increase Java garbage collection
-pauses a lot. Memory is allocated using <code>ByteBuffer.allocateDirect</code>.
-One chunk is allocated at a time (each chunk is usually a few MB large), so that
-allocation cost is low. To use the off-heap storage, call:
-</p>
-<pre>
-OffHeapStore offHeap = new OffHeapStore();
-MVStore s = new MVStore.Builder().
-        fileStore(offHeap).open();
-</pre>
-
-<h3 id="fileSystem">File System Abstraction, File Locking and Online Backup</h3>
-<p>
-The file system is pluggable. The same file system abstraction is used as H2 uses.
-The file can be encrypted using a encrypting file system wrapper.
-Other file system implementations support reading from a compressed zip or jar file.
-The file system abstraction closely matches the Java 7 file system API.
-</p>
-<p>
-Each store may only be opened once within a JVM.
-When opening a store, the file is locked in exclusive mode, so that
-the file can only be changed from within one process.
-Files can be opened in read-only mode, in which case a shared lock is used.
-</p>
-<p>
-The persisted data can be backed up at any time,
-even during write operations (online backup).
-To do that, automatic disk space reuse needs to be first disabled, so that
-new data is always appended at the end of the file.
-Then, the file can be copied. The file handle is available to the application.
-It is recommended to use the utility class <code>FileChannelInputStream</code> to do this.
-For encrypted databases, both the encrypted (raw) file content,
-as well as the clear text content, can be backed up.
-</p>
-
-<h3 id="encryption">Encrypted Files</h3>
-<p>
-File encryption ensures the data can only be read with the correct password.
-Data can be encrypted as follows:
-</p>
-<pre>
-MVStore s = new MVStore.Builder().
-    fileName(fileName).
-    encryptionKey("007".toCharArray()).
-    open();
-</pre>
-<p>
-</p><p>
-The following algorithms and settings are used:
-</p>
-<ul><li>The password char array is cleared after use,
-    to reduce the risk that the password is stolen
-    even if the attacker has access to the main memory.
-</li><li>The password is hashed according to the PBKDF2 standard,
-    using the SHA-256 hash algorithm.
-</li><li>The length of the salt is 64 bits,
-    so that an attacker can not use a pre-calculated password hash table (rainbow table).
-    It is generated using a cryptographically secure random number generator.
-</li><li>To speed up opening an encrypted stores on Android,
-    the number of PBKDF2 iterations is 10.
-    The higher the value, the better the protection against brute-force password cracking attacks,
-    but the slower is opening a file.
-</li><li>The file itself is encrypted using the standardized disk encryption mode XTS-AES.
-    Only little more than one AES-128 round per block is needed.
-</li></ul>
-
-<h3 id="tools">Tools</h3>
-<p>
-There is a tool, the <code>MVStoreTool</code>, to dump the contents of a file.
-</p>
-
-<h3 id="exceptionHandling">Exception Handling</h3>
-<p>
-This tool does not throw checked exceptions.
-Instead, unchecked exceptions are thrown if needed.
-The error message always contains the version of the tool.
-The following exceptions can occur:
-</p>
-<ul><li><code>IllegalStateException</code> if a map was already closed or
-    an IO exception occurred, for example if the file was locked, is already closed,
-    could not be opened or closed, if reading or writing failed,
-    if the file is corrupt, or if there is an internal error in the tool.
-    For such exceptions, an error code is added
-    so that the application can distinguish between different error cases.
-</li><li><code>IllegalArgumentException</code> if a method was called with an illegal argument.
-</li><li><code>UnsupportedOperationException</code> if a method was called that is not supported,
-    for example trying to modify a read-only map.
-</li><li><code>ConcurrentModificationException</code> if a map is modified concurrently.
-</li></ul>
-
-<h3 id="storageEngine">Storage Engine for H2</h3>
-<p>
-For H2 version 1.4 and newer, the MVStore is the default storage engine
-(supporting SQL, JDBC, transactions, MVCC, and so on).
-For older versions, append
-<code>;MV_STORE=TRUE</code>
-to the database URL.
-</p>
-
-<h2 id="fileFormat">File Format</h2>
-<p>
-The data is stored in one file.
-The file contains two file headers (for safety), and a number of chunks.
-The file headers are one block each; a block is 4096 bytes.
-Each chunk is at least one block, but typically 200 blocks or more.
-Data is stored in the chunks in the form of a
-<a href="https://en.wikipedia.org/wiki/Log-structured_file_system">log structured storage</a>.
-There is one chunk for every version.
-</p>
-<pre>
-[ file header 1 ] [ file header 2 ] [ chunk ] [ chunk ] ... [ chunk ]
-</pre>
-<p>
-Each chunk contains a number of B-tree pages.
-As an example, the following code:
-</p>
-<pre>
-MVStore s = MVStore.open(fileName);
-MVMap&lt;Integer, String&gt; map = s.openMap("data");
-for (int i = 0; i &lt; 400; i++) {
-    map.put(i, "Hello");
-}
-s.commit();
-for (int i = 0; i &lt; 100; i++) {
-    map.put(i, "Hi");
-}
-s.commit();
-s.close();
-</pre>
-<p>
-will result in the following two chunks (excluding metadata):
-</p>
-<p>
-<b>Chunk 1:</b><br />
-- Page 1: (root) node with 2 entries pointing to page 2 and 3<br />
-- Page 2: leaf with 140 entries (keys 0 - 139)<br />
-- Page 3: leaf with 260 entries (keys 140 - 399)<br />
-</p>
-<p>
-<b>Chunk 2:</b><br />
-- Page 4: (root) node with 2 entries pointing to page 5 and 3<br />
-- Page 5: leaf with 140 entries (keys 0 - 139)<br />
-</p>
-<p>
-That means each chunk contains the changes of one version:
-the new version of the changed pages and the parent pages, recursively, up to the root page.
-Pages in subsequent chunks refer to pages in earlier chunks.
-</p>
-
-<h3>File Header</h3>
-<p>
-There are two file headers, which normally contain the exact same data.
-But once in a while, the file headers are updated, and writing could partially fail,
-which could corrupt a header. That's why there is a second header.
-Only the file headers are updated in this way (called "in-place update").
-The headers contain the following data:
-</p>
-<pre>
-H:2,block:2,blockSize:1000,chunk:7,created:1441235ef73,format:1,version:7,fletcher:3044e6cc
-</pre>
-<p>
-The data is stored in the form of a key-value pair.
-Each value is stored as a hexadecimal number. The entries are:
-</p>
-<ul><li>H: The entry "H:2" stands for the H2 database.
-</li><li>block: The block number where one of the newest chunks starts
-    (but not necessarily the newest).
-</li><li>blockSize: The block size of the file; currently always hex 1000, which is decimal 4096,
-    to match the <a href="https://en.wikipedia.org/wiki/Disk_sector">disk sector</a>
-    length of modern hard disks.
-</li><li>chunk: The chunk id, which is normally the same value as the version;
-    however, the chunk id might roll over to 0, while the version doesn't.
-</li><li>created: The number of milliseconds since 1970 when the file was created.
-</li><li>format: The file format number. Currently 1.
-</li><li>version: The version number of the chunk.
-</li><li>fletcher: The <a href="https://en.wikipedia.org/wiki/Fletcher's_checksum">
-    Fletcher-32 checksum</a> of the header.
-</li></ul>
-<p>
-When opening the file, both headers are read and the checksum is verified.
-If both headers are valid, the one with the newer version is used.
-The chunk with the latest version is then detected (details about this see below),
-and the rest of the metadata is read from there.
-If the chunk id, block and version are not stored in the file header,
-then the latest chunk lookup starts with the last chunk in the file.
-</p>
-<p>
-</p>
-
-<h3>Chunk Format</h3>
-<p>
-There is one chunk per version.
-Each chunk consists of a header, the pages that were modified in this version, and a footer.
-The pages contain the actual data of the maps.
-The pages inside a chunk are stored right after the header, next to each other (unaligned).
-The size of a chunk is a multiple of the block size.
-The footer is stored in the last 128 bytes of the chunk.
-</p>
-<pre>
-[ header ] [ page ] [ page ] ... [ page ] [ footer ]
-</pre>
-<p>
-The footer allows to verify that the chunk is completely written (a chunk is written as one write operation),
-and allows to find the start position of the very last chunk in the file.
-The chunk header and footer contain the following data:
-</p>
-<pre>
-chunk:1,block:2,len:1,map:6,max:1c0,next:3,pages:2,root:4000004f8c,time:1fc,version:1
-chunk:1,block:2,version:1,fletcher:aed9a4f6
-</pre>
-<p>
-The fields of the chunk header and footer are:
-</p>
-<ul><li>chunk: The chunk id.
-</li><li>block: The first block of the chunk (multiply by the block size to get the position in the file).
-</li><li>len: The size of the chunk in number of blocks.
-</li><li>map: The id of the newest map; incremented when a new map is created.
-</li><li>max: The sum of all maximum page sizes (see page format).
-</li><li>next: The predicted start block of the next chunk.
-</li><li>pages: The number of pages in the chunk.
-</li><li>root: The position of the metadata root page (see page format).
-</li><li>time: The time the chunk was written, in milliseconds after the file was created.
-</li><li>version: The version this chunk represents.
-</li><li>fletcher: The checksum of the footer.
-</li></ul>
-<p>
-Chunks are never updated in-place. Each chunk contains the pages that were
-changed in that version (there is one chunk per version, see above),
-plus all the parent nodes of those pages, recursively, up to the root page.
-If an entry in a map is changed, removed, or added, then the respective page is copied,
-modified, and stored in the next chunk, and the number of live pages in the old chunk is decremented.
-This mechanism is called copy-on-write, and is similar to how the
-<a href="https://en.wikipedia.org/wiki/Btrfs">Btrfs</a> file system works.
-Chunks without live pages are marked as free, so the space can be re-used by more recent chunks.
-Because not all chunks are of the same size, there can be a number of free blocks in front of a chunk
-for some time (until a small chunk is written or the chunks are compacted).
-There is a <a href="http://stackoverflow.com/questions/13650134/after-how-many-seconds-are-file-system-write-buffers-typically-flushed">
-delay of 45 seconds</a> (by default) before a free chunk is overwritten,
-to ensure new versions are persisted first.
-</p>
-<p>
-How the newest chunk is located when opening a store:
-The file header contains the position of a recent chunk, but not always the newest one.
-This is to reduce the number of file header updates.
-After opening the file, the file headers, and the chunk footer of the very last chunk
-(at the end of the file) are read.
-From those candidates, the header of the most recent chunk is read.
-If it contains a "next" pointer (see above), those chunk's header and footer are read as well.
-If it turned out to be a newer valid chunk, this is repeated, until the newest chunk was found.
-Before writing a chunk, the position of the next chunk is predicted based on the assumption
-that the next chunk will be of the same size as the current one.
-When the next chunk is written, and the previous
-prediction turned out to be incorrect, the file header is updated as well.
-In any case, the file header is updated if the next chain gets longer than 20 hops.
-</p>
-
-<h3>Page Format</h3>
-<p>
-Each map is a <a href="https://en.wikipedia.org/wiki/B-tree">B-tree</a>,
-and the map data is stored in (B-tree-) pages.
-There are leaf pages that contain the key-value pairs of the map,
-and internal nodes, which only contain keys and pointers to leaf pages.
-The root of a tree is either a leaf or an internal node.
-Unlike file header and chunk header and footer, the page data is not human readable.
-Instead, it is stored as byte arrays, with long (8 bytes), int (4 bytes), short (2 bytes),
-and <a href="https://en.wikipedia.org/wiki/Variable-length_quantity">variable size int and long</a>
-(1 to 5 / 10 bytes). The page format is:
-</p>
-<ul><li>length (int): Length of the page in bytes.
-</li><li>checksum (short): Checksum (chunk id xor offset within the chunk xor page length).
-</li><li>mapId (variable size int): The id of the map this page belongs to.
-</li><li>len (variable size int): The number of keys in the page.
-</li><li>type (byte): The page type (0 for leaf page, 1 for internal node;
-    plus 2 if the keys and values are compressed with the LZF algorithm, or
-    plus 6 if the keys and values are compressed with the Deflate algorithm).
-</li><li>children (array of long; internal nodes only): The position of the children.
-</li><li>childCounts (array of variable size long; internal nodes only):
-    The total number of entries for the given child page.
-</li><li>keys (byte array): All keys, stored depending on the data type.
-</li><li>values (byte array; leaf pages only): All values, stored depending on the data type.
-</li></ul>
-<p>
-Even though this is not required by the file format, pages are stored in the following order:
-For each map, the root page is stored first, then the internal nodes (if there are any),
-and then the leaf pages.
-This should speed up reads for media where sequential reads are faster than random access reads.
-The metadata map is stored at the end of a chunk.
-</p>
-<p>
-Pointers to pages are stored as a long, using a special format:
-26 bits for the chunk id, 32 bits for the offset within the chunk, 5 bits for the length code,
-1 bit for the page type (leaf or internal node).
-The page type is encoded so that when clearing or removing a map, leaf pages don't
-have to be read (internal nodes do have to be read in order to know where all the pages are;
-but in a typical B-tree the vast majority of the pages are leaf pages).
-The absolute file position is not included so that chunks can be
-moved within the file without having to change page pointers;
-only the chunk metadata needs to be changed.
-The length code is a number from 0 to 31, where 0 means the maximum length
-of the page is 32 bytes, 1 means 48 bytes, 2: 64, 3: 96, 4: 128, 5: 192, and so on until 31 which
-means longer than 1 MB. That way, reading a page only requires one
-read operation (except for very large pages).
-The sum of the maximum length of all pages is stored in the chunk metadata (field "max"),
-and when a page is marked as removed, the live maximum length is adjusted.
-This allows to estimate the amount of free space within a block, in addition to the number of free pages.
-</p>
-<p>
-The total number of entries in child pages are kept to allow efficient range counting,
-lookup by index, and skip operations.
-The pages form a <a href="https://www.chiark.greenend.org.uk/~sgtatham/algorithms/cbtree.html">counted B-tree</a>.
-</p>
-<p>
-Data compression: The data after the page type are optionally compressed using the LZF algorithm.
-</p>
-
-<h3>Metadata Map</h3>
-<p>
-In addition to the user maps, there is one metadata map that contains names and
-positions of user maps, and chunk metadata.
-The very last page of a chunk contains the root page of that metadata map.
-The exact position of this root page is stored in the chunk header.
-This page (directly or indirectly) points to the root pages of all other maps.
-The metadata map of a store with a map named "data", and one chunk,
-contains the following entries:
-</p>
-<ul><li>chunk.1: The metadata of chunk 1. This is the same data as the chunk header,
-    plus the number of live pages, and the maximum live length.
-</li><li>map.1: The metadata of map 1. The entries are: name, createVersion, and type.
-</li><li>name.data: The map id of the map named "data". The value is "1".
-</li><li>root.1: The root position of map 1.
-</li><li>setting.storeVersion: The store version (a user defined value).
-</li></ul>
-
-<h2 id="differences">Similar Projects and Differences to Other Storage Engines</h2>
-<p>
-Unlike similar storage engines like LevelDB and Kyoto Cabinet,
-the MVStore is written in Java
-and can easily be embedded in a Java and Android application.
-</p><p>
-The MVStore is somewhat similar to the Berkeley DB Java Edition
-because it is also written in Java,
-and is also a log structured storage, but the H2 license is more liberal.
-</p><p>
-Like SQLite 3, the MVStore keeps all data in one file.
-Unlike SQLite 3, the MVStore uses is a log structured storage.
-The plan is to make the MVStore both easier to use as well as faster than SQLite 3.
-In a recent (very simple) test, the MVStore was about twice as fast as SQLite 3 on Android.
-</p><p>
-The API of the MVStore is similar to MapDB (previously known as JDBM) from Jan Kotek,
-and some code is shared between MVStore and MapDB.
-However, unlike MapDB, the MVStore uses is a log structured storage.
-The MVStore does not have a record size limit.
-</p>
-
-<h2 id="current_state">Current State</h2>
-<p>
-The code is still experimental at this stage.
-The API as well as the behavior may partially change.
-Features may be added and removed (even though the main features will stay).
-</p>
-
-<h2 id="requirements">Requirements</h2>
-<p>
-The MVStore is included in the latest H2 jar file.
-</p><p>
-There are no special requirements to use it.
-The MVStore should run on any JVM as well as on Android.
-</p><p>
-To build just the MVStore (without the database engine), run:
-</p>
-<pre>
-./build.sh jarMVStore
-</pre>
-<p>
-This will create the file <code>bin/h2mvstore-${version}.jar</code> (about 200 KB).
-</p>
-
-<!-- [close] { --></div></td></tr></table><!-- } --><!-- analytics --></body></html>
diff --git a/modules/h2/src/docsrc/html/navigation.js b/modules/h2/src/docsrc/html/navigation.js
deleted file mode 100644
... 27758 lines suppressed ...


[ignite] 03/17: IGNITE-11762 Mute testClientStartCloseServersRestart test with known issue

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit d2c944fc8a61b3c28564fd8d85fafb37e0a92776
Author: Pavel Kovalenko <jo...@gmail.com>
AuthorDate: Fri Apr 26 13:44:41 2019 +0300

    IGNITE-11762 Mute testClientStartCloseServersRestart test with known issue
    
    Signed-off-by: Pavel Kovalenko <jo...@gmail.com>
---
 .../internal/processors/cache/IgniteClientCacheStartFailoverTest.java   | 2 ++
 1 file changed, 2 insertions(+)

diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteClientCacheStartFailoverTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteClientCacheStartFailoverTest.java
index 2d91f92..961a2c5 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteClientCacheStartFailoverTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteClientCacheStartFailoverTest.java
@@ -49,6 +49,7 @@ import org.apache.ignite.lang.IgnitePredicate;
 import org.apache.ignite.plugin.extensions.communication.Message;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.junit.Ignore;
 import org.junit.Test;
 
 import static org.apache.ignite.cache.CacheAtomicityMode.ATOMIC;
@@ -437,6 +438,7 @@ public class IgniteClientCacheStartFailoverTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     @Test
+    @Ignore("https://issues.apache.org/jira/browse/IGNITE-11762")
     public void testClientStartCloseServersRestart() throws Exception {
         final int SRVS = 4;
         final int CLIENTS = 4;


[ignite] 14/17: GG-14890: Integrate H2 codebase to GG as separate module.

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 41536c7c6c4eec8b91c06667ab57118668fe14a8
Author: Andrey V. Mashenkov <an...@gmail.com>
AuthorDate: Mon Apr 29 19:03:34 2019 +0300

    GG-14890: Integrate H2 codebase to GG as separate module.
---
 modules/clients/pom.xml                            |     6 +-
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java    |    16 +-
 .../thin/JdbcThinDynamicIndexAbstractSelfTest.java |    16 +-
 modules/core/pom.xml                               |     6 +-
 .../processors/cache/H2CacheStoreStrategy.java     |     2 +-
 .../query/h2/opt/GridH2SpatialIndex.java           |    40 +-
 modules/h2/README.txt                              |    32 +
 modules/h2/licenses/EPL-1.0.txt                    |    86 +
 modules/h2/licenses/MPL-2.0.txt                    |   151 +
 modules/h2/licenses/gg-community.txt               |    13 +
 modules/h2/pom.xml                                 |   232 +
 modules/h2/src/docsrc/help/help.csv                |  5739 +++++++++
 modules/h2/src/docsrc/html/advanced.html           |  1968 +++
 modules/h2/src/docsrc/html/architecture.html       |   154 +
 modules/h2/src/docsrc/html/build.html              |   325 +
 modules/h2/src/docsrc/html/changelog.html          |  1487 +++
 modules/h2/src/docsrc/html/cheatSheet.html         |   216 +
 modules/h2/src/docsrc/html/commands.html           |   179 +
 modules/h2/src/docsrc/html/datatypes.html          |    99 +
 modules/h2/src/docsrc/html/download.html           |    76 +
 modules/h2/src/docsrc/html/faq.html                |   288 +
 modules/h2/src/docsrc/html/features.html           |  1719 +++
 modules/h2/src/docsrc/html/fragments.html          |   130 +
 modules/h2/src/docsrc/html/frame.html              |    40 +
 modules/h2/src/docsrc/html/functions.html          |   324 +
 modules/h2/src/docsrc/html/grammar.html            |   178 +
 modules/h2/src/docsrc/html/history.html            |   182 +
 .../html/images/connection-mode-embedded-2.png     |   Bin 0 -> 48466 bytes
 .../html/images/connection-mode-embedded.png       |   Bin 0 -> 20407 bytes
 .../docsrc/html/images/connection-mode-mixed-2.png |   Bin 0 -> 70685 bytes
 .../docsrc/html/images/connection-mode-mixed.png   |   Bin 0 -> 31588 bytes
 .../html/images/connection-mode-remote-2.png       |   Bin 0 -> 58248 bytes
 .../docsrc/html/images/connection-mode-remote.png  |   Bin 0 -> 25020 bytes
 modules/h2/src/docsrc/html/images/console-2.png    |   Bin 0 -> 68604 bytes
 modules/h2/src/docsrc/html/images/console.png      |   Bin 0 -> 29569 bytes
 modules/h2/src/docsrc/html/images/db-16.png        |   Bin 0 -> 547 bytes
 modules/h2/src/docsrc/html/images/db-64-t.png      |   Bin 0 -> 11867 bytes
 modules/h2/src/docsrc/html/images/download-2.png   |   Bin 0 -> 2673 bytes
 modules/h2/src/docsrc/html/images/download.png     |   Bin 0 -> 745 bytes
 modules/h2/src/docsrc/html/images/h2-logo-2.png    |   Bin 0 -> 4810 bytes
 modules/h2/src/docsrc/html/images/h2-logo.png      |   Bin 0 -> 3361 bytes
 .../h2/src/docsrc/html/images/h2-logo_square.png   |   Bin 0 -> 2330 bytes
 .../h2/src/docsrc/html/images/icon_disconnect.gif  |   Bin 0 -> 114 bytes
 modules/h2/src/docsrc/html/images/language_de.png  |   Bin 0 -> 240 bytes
 modules/h2/src/docsrc/html/images/language_en.gif  |   Bin 0 -> 268 bytes
 modules/h2/src/docsrc/html/images/language_ja.gif  |   Bin 0 -> 685 bytes
 modules/h2/src/docsrc/html/images/mail-support.png |   Bin 0 -> 756 bytes
 .../h2/src/docsrc/html/images/paypal-donate.png    |   Bin 0 -> 6172 bytes
 modules/h2/src/docsrc/html/images/performance.png  |   Bin 0 -> 2343 bytes
 modules/h2/src/docsrc/html/images/quickstart-1.png |   Bin 0 -> 13911 bytes
 modules/h2/src/docsrc/html/images/quickstart-2.png |   Bin 0 -> 3765 bytes
 modules/h2/src/docsrc/html/images/quickstart-3.png |   Bin 0 -> 11783 bytes
 modules/h2/src/docsrc/html/images/quickstart-4.png |   Bin 0 -> 30387 bytes
 modules/h2/src/docsrc/html/images/quickstart-5.png |   Bin 0 -> 36043 bytes
 modules/h2/src/docsrc/html/images/quickstart-6.png |   Bin 0 -> 31108 bytes
 modules/h2/src/docsrc/html/images/screenshot.png   |   Bin 0 -> 16894 bytes
 modules/h2/src/docsrc/html/installation.html       |   122 +
 modules/h2/src/docsrc/html/license.html            |   404 +
 modules/h2/src/docsrc/html/links.html              |   708 ++
 modules/h2/src/docsrc/html/main.html               |    46 +
 modules/h2/src/docsrc/html/mainWeb.html            |   195 +
 modules/h2/src/docsrc/html/mvstore.html            |   749 ++
 modules/h2/src/docsrc/html/navigation.js           |   195 +
 modules/h2/src/docsrc/html/performance.html        |   893 ++
 modules/h2/src/docsrc/html/quickstart.html         |   105 +
 modules/h2/src/docsrc/html/roadmap.html            |   532 +
 modules/h2/src/docsrc/html/search.js               |   273 +
 modules/h2/src/docsrc/html/source.html             |    52 +
 modules/h2/src/docsrc/html/sourceError.html        |   252 +
 modules/h2/src/docsrc/html/stylesheet.css          |   379 +
 modules/h2/src/docsrc/html/stylesheetPdf.css       |   154 +
 modules/h2/src/docsrc/html/systemtables.html       |    63 +
 modules/h2/src/docsrc/html/tutorial.html           |  1502 +++
 .../docsrc/images/connection-mode-embedded-2.png   |   Bin 0 -> 48466 bytes
 .../src/docsrc/images/connection-mode-mixed-2.png  |   Bin 0 -> 70685 bytes
 .../src/docsrc/images/connection-mode-remote-2.png |   Bin 0 -> 58248 bytes
 modules/h2/src/docsrc/images/connection-modes.svg  |  1118 ++
 modules/h2/src/docsrc/images/console-2.png         |   Bin 0 -> 68604 bytes
 modules/h2/src/docsrc/images/console.png           |   Bin 0 -> 29569 bytes
 modules/h2/src/docsrc/images/console.svg           |   515 +
 modules/h2/src/docsrc/images/db-16.png             |   Bin 0 -> 547 bytes
 modules/h2/src/docsrc/images/db-22.png             |   Bin 0 -> 1239 bytes
 modules/h2/src/docsrc/images/db-24.png             |   Bin 0 -> 574 bytes
 modules/h2/src/docsrc/images/db-32.png             |   Bin 0 -> 1399 bytes
 modules/h2/src/docsrc/images/db-64-t.png           |   Bin 0 -> 11867 bytes
 modules/h2/src/docsrc/images/db.svg                |   308 +
 modules/h2/src/docsrc/images/download-2.png        |   Bin 0 -> 2673 bytes
 modules/h2/src/docsrc/images/download.png          |   Bin 0 -> 745 bytes
 modules/h2/src/docsrc/images/download.svg          |   125 +
 modules/h2/src/docsrc/images/favicon.ico           |   Bin 0 -> 4286 bytes
 modules/h2/src/docsrc/images/h2-16.png             |   Bin 0 -> 675 bytes
 modules/h2/src/docsrc/images/h2-24.png             |   Bin 0 -> 995 bytes
 modules/h2/src/docsrc/images/h2-32.png             |   Bin 0 -> 1362 bytes
 modules/h2/src/docsrc/images/h2-64.png             |   Bin 0 -> 2718 bytes
 modules/h2/src/docsrc/images/h2-logo-2.png         |   Bin 0 -> 6617 bytes
 modules/h2/src/docsrc/images/h2-logo.png           |   Bin 0 -> 12780 bytes
 modules/h2/src/docsrc/images/h2-logo.svg           |    61 +
 modules/h2/src/docsrc/images/h2_v2_3_7.svg         |    61 +
 modules/h2/src/docsrc/images/paypal-donate.png     |   Bin 0 -> 6172 bytes
 modules/h2/src/docsrc/images/screenshot.png        |   Bin 0 -> 113875 bytes
 modules/h2/src/docsrc/index.html                   |    44 +
 modules/h2/src/docsrc/javadoc/animate.js           |    51 +
 modules/h2/src/docsrc/javadoc/classes.html         |    98 +
 modules/h2/src/docsrc/javadoc/index.html           |    24 +
 modules/h2/src/docsrc/javadoc/overview.html        |    38 +
 modules/h2/src/docsrc/javadoc/stylesheet.css       |   171 +
 modules/h2/src/docsrc/text/_docs_en.utf8.txt       | 12510 ++++++++++++++++++
 modules/h2/src/docsrc/text/_docs_ja.utf8.txt       | 12512 +++++++++++++++++++
 modules/h2/src/docsrc/textbase/_docs_en.properties |  4170 ++++++
 modules/h2/src/docsrc/textbase/_messages_en.prop   |   184 +
 modules/h2/src/docsrc/textbase/_text_en.prop       |   163 +
 .../main/java/META-INF/services/java.sql.Driver    |     1 +
 modules/h2/src/main/java/org/h2/Driver.java        |   207 +
 .../java/org/h2/JdbcDriverBackwardsCompat.java     |    16 +
 modules/h2/src/main/java/org/h2/api/Aggregate.java |    55 +
 .../main/java/org/h2/api/AggregateFunction.java    |    58 +
 .../main/java/org/h2/api/CredentialsValidator.java |    32 +
 .../java/org/h2/api/CustomDataTypesHandler.java    |   122 +
 .../java/org/h2/api/DatabaseEventListener.java     |   107 +
 modules/h2/src/main/java/org/h2/api/ErrorCode.java |  2140 ++++
 modules/h2/src/main/java/org/h2/api/Interval.java  |   635 +
 .../main/java/org/h2/api/IntervalQualifier.java    |   337 +
 .../main/java/org/h2/api/JavaObjectSerializer.java |    32 +
 .../h2/src/main/java/org/h2/api/TableEngine.java   |    27 +
 .../java/org/h2/api/TimestampWithTimeZone.java     |   152 +
 modules/h2/src/main/java/org/h2/api/Trigger.java   |    93 +
 .../main/java/org/h2/api/UserToRolesMapper.java    |    33 +
 modules/h2/src/main/java/org/h2/api/package.html   |    14 +
 modules/h2/src/main/java/org/h2/bnf/Bnf.java       |   369 +
 .../h2/src/main/java/org/h2/bnf/BnfVisitor.java    |    54 +
 modules/h2/src/main/java/org/h2/bnf/Rule.java      |    38 +
 .../h2/src/main/java/org/h2/bnf/RuleElement.java   |    80 +
 modules/h2/src/main/java/org/h2/bnf/RuleFixed.java |   211 +
 modules/h2/src/main/java/org/h2/bnf/RuleHead.java  |    38 +
 modules/h2/src/main/java/org/h2/bnf/RuleList.java  |    74 +
 .../h2/src/main/java/org/h2/bnf/RuleOptional.java  |    40 +
 .../h2/src/main/java/org/h2/bnf/RuleRepeat.java    |    47 +
 modules/h2/src/main/java/org/h2/bnf/Sentence.java  |   222 +
 .../src/main/java/org/h2/bnf/context/DbColumn.java |   114 +
 .../main/java/org/h2/bnf/context/DbContents.java   |   275 +
 .../java/org/h2/bnf/context/DbContextRule.java     |   349 +
 .../main/java/org/h2/bnf/context/DbProcedure.java  |    97 +
 .../src/main/java/org/h2/bnf/context/DbSchema.java |   162 +
 .../java/org/h2/bnf/context/DbTableOrView.java     |   113 +
 .../src/main/java/org/h2/bnf/context/package.html  |    14 +
 modules/h2/src/main/java/org/h2/bnf/package.html   |    14 +
 .../h2/src/main/java/org/h2/command/Command.java   |   403 +
 .../main/java/org/h2/command/CommandContainer.java |   188 +
 .../main/java/org/h2/command/CommandInterface.java |   552 +
 .../src/main/java/org/h2/command/CommandList.java  |    86 +
 .../main/java/org/h2/command/CommandRemote.java    |   331 +
 .../h2/src/main/java/org/h2/command/Parser.java    |  8134 ++++++++++++
 .../h2/src/main/java/org/h2/command/Prepared.java  |   476 +
 .../java/org/h2/command/ddl/AlterIndexRename.java  |    75 +
 .../java/org/h2/command/ddl/AlterSchemaRename.java |    66 +
 .../java/org/h2/command/ddl/AlterSequence.java     |    97 +
 .../h2/command/ddl/AlterTableAddConstraint.java    |   461 +
 .../org/h2/command/ddl/AlterTableAlterColumn.java  |   648 +
 .../h2/command/ddl/AlterTableDropConstraint.java   |    56 +
 .../java/org/h2/command/ddl/AlterTableRename.java  |    84 +
 .../org/h2/command/ddl/AlterTableRenameColumn.java |    97 +
 .../h2/command/ddl/AlterTableRenameConstraint.java |    59 +
 .../main/java/org/h2/command/ddl/AlterUser.java    |   105 +
 .../main/java/org/h2/command/ddl/AlterView.java    |    54 +
 .../src/main/java/org/h2/command/ddl/Analyze.java  |   151 +
 .../org/h2/command/ddl/CommandWithColumns.java     |   161 +
 .../java/org/h2/command/ddl/CreateAggregate.java   |    76 +
 .../java/org/h2/command/ddl/CreateConstant.java    |    69 +
 .../main/java/org/h2/command/ddl/CreateDomain.java |    84 +
 .../org/h2/command/ddl/CreateFunctionAlias.java    |   106 +
 .../main/java/org/h2/command/ddl/CreateIndex.java  |   141 +
 .../java/org/h2/command/ddl/CreateLinkedTable.java |   124 +
 .../main/java/org/h2/command/ddl/CreateRole.java   |    61 +
 .../main/java/org/h2/command/ddl/CreateSchema.java |    76 +
 .../java/org/h2/command/ddl/CreateSequence.java    |    72 +
 .../java/org/h2/command/ddl/CreateSynonym.java     |   114 +
 .../java/org/h2/command/ddl/CreateSynonymData.java |    44 +
 .../main/java/org/h2/command/ddl/CreateTable.java  |   252 +
 .../java/org/h2/command/ddl/CreateTableData.java   |    83 +
 .../java/org/h2/command/ddl/CreateTrigger.java     |   137 +
 .../main/java/org/h2/command/ddl/CreateUser.java   |   135 +
 .../main/java/org/h2/command/ddl/CreateView.java   |   154 +
 .../org/h2/command/ddl/DeallocateProcedure.java    |    38 +
 .../java/org/h2/command/ddl/DefineCommand.java     |    52 +
 .../java/org/h2/command/ddl/DropAggregate.java     |    57 +
 .../main/java/org/h2/command/ddl/DropConstant.java |    58 +
 .../main/java/org/h2/command/ddl/DropDatabase.java |   161 +
 .../main/java/org/h2/command/ddl/DropDomain.java   |    84 +
 .../java/org/h2/command/ddl/DropFunctionAlias.java |    58 +
 .../main/java/org/h2/command/ddl/DropIndex.java    |    84 +
 .../src/main/java/org/h2/command/ddl/DropRole.java |    61 +
 .../main/java/org/h2/command/ddl/DropSchema.java   |    84 +
 .../main/java/org/h2/command/ddl/DropSequence.java |    61 +
 .../main/java/org/h2/command/ddl/DropSynonym.java  |    57 +
 .../main/java/org/h2/command/ddl/DropTable.java    |   146 +
 .../main/java/org/h2/command/ddl/DropTrigger.java  |    61 +
 .../src/main/java/org/h2/command/ddl/DropUser.java |    74 +
 .../src/main/java/org/h2/command/ddl/DropView.java |   101 +
 .../main/java/org/h2/command/ddl/GrantRevoke.java  |   227 +
 .../java/org/h2/command/ddl/PrepareProcedure.java  |    62 +
 .../java/org/h2/command/ddl/SchemaCommand.java     |    38 +
 .../java/org/h2/command/ddl/SequenceOptions.java   |   172 +
 .../main/java/org/h2/command/ddl/SetComment.java   |   157 +
 .../java/org/h2/command/ddl/TruncateTable.java     |    68 +
 .../src/main/java/org/h2/command/ddl/package.html  |    14 +
 .../java/org/h2/command/dml/AllColumnsForPlan.java |    58 +
 .../java/org/h2/command/dml/AlterTableSet.java     |    80 +
 .../java/org/h2/command/dml/BackupCommand.java     |   182 +
 .../h2/src/main/java/org/h2/command/dml/Call.java  |   115 +
 .../java/org/h2/command/dml/CommandWithValues.java |    45 +
 .../src/main/java/org/h2/command/dml/Delete.java   |   211 +
 .../java/org/h2/command/dml/ExecuteProcedure.java  |    93 +
 .../src/main/java/org/h2/command/dml/Explain.java  |   160 +
 .../src/main/java/org/h2/command/dml/Insert.java   |   482 +
 .../h2/src/main/java/org/h2/command/dml/Merge.java |   322 +
 .../main/java/org/h2/command/dml/MergeUsing.java   |   519 +
 .../main/java/org/h2/command/dml/NoOperation.java  |    52 +
 .../main/java/org/h2/command/dml/Optimizer.java    |   265 +
 .../h2/src/main/java/org/h2/command/dml/Query.java |   746 ++
 .../src/main/java/org/h2/command/dml/Replace.java  |   295 +
 .../java/org/h2/command/dml/RunScriptCommand.java  |   103 +
 .../main/java/org/h2/command/dml/ScriptBase.java   |   268 +
 .../java/org/h2/command/dml/ScriptCommand.java     |   728 ++
 .../src/main/java/org/h2/command/dml/Select.java   |  1987 +++
 .../main/java/org/h2/command/dml/SelectGroups.java |   442 +
 .../h2/command/dml/SelectListColumnResolver.java   |   100 +
 .../java/org/h2/command/dml/SelectOrderBy.java     |    49 +
 .../main/java/org/h2/command/dml/SelectUnion.java  |   535 +
 .../h2/src/main/java/org/h2/command/dml/Set.java   |   671 +
 .../src/main/java/org/h2/command/dml/SetTypes.java |   353 +
 .../org/h2/command/dml/TransactionCommand.java     |   149 +
 .../src/main/java/org/h2/command/dml/Update.java   |   308 +
 .../src/main/java/org/h2/command/dml/package.html  |    14 +
 .../h2/src/main/java/org/h2/command/package.html   |    14 +
 .../main/java/org/h2/compress/CompressDeflate.java |    95 +
 .../src/main/java/org/h2/compress/CompressLZF.java |   471 +
 .../src/main/java/org/h2/compress/CompressNo.java  |    37 +
 .../src/main/java/org/h2/compress/Compressor.java  |    67 +
 .../main/java/org/h2/compress/LZFInputStream.java  |   133 +
 .../main/java/org/h2/compress/LZFOutputStream.java |   102 +
 .../h2/src/main/java/org/h2/compress/package.html  |    14 +
 .../main/java/org/h2/constraint/Constraint.java    |   196 +
 .../org/h2/constraint/ConstraintActionType.java    |    44 +
 .../java/org/h2/constraint/ConstraintCheck.java    |   171 +
 .../org/h2/constraint/ConstraintReferential.java   |   640 +
 .../java/org/h2/constraint/ConstraintUnique.java   |   158 +
 .../src/main/java/org/h2/constraint/package.html   |    14 +
 .../h2/src/main/java/org/h2/engine/Comment.java    |   119 +
 .../main/java/org/h2/engine/ConnectionInfo.java    |   674 +
 .../h2/src/main/java/org/h2/engine/Constants.java  |   593 +
 .../h2/src/main/java/org/h2/engine/Database.java   |  3200 +++++
 .../h2/src/main/java/org/h2/engine/DbObject.java   |   223 +
 .../src/main/java/org/h2/engine/DbObjectBase.java  |   183 +
 .../h2/src/main/java/org/h2/engine/DbSettings.java |   389 +
 .../java/org/h2/engine/DelayedDatabaseCloser.java  |    76 +
 modules/h2/src/main/java/org/h2/engine/Domain.java |    66 +
 modules/h2/src/main/java/org/h2/engine/Engine.java |   371 +
 .../src/main/java/org/h2/engine/FunctionAlias.java |   523 +
 .../src/main/java/org/h2/engine/GeneratedKeys.java |   242 +
 .../main/java/org/h2/engine/GeneratedKeysMode.java |    67 +
 .../h2/src/main/java/org/h2/engine/MetaRecord.java |   153 +
 modules/h2/src/main/java/org/h2/engine/Mode.java   |   403 +
 .../java/org/h2/engine/OnExitDatabaseCloser.java   |   117 +
 .../h2/src/main/java/org/h2/engine/Procedure.java  |    32 +
 .../java/org/h2/engine/QueryStatisticsData.java    |   200 +
 modules/h2/src/main/java/org/h2/engine/Right.java  |   193 +
 .../h2/src/main/java/org/h2/engine/RightOwner.java |   208 +
 modules/h2/src/main/java/org/h2/engine/Role.java   |    90 +
 .../h2/src/main/java/org/h2/engine/Session.java    |  1906 +++
 .../main/java/org/h2/engine/SessionFactory.java    |    25 +
 .../main/java/org/h2/engine/SessionInterface.java  |   165 +
 .../src/main/java/org/h2/engine/SessionRemote.java |   858 ++
 .../main/java/org/h2/engine/SessionWithState.java  |    61 +
 .../h2/src/main/java/org/h2/engine/Setting.java    |    88 +
 .../src/main/java/org/h2/engine/SettingsBase.java  |   107 +
 .../src/main/java/org/h2/engine/SysProperties.java |   623 +
 .../h2/src/main/java/org/h2/engine/UndoLog.java    |   196 +
 .../src/main/java/org/h2/engine/UndoLogRecord.java |   257 +
 modules/h2/src/main/java/org/h2/engine/User.java   |   275 +
 .../src/main/java/org/h2/engine/UserAggregate.java |   132 +
 .../src/main/java/org/h2/engine/UserBuilder.java   |    36 +
 .../h2/src/main/java/org/h2/engine/package.html    |    14 +
 .../h2/src/main/java/org/h2/expression/Alias.java  |   113 +
 .../java/org/h2/expression/BinaryOperation.java    |   459 +
 .../main/java/org/h2/expression/Expression.java    |   432 +
 .../java/org/h2/expression/ExpressionColumn.java   |   370 +
 .../java/org/h2/expression/ExpressionList.java     |   139 +
 .../java/org/h2/expression/ExpressionVisitor.java  |   386 +
 .../java/org/h2/expression/IntervalOperation.java  |   318 +
 .../src/main/java/org/h2/expression/Parameter.java |   193 +
 .../java/org/h2/expression/ParameterInterface.java |    74 +
 .../java/org/h2/expression/ParameterRemote.java    |   103 +
 .../h2/src/main/java/org/h2/expression/Rownum.java |    98 +
 .../main/java/org/h2/expression/SequenceValue.java |   101 +
 .../src/main/java/org/h2/expression/Subquery.java  |   122 +
 .../java/org/h2/expression/UnaryOperation.java     |    99 +
 .../java/org/h2/expression/ValueExpression.java    |   172 +
 .../src/main/java/org/h2/expression/Variable.java  |    99 +
 .../src/main/java/org/h2/expression/Wildcard.java  |   136 +
 .../h2/expression/aggregate/AbstractAggregate.java |   316 +
 .../org/h2/expression/aggregate/Aggregate.java     |   952 ++
 .../org/h2/expression/aggregate/AggregateData.java |    92 +
 .../aggregate/AggregateDataCollecting.java         |   114 +
 .../expression/aggregate/AggregateDataCount.java   |    38 +
 .../expression/aggregate/AggregateDataDefault.java |   185 +
 .../aggregate/AggregateDataDistinctWithCounts.java |    72 +
 .../aggregate/AggregateDataEnvelope.java           |    72 +
 .../aggregate/AggregateDataSelectivity.java        |    69 +
 .../org/h2/expression/aggregate/AggregateType.java |   148 +
 .../org/h2/expression/aggregate/JavaAggregate.java |   226 +
 .../h2/expression/aggregate/LongDataCounter.java   |    18 +
 .../org/h2/expression/aggregate/Percentile.java    |   363 +
 .../java/org/h2/expression/aggregate/package.html  |    14 +
 .../expression/analysis/DataAnalysisOperation.java |   529 +
 .../org/h2/expression/analysis/PartitionData.java  |    91 +
 .../java/org/h2/expression/analysis/Window.java    |   280 +
 .../org/h2/expression/analysis/WindowFrame.java    |   878 ++
 .../h2/expression/analysis/WindowFrameBound.java   |   164 +
 .../expression/analysis/WindowFrameBoundType.java  |    54 +
 .../expression/analysis/WindowFrameExclusion.java  |    62 +
 .../h2/expression/analysis/WindowFrameUnits.java   |    40 +
 .../org/h2/expression/analysis/WindowFunction.java |   534 +
 .../h2/expression/analysis/WindowFunctionType.java |   123 +
 .../java/org/h2/expression/analysis/package.html   |    14 +
 .../org/h2/expression/condition/CompareLike.java   |   546 +
 .../org/h2/expression/condition/Comparison.java    |   678 +
 .../org/h2/expression/condition/Condition.java     |    21 +
 .../h2/expression/condition/ConditionAndOr.java    |   348 +
 .../h2/expression/condition/ConditionExists.java   |    79 +
 .../org/h2/expression/condition/ConditionIn.java   |   268 +
 .../condition/ConditionInConstantSet.java          |   189 +
 .../expression/condition/ConditionInParameter.java |   184 +
 .../h2/expression/condition/ConditionInSelect.java |   219 +
 .../org/h2/expression/condition/ConditionNot.java  |   118 +
 .../java/org/h2/expression/condition/package.html  |    14 +
 .../h2/expression/function/DateTimeFunctions.java  |   817 ++
 .../java/org/h2/expression/function/Function.java  |  2786 +++++
 .../org/h2/expression/function/FunctionCall.java   |    79 +
 .../org/h2/expression/function/FunctionInfo.java   |   108 +
 .../org/h2/expression/function/JavaFunction.java   |   185 +
 .../org/h2/expression/function/TableFunction.java  |   163 +
 .../java/org/h2/expression/function/ToChar.java    |  1045 ++
 .../org/h2/expression/function/ToDateParser.java   |   379 +
 .../h2/expression/function/ToDateTokenizer.java    |   713 ++
 .../java/org/h2/expression/function/package.html   |    14 +
 .../src/main/java/org/h2/expression/package.html   |    14 +
 .../h2/src/main/java/org/h2/fulltext/FullText.java |  1189 ++
 .../main/java/org/h2/fulltext/FullTextLucene.java  |   769 ++
 .../java/org/h2/fulltext/FullTextSettings.java     |   282 +
 .../src/main/java/org/h2/fulltext/IndexInfo.java   |    42 +
 .../h2/src/main/java/org/h2/fulltext/package.html  |    14 +
 .../java/org/h2/index/AbstractFunctionCursor.java  |   102 +
 .../h2/src/main/java/org/h2/index/BaseIndex.java   |   503 +
 modules/h2/src/main/java/org/h2/index/Cursor.java  |    53 +
 .../src/main/java/org/h2/index/FunctionCursor.java |    35 +
 .../java/org/h2/index/FunctionCursorResultSet.java |    41 +
 .../src/main/java/org/h2/index/FunctionIndex.java  |   131 +
 .../h2/src/main/java/org/h2/index/HashIndex.java   |   178 +
 modules/h2/src/main/java/org/h2/index/Index.java   |   289 +
 .../src/main/java/org/h2/index/IndexCondition.java |   432 +
 .../h2/src/main/java/org/h2/index/IndexCursor.java |   330 +
 .../main/java/org/h2/index/IndexLookupBatch.java   |    70 +
 .../h2/src/main/java/org/h2/index/IndexType.java   |   207 +
 .../src/main/java/org/h2/index/LinkedCursor.java   |    78 +
 .../h2/src/main/java/org/h2/index/LinkedIndex.java |   282 +
 .../h2/src/main/java/org/h2/index/MetaCursor.java  |    48 +
 .../h2/src/main/java/org/h2/index/MetaIndex.java   |   138 +
 .../java/org/h2/index/NonUniqueHashCursor.java     |    57 +
 .../main/java/org/h2/index/NonUniqueHashIndex.java |   180 +
 .../h2/src/main/java/org/h2/index/PageBtree.java   |   292 +
 .../main/java/org/h2/index/PageBtreeCursor.java    |    93 +
 .../src/main/java/org/h2/index/PageBtreeIndex.java |   494 +
 .../src/main/java/org/h2/index/PageBtreeLeaf.java  |   402 +
 .../src/main/java/org/h2/index/PageBtreeNode.java  |   609 +
 .../h2/src/main/java/org/h2/index/PageData.java    |   248 +
 .../src/main/java/org/h2/index/PageDataCursor.java |    76 +
 .../src/main/java/org/h2/index/PageDataIndex.java  |   510 +
 .../src/main/java/org/h2/index/PageDataLeaf.java   |   625 +
 .../src/main/java/org/h2/index/PageDataNode.java   |   454 +
 .../main/java/org/h2/index/PageDataOverflow.java   |   273 +
 .../main/java/org/h2/index/PageDelegateIndex.java  |   163 +
 .../h2/src/main/java/org/h2/index/PageIndex.java   |    60 +
 .../h2/src/main/java/org/h2/index/RangeCursor.java |    65 +
 .../h2/src/main/java/org/h2/index/RangeIndex.java  |   140 +
 .../h2/src/main/java/org/h2/index/ScanCursor.java  |    45 +
 .../h2/src/main/java/org/h2/index/ScanIndex.java   |   199 +
 .../main/java/org/h2/index/SingleRowCursor.java    |    53 +
 .../src/main/java/org/h2/index/SpatialIndex.java   |    32 +
 .../main/java/org/h2/index/SpatialTreeIndex.java   |   308 +
 .../h2/src/main/java/org/h2/index/TreeCursor.java  |   124 +
 .../h2/src/main/java/org/h2/index/TreeIndex.java   |   411 +
 .../h2/src/main/java/org/h2/index/TreeNode.java    |    54 +
 .../h2/src/main/java/org/h2/index/ViewCursor.java  |    87 +
 .../h2/src/main/java/org/h2/index/ViewIndex.java   |   450 +
 modules/h2/src/main/java/org/h2/index/package.html |    14 +
 .../h2/src/main/java/org/h2/jdbc/JdbcArray.java    |   317 +
 .../java/org/h2/jdbc/JdbcBatchUpdateException.java |    66 +
 modules/h2/src/main/java/org/h2/jdbc/JdbcBlob.java |   312 +
 .../java/org/h2/jdbc/JdbcCallableStatement.java    |  1714 +++
 .../jdbc/JdbcCallableStatementBackwardsCompat.java |    16 +
 modules/h2/src/main/java/org/h2/jdbc/JdbcClob.java |   259 +
 .../src/main/java/org/h2/jdbc/JdbcConnection.java  |  2193 ++++
 .../org/h2/jdbc/JdbcConnectionBackwardsCompat.java |    16 +
 .../java/org/h2/jdbc/JdbcDatabaseMetaData.java     |  3320 +++++
 .../jdbc/JdbcDatabaseMetaDataBackwardsCompat.java  |    16 +
 .../src/main/java/org/h2/jdbc/JdbcException.java   |    49 +
 modules/h2/src/main/java/org/h2/jdbc/JdbcLob.java  |   224 +
 .../java/org/h2/jdbc/JdbcParameterMetaData.java    |   259 +
 .../java/org/h2/jdbc/JdbcPreparedStatement.java    |  1847 +++
 .../jdbc/JdbcPreparedStatementBackwardsCompat.java |    37 +
 .../src/main/java/org/h2/jdbc/JdbcResultSet.java   |  4003 ++++++
 .../org/h2/jdbc/JdbcResultSetBackwardsCompat.java  |    16 +
 .../java/org/h2/jdbc/JdbcResultSetMetaData.java    |   489 +
 .../java/org/h2/jdbc/JdbcSQLDataException.java     |    87 +
 .../main/java/org/h2/jdbc/JdbcSQLException.java    |    87 +
 .../jdbc/JdbcSQLFeatureNotSupportedException.java  |    87 +
 ...bcSQLIntegrityConstraintViolationException.java |    88 +
 .../JdbcSQLInvalidAuthorizationSpecException.java  |    88 +
 .../JdbcSQLNonTransientConnectionException.java    |    88 +
 .../org/h2/jdbc/JdbcSQLNonTransientException.java  |    87 +
 .../org/h2/jdbc/JdbcSQLSyntaxErrorException.java   |    87 +
 .../java/org/h2/jdbc/JdbcSQLTimeoutException.java  |    87 +
 .../jdbc/JdbcSQLTransactionRollbackException.java  |    87 +
 .../org/h2/jdbc/JdbcSQLTransientException.java     |    87 +
 .../h2/src/main/java/org/h2/jdbc/JdbcSQLXML.java   |   217 +
 .../src/main/java/org/h2/jdbc/JdbcSavepoint.java   |   123 +
 .../src/main/java/org/h2/jdbc/JdbcStatement.java   |  1437 +++
 .../org/h2/jdbc/JdbcStatementBackwardsCompat.java  |   140 +
 modules/h2/src/main/java/org/h2/jdbc/package.html  |    14 +
 .../main/java/org/h2/jdbcx/JdbcConnectionPool.java |   349 +
 .../jdbcx/JdbcConnectionPoolBackwardsCompat.java   |    16 +
 .../src/main/java/org/h2/jdbcx/JdbcDataSource.java |   450 +
 .../h2/jdbcx/JdbcDataSourceBackwardsCompat.java    |    16 +
 .../java/org/h2/jdbcx/JdbcDataSourceFactory.java   |    94 +
 .../main/java/org/h2/jdbcx/JdbcXAConnection.java   |   477 +
 modules/h2/src/main/java/org/h2/jdbcx/JdbcXid.java |    91 +
 modules/h2/src/main/java/org/h2/jdbcx/package.html |    14 +
 .../h2/src/main/java/org/h2/jmx/DatabaseInfo.java  |   278 +
 .../main/java/org/h2/jmx/DatabaseInfoMBean.java    |   169 +
 .../src/main/java/org/h2/jmx/DocumentedMBean.java  |    76 +
 modules/h2/src/main/java/org/h2/jmx/package.html   |    14 +
 .../src/main/java/org/h2/message/DbException.java  |   724 ++
 modules/h2/src/main/java/org/h2/message/Trace.java |   363 +
 .../src/main/java/org/h2/message/TraceObject.java  |   404 +
 .../src/main/java/org/h2/message/TraceSystem.java  |   348 +
 .../src/main/java/org/h2/message/TraceWriter.java  |    52 +
 .../java/org/h2/message/TraceWriterAdapter.java    |    76 +
 .../h2/src/main/java/org/h2/message/package.html   |    14 +
 .../src/main/java/org/h2/mode/FunctionsBase.java   |    37 +
 .../java/org/h2/mode/FunctionsMSSQLServer.java     |    45 +
 .../src/main/java/org/h2/mode/FunctionsMySQL.java  |   246 +
 modules/h2/src/main/java/org/h2/mode/package.html  |    14 +
 modules/h2/src/main/java/org/h2/mvstore/Chunk.java |   277 +
 .../h2/src/main/java/org/h2/mvstore/Cursor.java    |   176 +
 .../h2/src/main/java/org/h2/mvstore/CursorPos.java |    35 +
 .../h2/src/main/java/org/h2/mvstore/DataUtils.java |  1058 ++
 .../h2/src/main/java/org/h2/mvstore/FileStore.java |   399 +
 .../main/java/org/h2/mvstore/FreeSpaceBitSet.java  |   239 +
 modules/h2/src/main/java/org/h2/mvstore/MVMap.java |  1920 +++
 .../h2/src/main/java/org/h2/mvstore/MVStore.java   |  3363 +++++
 .../src/main/java/org/h2/mvstore/MVStoreTool.java  |   725 ++
 .../src/main/java/org/h2/mvstore/OffHeapStore.java |   148 +
 modules/h2/src/main/java/org/h2/mvstore/Page.java  |  1604 +++
 .../main/java/org/h2/mvstore/RootReference.java    |   118 +
 .../src/main/java/org/h2/mvstore/StreamStore.java  |   583 +
 .../src/main/java/org/h2/mvstore/WriteBuffer.java  |   331 +
 .../org/h2/mvstore/cache/CacheLongKeyLIRS.java     |  1217 ++
 .../java/org/h2/mvstore/cache/FilePathCache.java   |   181 +
 .../main/java/org/h2/mvstore/cache/package.html    |    14 +
 .../java/org/h2/mvstore/db/MVDelegateIndex.java    |   157 +
 .../src/main/java/org/h2/mvstore/db/MVIndex.java   |    35 +
 .../java/org/h2/mvstore/db/MVPlainTempResult.java  |   119 +
 .../java/org/h2/mvstore/db/MVPrimaryIndex.java     |   485 +
 .../java/org/h2/mvstore/db/MVSecondaryIndex.java   |   479 +
 .../java/org/h2/mvstore/db/MVSortedTempResult.java |   353 +
 .../java/org/h2/mvstore/db/MVSpatialIndex.java     |   525 +
 .../src/main/java/org/h2/mvstore/db/MVTable.java   |   727 ++
 .../main/java/org/h2/mvstore/db/MVTableEngine.java |   475 +
 .../main/java/org/h2/mvstore/db/MVTempResult.java  |   239 +
 .../main/java/org/h2/mvstore/db/ValueDataType.java |   743 ++
 .../src/main/java/org/h2/mvstore/db/package.html   |    14 +
 .../h2/src/main/java/org/h2/mvstore/package.html   |    14 +
 .../main/java/org/h2/mvstore/rtree/MVRTreeMap.java |   619 +
 .../java/org/h2/mvstore/rtree/SpatialDataType.java |   386 +
 .../main/java/org/h2/mvstore/rtree/SpatialKey.java |   124 +
 .../main/java/org/h2/mvstore/rtree/package.html    |    14 +
 .../org/h2/mvstore/tx/CommitDecisionMaker.java     |    65 +
 .../org/h2/mvstore/tx/RollbackDecisionMaker.java   |    67 +
 .../main/java/org/h2/mvstore/tx/Transaction.java   |   641 +
 .../java/org/h2/mvstore/tx/TransactionMap.java     |   763 ++
 .../java/org/h2/mvstore/tx/TransactionStore.java   |   840 ++
 .../java/org/h2/mvstore/tx/TxDecisionMaker.java    |   302 +
 .../java/org/h2/mvstore/tx/VersionedBitSet.java    |    33 +
 .../org/h2/mvstore/tx/VersionedValueCommitted.java |    49 +
 .../java/org/h2/mvstore/tx/VersionedValueType.java |   132 +
 .../h2/mvstore/tx/VersionedValueUncommitted.java   |    59 +
 .../src/main/java/org/h2/mvstore/tx/package.html   |    14 +
 .../main/java/org/h2/mvstore/type/DataType.java    |    72 +
 .../java/org/h2/mvstore/type/ObjectDataType.java   |  1552 +++
 .../java/org/h2/mvstore/type/StringDataType.java   |    57 +
 .../src/main/java/org/h2/mvstore/type/package.html |    14 +
 modules/h2/src/main/java/org/h2/package.html       |    14 +
 .../h2/src/main/java/org/h2/res/_messages_cs.prop  |   184 +
 .../h2/src/main/java/org/h2/res/_messages_de.prop  |   184 +
 .../h2/src/main/java/org/h2/res/_messages_en.prop  |   184 +
 .../h2/src/main/java/org/h2/res/_messages_es.prop  |   184 +
 .../h2/src/main/java/org/h2/res/_messages_fr.prop  |   184 +
 .../h2/src/main/java/org/h2/res/_messages_ja.prop  |   184 +
 .../h2/src/main/java/org/h2/res/_messages_pl.prop  |   184 +
 .../src/main/java/org/h2/res/_messages_pt_br.prop  |   184 +
 .../h2/src/main/java/org/h2/res/_messages_ru.prop  |   184 +
 .../h2/src/main/java/org/h2/res/_messages_sk.prop  |   184 +
 .../src/main/java/org/h2/res/_messages_zh_cn.prop  |   184 +
 modules/h2/src/main/java/org/h2/res/h2-22-t.png    |   Bin 0 -> 3870 bytes
 modules/h2/src/main/java/org/h2/res/h2-22.png      |   Bin 0 -> 1239 bytes
 modules/h2/src/main/java/org/h2/res/h2-24.png      |   Bin 0 -> 574 bytes
 modules/h2/src/main/java/org/h2/res/h2-64-t.png    |   Bin 0 -> 11867 bytes
 modules/h2/src/main/java/org/h2/res/h2.png         |   Bin 0 -> 547 bytes
 modules/h2/src/main/java/org/h2/res/help.csv       |  2045 +++
 .../h2/src/main/java/org/h2/res/javadoc.properties |    41 +
 .../h2/src/main/java/org/h2/result/LazyResult.java |   204 +
 .../src/main/java/org/h2/result/LocalResult.java   |   103 +
 .../java/org/h2/result/LocalResultFactory.java     |    57 +
 .../main/java/org/h2/result/LocalResultImpl.java   |   588 +
 .../src/main/java/org/h2/result/MergedResult.java  |    88 +
 .../src/main/java/org/h2/result/ResultColumn.java  |    94 +
 .../main/java/org/h2/result/ResultExternal.java    |    74 +
 .../main/java/org/h2/result/ResultInterface.java   |   182 +
 .../src/main/java/org/h2/result/ResultRemote.java  |   270 +
 .../src/main/java/org/h2/result/ResultTarget.java  |    36 +
 .../org/h2/result/ResultWithGeneratedKeys.java     |    72 +
 .../org/h2/result/ResultWithPaddedStrings.java     |   193 +
 modules/h2/src/main/java/org/h2/result/Row.java    |    69 +
 .../h2/src/main/java/org/h2/result/RowFactory.java |    39 +
 .../h2/src/main/java/org/h2/result/RowImpl.java    |   154 +
 .../h2/src/main/java/org/h2/result/RowList.java    |   250 +
 .../h2/src/main/java/org/h2/result/SearchRow.java  |    76 +
 .../src/main/java/org/h2/result/SimpleResult.java  |   260 +
 .../h2/src/main/java/org/h2/result/SimpleRow.java  |    73 +
 .../main/java/org/h2/result/SimpleRowValue.java    |    67 +
 .../h2/src/main/java/org/h2/result/SortOrder.java  |   338 +
 .../src/main/java/org/h2/result/UpdatableRow.java  |   330 +
 .../h2/src/main/java/org/h2/result/package.html    |    14 +
 .../h2/src/main/java/org/h2/schema/Constant.java   |    71 +
 modules/h2/src/main/java/org/h2/schema/Schema.java |   751 ++
 .../src/main/java/org/h2/schema/SchemaObject.java  |    30 +
 .../main/java/org/h2/schema/SchemaObjectBase.java  |    53 +
 .../h2/src/main/java/org/h2/schema/Sequence.java   |   371 +
 .../src/main/java/org/h2/schema/TriggerObject.java |   480 +
 .../h2/src/main/java/org/h2/schema/package.html    |    14 +
 modules/h2/src/main/java/org/h2/security/AES.java  |   327 +
 .../src/main/java/org/h2/security/BlockCipher.java |    53 +
 .../main/java/org/h2/security/CipherFactory.java   |   411 +
 modules/h2/src/main/java/org/h2/security/Fog.java  |    75 +
 .../h2/src/main/java/org/h2/security/SHA256.java   |   156 +
 .../main/java/org/h2/security/SecureFileStore.java |   114 +
 modules/h2/src/main/java/org/h2/security/XTEA.java |   150 +
 .../org/h2/security/auth/AuthConfigException.java  |    30 +
 .../h2/security/auth/AuthenticationException.java  |    30 +
 .../org/h2/security/auth/AuthenticationInfo.java   |    89 +
 .../java/org/h2/security/auth/Authenticator.java   |    33 +
 .../org/h2/security/auth/AuthenticatorFactory.java |    20 +
 .../org/h2/security/auth/ConfigProperties.java     |   116 +
 .../java/org/h2/security/auth/Configurable.java    |    17 +
 .../org/h2/security/auth/DefaultAuthenticator.java |   360 +
 .../java/org/h2/security/auth/H2AuthConfig.java    |    98 +
 .../java/org/h2/security/auth/H2AuthConfigXml.java |   128 +
 .../org/h2/security/auth/HasConfigProperties.java  |    15 +
 .../java/org/h2/security/auth/PropertyConfig.java  |    40 +
 .../java/org/h2/security/auth/RealmConfig.java     |    64 +
 .../h2/security/auth/UserToRolesMapperConfig.java  |    46 +
 .../h2/security/auth/impl/AssignRealmNameRole.java |    48 +
 .../auth/impl/JaasCredentialsValidator.java        |    85 +
 .../auth/impl/LdapCredentialsValidator.java        |    73 +
 .../h2/security/auth/impl/StaticRolesMapper.java   |    51 +
 .../auth/impl/StaticUserCredentialsValidator.java  |    73 +
 .../java/org/h2/security/auth/impl/package.html    |    14 +
 .../main/java/org/h2/security/auth/package.html    |    14 +
 .../h2/src/main/java/org/h2/security/package.html  |    14 +
 .../h2/src/main/java/org/h2/server/Service.java    |    92 +
 .../main/java/org/h2/server/ShutdownHandler.java   |    17 +
 .../h2/src/main/java/org/h2/server/TcpServer.java  |   518 +
 .../main/java/org/h2/server/TcpServerThread.java   |   654 +
 .../h2/src/main/java/org/h2/server/package.html    |    14 +
 .../src/main/java/org/h2/server/pg/PgServer.java   |   595 +
 .../main/java/org/h2/server/pg/PgServerThread.java |  1118 ++
 .../h2/src/main/java/org/h2/server/pg/package.html |    14 +
 .../src/main/java/org/h2/server/pg/pg_catalog.sql  |   379 +
 .../java/org/h2/server/web/ConnectionInfo.java     |    66 +
 .../src/main/java/org/h2/server/web/DbStarter.java |    93 +
 .../main/java/org/h2/server/web/PageParser.java    |   349 +
 .../h2/src/main/java/org/h2/server/web/WebApp.java |  1945 +++
 .../src/main/java/org/h2/server/web/WebServer.java |   930 ++
 .../main/java/org/h2/server/web/WebServlet.java    |   161 +
 .../main/java/org/h2/server/web/WebSession.java    |   275 +
 .../src/main/java/org/h2/server/web/WebThread.java |   363 +
 .../src/main/java/org/h2/server/web/package.html   |    14 +
 .../main/java/org/h2/server/web/res/_text_cs.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_de.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_en.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_es.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_fr.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_hu.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_in.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_it.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_ja.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_ko.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_nl.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_pl.prop  |   163 +
 .../java/org/h2/server/web/res/_text_pt_br.prop    |   163 +
 .../java/org/h2/server/web/res/_text_pt_pt.prop    |   163 +
 .../main/java/org/h2/server/web/res/_text_ru.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_sk.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_tr.prop  |   163 +
 .../main/java/org/h2/server/web/res/_text_uk.prop  |   163 +
 .../java/org/h2/server/web/res/_text_zh_cn.prop    |   163 +
 .../java/org/h2/server/web/res/_text_zh_tw.prop    |   163 +
 .../src/main/java/org/h2/server/web/res/admin.jsp  |   125 +
 .../main/java/org/h2/server/web/res/adminLogin.jsp |    44 +
 .../org/h2/server/web/res/autoCompleteList.jsp     |     1 +
 .../main/java/org/h2/server/web/res/background.gif |   Bin 0 -> 169 bytes
 .../src/main/java/org/h2/server/web/res/error.jsp  |    16 +
 .../main/java/org/h2/server/web/res/favicon.ico    |   Bin 0 -> 4286 bytes
 .../src/main/java/org/h2/server/web/res/frame.jsp  |    28 +
 .../src/main/java/org/h2/server/web/res/header.jsp |   163 +
 .../src/main/java/org/h2/server/web/res/help.jsp   |    99 +
 .../java/org/h2/server/web/res/helpTranslate.jsp   |    43 +
 .../main/java/org/h2/server/web/res/ico_add.gif    |   Bin 0 -> 318 bytes
 .../src/main/java/org/h2/server/web/res/ico_ok.gif |   Bin 0 -> 846 bytes
 .../main/java/org/h2/server/web/res/ico_remove.gif |   Bin 0 -> 350 bytes
 .../java/org/h2/server/web/res/ico_remove_ok.gif   |   Bin 0 -> 107 bytes
 .../main/java/org/h2/server/web/res/ico_search.gif |   Bin 0 -> 545 bytes
 .../main/java/org/h2/server/web/res/ico_undo.gif   |   Bin 0 -> 851 bytes
 .../main/java/org/h2/server/web/res/ico_write.gif  |   Bin 0 -> 210 bytes
 .../java/org/h2/server/web/res/icon_commit.gif     |   Bin 0 -> 323 bytes
 .../java/org/h2/server/web/res/icon_disconnect.gif |   Bin 0 -> 114 bytes
 .../main/java/org/h2/server/web/res/icon_help.gif  |   Bin 0 -> 373 bytes
 .../java/org/h2/server/web/res/icon_history.gif    |   Bin 0 -> 216 bytes
 .../main/java/org/h2/server/web/res/icon_line.gif  |   Bin 0 -> 818 bytes
 .../java/org/h2/server/web/res/icon_refresh.gif    |   Bin 0 -> 327 bytes
 .../java/org/h2/server/web/res/icon_rollback.gif   |   Bin 0 -> 331 bytes
 .../main/java/org/h2/server/web/res/icon_run.gif   |   Bin 0 -> 379 bytes
 .../org/h2/server/web/res/icon_run_selected.gif    |   Bin 0 -> 312 bytes
 .../main/java/org/h2/server/web/res/icon_stop.gif  |   Bin 0 -> 215 bytes
 .../src/main/java/org/h2/server/web/res/index.jsp  |    24 +
 .../src/main/java/org/h2/server/web/res/login.jsp  |   132 +
 .../main/java/org/h2/server/web/res/notAllowed.jsp |    16 +
 .../src/main/java/org/h2/server/web/res/query.jsp  |   530 +
 .../src/main/java/org/h2/server/web/res/result.jsp |    22 +
 .../main/java/org/h2/server/web/res/stylesheet.css |   334 +
 .../src/main/java/org/h2/server/web/res/table.js   |   266 +
 .../src/main/java/org/h2/server/web/res/tables.jsp |    35 +
 .../src/main/java/org/h2/server/web/res/tools.jsp  |   241 +
 .../h2/src/main/java/org/h2/server/web/res/tree.js |   124 +
 .../java/org/h2/server/web/res/tree_column.gif     |   Bin 0 -> 317 bytes
 .../java/org/h2/server/web/res/tree_database.gif   |   Bin 0 -> 545 bytes
 .../main/java/org/h2/server/web/res/tree_empty.gif |   Bin 0 -> 62 bytes
 .../java/org/h2/server/web/res/tree_folder.gif     |   Bin 0 -> 372 bytes
 .../main/java/org/h2/server/web/res/tree_index.gif |   Bin 0 -> 152 bytes
 .../java/org/h2/server/web/res/tree_index_az.gif   |   Bin 0 -> 157 bytes
 .../main/java/org/h2/server/web/res/tree_info.gif  |   Bin 0 -> 267 bytes
 .../main/java/org/h2/server/web/res/tree_line.gif  |   Bin 0 -> 66 bytes
 .../main/java/org/h2/server/web/res/tree_minus.gif |   Bin 0 -> 861 bytes
 .../main/java/org/h2/server/web/res/tree_page.gif  |   Bin 0 -> 582 bytes
 .../main/java/org/h2/server/web/res/tree_plus.gif  |   Bin 0 -> 870 bytes
 .../java/org/h2/server/web/res/tree_sequence.gif   |   Bin 0 -> 91 bytes
 .../java/org/h2/server/web/res/tree_sequences.gif  |   Bin 0 -> 114 bytes
 .../main/java/org/h2/server/web/res/tree_table.gif |   Bin 0 -> 343 bytes
 .../main/java/org/h2/server/web/res/tree_type.gif  |   Bin 0 -> 197 bytes
 .../main/java/org/h2/server/web/res/tree_types.gif |   Bin 0 -> 364 bytes
 .../main/java/org/h2/server/web/res/tree_user.gif  |   Bin 0 -> 500 bytes
 .../main/java/org/h2/server/web/res/tree_users.gif |   Bin 0 -> 601 bytes
 .../main/java/org/h2/server/web/res/tree_view.gif  |   Bin 0 -> 157 bytes
 .../org/h2/store/CountingReaderInputStream.java    |   112 +
 modules/h2/src/main/java/org/h2/store/Data.java    |  1461 +++
 .../h2/src/main/java/org/h2/store/DataHandler.java |   124 +
 .../h2/src/main/java/org/h2/store/DataReader.java  |   201 +
 .../h2/src/main/java/org/h2/store/FileLister.java  |   122 +
 .../h2/src/main/java/org/h2/store/FileLock.java    |   515 +
 .../src/main/java/org/h2/store/FileLockMethod.java |    35 +
 .../h2/src/main/java/org/h2/store/FileStore.java   |   516 +
 .../java/org/h2/store/FileStoreInputStream.java    |   160 +
 .../java/org/h2/store/FileStoreOutputStream.java   |    85 +
 .../main/java/org/h2/store/InDoubtTransaction.java |    51 +
 .../main/java/org/h2/store/LobStorageBackend.java  |   780 ++
 .../main/java/org/h2/store/LobStorageFrontend.java |   108 +
 .../java/org/h2/store/LobStorageInterface.java     |    84 +
 .../src/main/java/org/h2/store/LobStorageMap.java  |   359 +
 .../org/h2/store/LobStorageRemoteInputStream.java  |    90 +
 modules/h2/src/main/java/org/h2/store/Page.java    |   264 +
 .../src/main/java/org/h2/store/PageFreeList.java   |   231 +
 .../main/java/org/h2/store/PageInputStream.java    |   172 +
 modules/h2/src/main/java/org/h2/store/PageLog.java |   895 ++
 .../main/java/org/h2/store/PageOutputStream.java   |   224 +
 .../h2/src/main/java/org/h2/store/PageStore.java   |  2037 +++
 .../org/h2/store/PageStoreInDoubtTransaction.java  |    72 +
 .../src/main/java/org/h2/store/PageStreamData.java |   179 +
 .../main/java/org/h2/store/PageStreamTrunk.java    |   303 +
 .../main/java/org/h2/store/RangeInputStream.java   |   102 +
 .../h2/src/main/java/org/h2/store/RangeReader.java |   103 +
 .../src/main/java/org/h2/store/RecoverTester.java  |   196 +
 .../src/main/java/org/h2/store/SessionState.java   |    54 +
 .../src/main/java/org/h2/store/WriterThread.java   |   134 +
 .../main/java/org/h2/store/fs/FakeFileChannel.java |   112 +
 .../h2/src/main/java/org/h2/store/fs/FileBase.java |   111 +
 .../org/h2/store/fs/FileChannelInputStream.java    |    71 +
 .../org/h2/store/fs/FileChannelOutputStream.java   |    59 +
 .../h2/src/main/java/org/h2/store/fs/FilePath.java |   325 +
 .../main/java/org/h2/store/fs/FilePathAsync.java   |   207 +
 .../main/java/org/h2/store/fs/FilePathDisk.java    |   502 +
 .../main/java/org/h2/store/fs/FilePathEncrypt.java |   529 +
 .../src/main/java/org/h2/store/fs/FilePathMem.java |   803 ++
 .../src/main/java/org/h2/store/fs/FilePathNio.java |   129 +
 .../java/org/h2/store/fs/FilePathNioMapped.java    |   243 +
 .../main/java/org/h2/store/fs/FilePathNioMem.java  |   814 ++
 .../src/main/java/org/h2/store/fs/FilePathRec.java |   216 +
 .../org/h2/store/fs/FilePathRetryOnInterrupt.java  |   257 +
 .../main/java/org/h2/store/fs/FilePathSplit.java   |   449 +
 .../main/java/org/h2/store/fs/FilePathWrapper.java |   165 +
 .../src/main/java/org/h2/store/fs/FilePathZip.java |   378 +
 .../src/main/java/org/h2/store/fs/FileUtils.java   |   379 +
 .../h2/src/main/java/org/h2/store/fs/Recorder.java |    59 +
 .../h2/src/main/java/org/h2/store/fs/package.html  |    14 +
 modules/h2/src/main/java/org/h2/store/package.html |    14 +
 modules/h2/src/main/java/org/h2/table/Column.java  |   885 ++
 .../src/main/java/org/h2/table/ColumnResolver.java |    93 +
 .../src/main/java/org/h2/table/FunctionTable.java  |   258 +
 .../h2/src/main/java/org/h2/table/IndexColumn.java |   123 +
 .../h2/src/main/java/org/h2/table/IndexHints.java  |    57 +
 .../h2/src/main/java/org/h2/table/JoinBatch.java   |  1128 ++
 .../h2/src/main/java/org/h2/table/LinkSchema.java  |    93 +
 .../h2/src/main/java/org/h2/table/MetaTable.java   |  2391 ++++
 .../src/main/java/org/h2/table/PageStoreTable.java |   534 +
 modules/h2/src/main/java/org/h2/table/Plan.java    |   154 +
 .../h2/src/main/java/org/h2/table/PlanItem.java    |    58 +
 .../h2/src/main/java/org/h2/table/RangeTable.java  |   260 +
 .../src/main/java/org/h2/table/RegularTable.java   |   265 +
 .../java/org/h2/table/SingleColumnResolver.java    |    80 +
 .../src/main/java/org/h2/table/SubQueryInfo.java   |    59 +
 modules/h2/src/main/java/org/h2/table/Table.java   |  1278 ++
 .../h2/src/main/java/org/h2/table/TableBase.java   |   156 +
 .../h2/src/main/java/org/h2/table/TableFilter.java |  1271 ++
 .../h2/src/main/java/org/h2/table/TableLink.java   |   717 ++
 .../java/org/h2/table/TableLinkConnection.java     |   145 +
 .../src/main/java/org/h2/table/TableSynonym.java   |   121 +
 .../h2/src/main/java/org/h2/table/TableType.java   |    51 +
 .../h2/src/main/java/org/h2/table/TableView.java   |   869 ++
 modules/h2/src/main/java/org/h2/table/package.html |    14 +
 modules/h2/src/main/java/org/h2/tools/Backup.java  |   179 +
 .../java/org/h2/tools/ChangeFileEncryption.java    |   312 +
 .../src/main/java/org/h2/tools/CompressTool.java   |   334 +
 modules/h2/src/main/java/org/h2/tools/Console.java |   313 +
 .../main/java/org/h2/tools/ConvertTraceFile.java   |   226 +
 .../src/main/java/org/h2/tools/CreateCluster.java  |   186 +
 modules/h2/src/main/java/org/h2/tools/Csv.java     |   871 ++
 .../src/main/java/org/h2/tools/DeleteDbFiles.java  |   110 +
 .../h2/src/main/java/org/h2/tools/GUIConsole.java  |   612 +
 .../src/main/java/org/h2/tools/MultiDimension.java |   336 +
 modules/h2/src/main/java/org/h2/tools/Recover.java |  1793 +++
 modules/h2/src/main/java/org/h2/tools/Restore.java |   200 +
 .../h2/src/main/java/org/h2/tools/RunScript.java   |   335 +
 modules/h2/src/main/java/org/h2/tools/Script.java  |   143 +
 modules/h2/src/main/java/org/h2/tools/Server.java  |   778 ++
 modules/h2/src/main/java/org/h2/tools/Shell.java   |   624 +
 .../main/java/org/h2/tools/SimpleResultSet.java    |  2466 ++++
 .../main/java/org/h2/tools/SimpleRowSource.java    |    34 +
 .../src/main/java/org/h2/tools/TriggerAdapter.java |   198 +
 modules/h2/src/main/java/org/h2/tools/package.html |    14 +
 .../h2/src/main/java/org/h2/upgrade/DbUpgrade.java |   187 +
 .../h2/src/main/java/org/h2/upgrade/package.html   |    14 +
 .../h2/src/main/java/org/h2/util/AbbaDetector.java |   129 +
 .../main/java/org/h2/util/AbbaLockingDetector.java |   262 +
 modules/h2/src/main/java/org/h2/util/Bits.java     |   325 +
 modules/h2/src/main/java/org/h2/util/Cache.java    |    92 +
 .../h2/src/main/java/org/h2/util/CacheHead.java    |    23 +
 modules/h2/src/main/java/org/h2/util/CacheLRU.java |   383 +
 .../h2/src/main/java/org/h2/util/CacheObject.java  |    84 +
 .../main/java/org/h2/util/CacheSecondLevel.java    |    89 +
 modules/h2/src/main/java/org/h2/util/CacheTQ.java  |   133 +
 .../h2/src/main/java/org/h2/util/CacheWriter.java  |    38 +
 .../h2/src/main/java/org/h2/util/CloseWatcher.java |   135 +
 .../h2/src/main/java/org/h2/util/ColumnNamer.java  |   148 +
 .../java/org/h2/util/ColumnNamerConfiguration.java |   244 +
 .../main/java/org/h2/util/CurrentTimestamp.java    |    30 +
 .../src/main/java/org/h2/util/DateTimeUtils.java   |  1585 +++
 .../main/java/org/h2/util/DbDriverActivator.java   |    52 +
 .../java/org/h2/util/DebuggingThreadLocal.java     |    45 +
 .../h2/src/main/java/org/h2/util/DoneFuture.java   |    56 +
 modules/h2/src/main/java/org/h2/util/HashBase.java |   128 +
 modules/h2/src/main/java/org/h2/util/IOUtils.java  |   416 +
 modules/h2/src/main/java/org/h2/util/IntArray.java |   170 +
 .../src/main/java/org/h2/util/IntIntHashMap.java   |   157 +
 .../src/main/java/org/h2/util/IntervalUtils.java   |   867 ++
 .../h2/src/main/java/org/h2/util/JdbcUtils.java    |   429 +
 .../h2/src/main/java/org/h2/util/LazyFuture.java   |   107 +
 .../main/java/org/h2/util/LocalDateTimeUtils.java  |   701 ++
 .../h2/src/main/java/org/h2/util/MathUtils.java    |   313 +
 .../src/main/java/org/h2/util/MemoryUnmapper.java  |    92 +
 modules/h2/src/main/java/org/h2/util/NetUtils.java |   295 +
 .../java/org/h2/util/OsgiDataSourceFactory.java    |   305 +
 .../h2/src/main/java/org/h2/util/ParserUtil.java   |   645 +
 .../h2/src/main/java/org/h2/util/Permutations.java |   173 +
 modules/h2/src/main/java/org/h2/util/Profiler.java |   518 +
 .../h2/src/main/java/org/h2/util/ScriptReader.java |   324 +
 .../main/java/org/h2/util/SimpleColumnInfo.java    |    80 +
 .../src/main/java/org/h2/util/SmallLRUCache.java   |    48 +
 modules/h2/src/main/java/org/h2/util/SmallMap.java |    94 +
 .../h2/src/main/java/org/h2/util/SoftHashMap.java  |   108 +
 .../main/java/org/h2/util/SortedProperties.java    |   170 +
 .../src/main/java/org/h2/util/SourceCompiler.java  |   597 +
 .../h2/src/main/java/org/h2/util/StringUtils.java  |  1209 ++
 modules/h2/src/main/java/org/h2/util/Task.java     |   126 +
 .../src/main/java/org/h2/util/TempFileDeleter.java |   139 +
 .../java/org/h2/util/ThreadDeadlockDetector.java   |   197 +
 modules/h2/src/main/java/org/h2/util/Tool.java     |   137 +
 modules/h2/src/main/java/org/h2/util/Utils.java    |   817 ++
 .../main/java/org/h2/util/geometry/EWKBUtils.java  |   528 +
 .../main/java/org/h2/util/geometry/EWKTUtils.java  |   924 ++
 .../java/org/h2/util/geometry/GeometryUtils.java   |   586 +
 .../main/java/org/h2/util/geometry/JTSUtils.java   |   483 +
 .../main/java/org/h2/util/geometry/package.html    |    14 +
 modules/h2/src/main/java/org/h2/util/package.html  |    14 +
 .../org/h2/value/CaseInsensitiveConcurrentMap.java |    41 +
 .../main/java/org/h2/value/CaseInsensitiveMap.java |    40 +
 .../main/java/org/h2/value/CharsetCollator.java    |    86 +
 .../h2/src/main/java/org/h2/value/CompareMode.java |   317 +
 .../main/java/org/h2/value/CompareModeDefault.java |    74 +
 .../main/java/org/h2/value/CompareModeIcu4J.java   |    89 +
 .../h2/src/main/java/org/h2/value/DataType.java    |  1642 +++
 .../h2/src/main/java/org/h2/value/ExtTypeInfo.java |    34 +
 .../main/java/org/h2/value/ExtTypeInfoEnum.java    |   211 +
 .../java/org/h2/value/ExtTypeInfoGeometry.java     |    70 +
 .../h2/src/main/java/org/h2/value/Transfer.java    |   863 ++
 .../h2/src/main/java/org/h2/value/TypeInfo.java    |   498 +
 modules/h2/src/main/java/org/h2/value/Value.java   |  1679 +++
 .../h2/src/main/java/org/h2/value/ValueArray.java  |   204 +
 .../src/main/java/org/h2/value/ValueBoolean.java   |   116 +
 .../h2/src/main/java/org/h2/value/ValueByte.java   |   156 +
 .../h2/src/main/java/org/h2/value/ValueBytes.java  |   165 +
 .../java/org/h2/value/ValueCollectionBase.java     |   133 +
 .../h2/src/main/java/org/h2/value/ValueDate.java   |   143 +
 .../src/main/java/org/h2/value/ValueDecimal.java   |   265 +
 .../h2/src/main/java/org/h2/value/ValueDouble.java |   185 +
 .../h2/src/main/java/org/h2/value/ValueEnum.java   |    29 +
 .../src/main/java/org/h2/value/ValueEnumBase.java  |   150 +
 .../h2/src/main/java/org/h2/value/ValueFloat.java  |   189 +
 .../src/main/java/org/h2/value/ValueGeometry.java  |   358 +
 .../h2/src/main/java/org/h2/value/ValueInt.java    |   179 +
 .../src/main/java/org/h2/value/ValueInterval.java  |   342 +
 .../main/java/org/h2/value/ValueJavaObject.java    |   213 +
 .../h2/src/main/java/org/h2/value/ValueLob.java    |   688 +
 .../h2/src/main/java/org/h2/value/ValueLobDb.java  |   751 ++
 .../h2/src/main/java/org/h2/value/ValueLong.java   |   212 +
 .../h2/src/main/java/org/h2/value/ValueNull.java   |   177 +
 .../src/main/java/org/h2/value/ValueResultSet.java |   179 +
 .../h2/src/main/java/org/h2/value/ValueRow.java    |   187 +
 .../h2/src/main/java/org/h2/value/ValueShort.java  |   156 +
 .../h2/src/main/java/org/h2/value/ValueString.java |   178 +
 .../main/java/org/h2/value/ValueStringFixed.java   |    66 +
 .../java/org/h2/value/ValueStringIgnoreCase.java   |    85 +
 .../h2/src/main/java/org/h2/value/ValueTime.java   |   219 +
 .../src/main/java/org/h2/value/ValueTimestamp.java |   282 +
 .../java/org/h2/value/ValueTimestampTimeZone.java  |   292 +
 .../h2/src/main/java/org/h2/value/ValueUuid.java   |   228 +
 .../src/main/java/org/h2/value/VersionedValue.java |    39 +
 modules/h2/src/main/java/org/h2/value/package.html |    14 +
 modules/h2/src/main/java9/org/h2/util/Bits.java    |   320 +
 .../main/java9/org/h2/util/CurrentTimestamp.java   |    38 +
 modules/h2/src/main/java9/org/h2/util/package.html |    14 +
 .../resources/precompiled/org/h2/util/Bits.class   |   Bin 0 -> 2361 bytes
 .../precompiled/org/h2/util/CurrentTimestamp.class |   Bin 0 -> 792 bytes
 .../services/javax.annotation.processing.Processor |     1 +
 .../apache/ignite/testsuites/H2AllTestsSuite.java  |    34 +
 .../H2InMemoryMultiThreadLazyTestSuite.java        |    39 +
 .../testsuites/H2InMemoryMultiThreadTestSuite.java |    38 +
 .../H2MVStoreWithNetworkingTestSuite.java          |    40 +
 .../ignite/testsuites/H2MultiThreadTestSuite.java  |    38 +
 .../ignite/testsuites/H2NormalModeTestSuite.java   |    38 +
 .../testsuites/H2PageStoreDefragTestSuite.java     |    38 +
 .../testsuites/H2PageStoreNoMVStoreTestSuite.java  |    39 +
 .../testsuites/H2PageStoreOffloadTestSuite.java    |    42 +
 .../org/apache/ignite/testsuites/H2TestSuite.java  |    31 +
 .../org/h2/samples/CachedPreparedStatements.java   |    59 +
 .../h2/src/test/java/org/h2/samples/Compact.java   |    63 +
 .../test/java/org/h2/samples/CreateScriptFile.java |   165 +
 .../h2/src/test/java/org/h2/samples/CsvSample.java |    67 +
 .../src/test/java/org/h2/samples/DirectInsert.java |    80 +
 .../test/java/org/h2/samples/FileFunctions.java    |    89 +
 .../h2/src/test/java/org/h2/samples/Function.java  |   156 +
 .../java/org/h2/samples/FunctionMultiReturn.java   |   162 +
 .../src/test/java/org/h2/samples/HelloWorld.java   |    48 +
 .../java/org/h2/samples/InitDatabaseFromJar.java   |    70 +
 .../h2/src/test/java/org/h2/samples/MixedMode.java |    64 +
 .../h2/src/test/java/org/h2/samples/Newsfeed.java  |    83 +
 .../java/org/h2/samples/ReadOnlyDatabaseInZip.java |    69 +
 .../test/java/org/h2/samples/RowAccessRights.java  |   123 +
 .../src/test/java/org/h2/samples/SQLInjection.java |   433 +
 .../test/java/org/h2/samples/SecurePassword.java   |    89 +
 .../src/test/java/org/h2/samples/ShowProgress.java |   172 +
 .../test/java/org/h2/samples/ShutdownServer.java   |    23 +
 .../h2/src/test/java/org/h2/samples/ToDate.java    |    68 +
 .../test/java/org/h2/samples/TriggerPassData.java  |    95 +
 .../test/java/org/h2/samples/TriggerSample.java    |   124 +
 .../test/java/org/h2/samples/UpdatableView.java    |    89 +
 .../test/java/org/h2/samples/fullTextSearch.sql    |    59 +
 .../h2/src/test/java/org/h2/samples/newsfeed.sql   |   134 +
 .../src/test/java/org/h2/samples/optimizations.sql |   295 +
 .../h2/src/test/java/org/h2/samples/package.html   |    14 +
 .../h2/src/test/java/org/h2/test/H2TestCase.java   |    86 +
 .../test/java/org/h2/test/H2TestSuiteBuilder.java  |   129 +
 modules/h2/src/test/java/org/h2/test/TestAll.java  |  1191 ++
 .../h2/src/test/java/org/h2/test/TestAllJunit.java |    23 +
 modules/h2/src/test/java/org/h2/test/TestBase.java |  1585 +++
 modules/h2/src/test/java/org/h2/test/TestDb.java   |   243 +
 .../org/h2/test/ap/TestAnnotationProcessor.java    |    83 +
 .../h2/src/test/java/org/h2/test/ap/package.html   |    14 +
 .../test/java/org/h2/test/auth/MyLoginModule.java  |    61 +
 .../java/org/h2/test/auth/TestAuthentication.java  |   296 +
 .../h2/src/test/java/org/h2/test/auth/package.html |    14 +
 .../h2/src/test/java/org/h2/test/bench/Bench.java  |    36 +
 .../h2/src/test/java/org/h2/test/bench/BenchA.java |   201 +
 .../h2/src/test/java/org/h2/test/bench/BenchB.java |   240 +
 .../h2/src/test/java/org/h2/test/bench/BenchC.java |   569 +
 .../test/java/org/h2/test/bench/BenchCRandom.java  |   179 +
 .../test/java/org/h2/test/bench/BenchCThread.java  |   726 ++
 .../test/java/org/h2/test/bench/BenchSimple.java   |   114 +
 .../src/test/java/org/h2/test/bench/Database.java  |   492 +
 .../java/org/h2/test/bench/TestPerformance.java    |   277 +
 .../java/org/h2/test/bench/TestScalability.java    |   225 +
 .../src/test/java/org/h2/test/bench/package.html   |    14 +
 .../test/java/org/h2/test/bench/test.properties    |    39 +
 .../test/java/org/h2/test/coverage/Coverage.java   |   531 +
 .../test/java/org/h2/test/coverage/Profile.java    |   228 +
 .../test/java/org/h2/test/coverage/Tokenizer.java  |   277 +
 .../test/java/org/h2/test/coverage/package.html    |    14 +
 .../db/AbstractBaseForCommonTableExpressions.java  |   103 +
 modules/h2/src/test/java/org/h2/test/db/Db.java    |   252 +
 .../h2/src/test/java/org/h2/test/db/TaskDef.java   |    76 +
 .../src/test/java/org/h2/test/db/TaskProcess.java  |   132 +
 .../h2/src/test/java/org/h2/test/db/TestAlter.java |   334 +
 .../java/org/h2/test/db/TestAlterSchemaRename.java |   127 +
 .../java/org/h2/test/db/TestAnalyzeTableTx.java    |    60 +
 .../java/org/h2/test/db/TestAutoRecompile.java     |    54 +
 .../src/test/java/org/h2/test/db/TestBackup.java   |   215 +
 .../h2/src/test/java/org/h2/test/db/TestBigDb.java |   170 +
 .../test/java/org/h2/test/db/TestBigResult.java    |   499 +
 .../h2/src/test/java/org/h2/test/db/TestCases.java |  1929 +++
 .../test/java/org/h2/test/db/TestCheckpoint.java   |    58 +
 .../src/test/java/org/h2/test/db/TestCluster.java  |   518 +
 .../java/org/h2/test/db/TestCompatibility.java     |   769 ++
 .../org/h2/test/db/TestCompatibilityOracle.java    |   350 +
 .../org/h2/test/db/TestCompatibilitySQLServer.java |    84 +
 .../h2/src/test/java/org/h2/test/db/TestCsv.java   |   590 +
 .../test/java/org/h2/test/db/TestDateStorage.java  |   226 +
 .../src/test/java/org/h2/test/db/TestDeadlock.java |   417 +
 .../h2/src/test/java/org/h2/test/db/TestDrop.java  |    79 +
 .../org/h2/test/db/TestDuplicateKeyUpdate.java     |   315 +
 .../test/java/org/h2/test/db/TestEncryptedDb.java  |    65 +
 .../test/java/org/h2/test/db/TestExclusive.java    |    68 +
 .../src/test/java/org/h2/test/db/TestFullText.java |   637 +
 .../java/org/h2/test/db/TestFunctionOverload.java  |   202 +
 .../test/java/org/h2/test/db/TestFunctions.java    |  2557 ++++
 .../h2/test/db/TestGeneralCommonTableQueries.java  |   580 +
 .../h2/src/test/java/org/h2/test/db/TestIndex.java |   787 ++
 .../test/java/org/h2/test/db/TestIndexHints.java   |   136 +
 .../org/h2/test/db/TestLIRSMemoryConsumption.java  |   119 +
 .../test/java/org/h2/test/db/TestLargeBlob.java    |    92 +
 .../test/java/org/h2/test/db/TestLinkedTable.java  |   721 ++
 .../src/test/java/org/h2/test/db/TestListener.java |   151 +
 .../h2/src/test/java/org/h2/test/db/TestLob.java   |  1764 +++
 .../test/java/org/h2/test/db/TestLobObject.java    |    26 +
 .../test/java/org/h2/test/db/TestMemoryUsage.java  |   320 +
 .../test/java/org/h2/test/db/TestMergeUsing.java   |   355 +
 .../test/java/org/h2/test/db/TestMultiConn.java    |   246 +
 .../java/org/h2/test/db/TestMultiDimension.java    |   271 +
 .../test/java/org/h2/test/db/TestMultiThread.java  |   554 +
 .../org/h2/test/db/TestMultiThreadedKernel.java    |   183 +
 .../test/java/org/h2/test/db/TestOpenClose.java    |   280 +
 .../java/org/h2/test/db/TestOptimizations.java     |  1207 ++
 .../java/org/h2/test/db/TestOptimizerHints.java    |   174 +
 .../test/java/org/h2/test/db/TestOutOfMemory.java  |   255 +
 .../db/TestPersistentCommonTableExpressions.java   |   276 +
 .../src/test/java/org/h2/test/db/TestPowerOff.java |   358 +
 .../test/java/org/h2/test/db/TestQueryCache.java   |   110 +
 .../src/test/java/org/h2/test/db/TestReadOnly.java |   207 +
 .../java/org/h2/test/db/TestRecursiveQueries.java  |   183 +
 .../src/test/java/org/h2/test/db/TestRights.java   |   749 ++
 .../test/java/org/h2/test/db/TestRowFactory.java   |    65 +
 .../test/java/org/h2/test/db/TestRunscript.java    |   566 +
 .../test/java/org/h2/test/db/TestSQLInjection.java |   123 +
 .../h2/test/db/TestSelectCountNonNullColumn.java   |   108 +
 .../src/test/java/org/h2/test/db/TestSequence.java |   450 +
 .../java/org/h2/test/db/TestSessionsLocks.java     |   150 +
 .../test/java/org/h2/test/db/TestSetCollation.java |   191 +
 .../test/java/org/h2/test/db/TestSpaceReuse.java   |    70 +
 .../src/test/java/org/h2/test/db/TestSpatial.java  |  1204 ++
 .../h2/src/test/java/org/h2/test/db/TestSpeed.java |   164 +
 ...TestSubqueryPerformanceOnLazyExecutionMode.java |   167 +
 .../java/org/h2/test/db/TestSynonymForTable.java   |   334 +
 .../test/java/org/h2/test/db/TestTableEngines.java |  1916 +++
 .../test/java/org/h2/test/db/TestTempTables.java   |   363 +
 .../test/java/org/h2/test/db/TestTransaction.java  |   875 ++
 .../org/h2/test/db/TestTriggersConstraints.java    |   745 ++
 .../java/org/h2/test/db/TestTwoPhaseCommit.java    |   181 +
 .../src/test/java/org/h2/test/db/TestUpgrade.java  |   235 +
 .../test/java/org/h2/test/db/TestUsingIndex.java   |   167 +
 .../h2/src/test/java/org/h2/test/db/TestView.java  |   394 +
 .../java/org/h2/test/db/TestViewAlterTable.java    |   215 +
 .../test/java/org/h2/test/db/TestViewDropView.java |   172 +
 .../h2/src/test/java/org/h2/test/db/package.html   |    14 +
 .../java/org/h2/test/jdbc/TestBatchUpdates.java    |   551 +
 .../org/h2/test/jdbc/TestCallableStatement.java    |   583 +
 .../src/test/java/org/h2/test/jdbc/TestCancel.java |   209 +
 .../test/jdbc/TestConcurrentConnectionUsage.java   |    59 +
 .../test/java/org/h2/test/jdbc/TestConnection.java |   139 +
 .../h2/test/jdbc/TestCustomDataTypesHandler.java   |   595 +
 .../h2/test/jdbc/TestDatabaseEventListener.java    |   303 +
 .../src/test/java/org/h2/test/jdbc/TestDriver.java |    68 +
 .../org/h2/test/jdbc/TestGetGeneratedKeys.java     |  1813 +++
 .../test/java/org/h2/test/jdbc/TestJavaObject.java |   174 +
 .../org/h2/test/jdbc/TestJavaObjectSerializer.java |   156 +
 .../java/org/h2/test/jdbc/TestLimitUpdates.java    |   116 +
 .../src/test/java/org/h2/test/jdbc/TestLobApi.java |   387 +
 .../java/org/h2/test/jdbc/TestManyJdbcObjects.java |   117 +
 .../test/java/org/h2/test/jdbc/TestMetaData.java   |  1382 ++
 .../test/java/org/h2/test/jdbc/TestNativeSQL.java  |   264 +
 .../org/h2/test/jdbc/TestPreparedStatement.java    |  1761 +++
 .../test/java/org/h2/test/jdbc/TestResultSet.java  |  1998 +++
 .../src/test/java/org/h2/test/jdbc/TestSQLXML.java |   217 +
 .../test/java/org/h2/test/jdbc/TestStatement.java  |   559 +
 .../org/h2/test/jdbc/TestTransactionIsolation.java |   110 +
 .../org/h2/test/jdbc/TestUpdatableResultSet.java   |   686 +
 .../h2/test/jdbc/TestUrlJavaObjectSerializer.java  |    97 +
 .../src/test/java/org/h2/test/jdbc/TestZloty.java  |   121 +
 .../h2/src/test/java/org/h2/test/jdbc/package.html |    14 +
 .../src/test/java/org/h2/test/jdbcx/SimpleXid.java |    85 +
 .../java/org/h2/test/jdbcx/TestConnectionPool.java |   256 +
 .../java/org/h2/test/jdbcx/TestDataSource.java     |   215 +
 .../h2/src/test/java/org/h2/test/jdbcx/TestXA.java |   424 +
 .../test/java/org/h2/test/jdbcx/TestXASimple.java  |   161 +
 .../src/test/java/org/h2/test/jdbcx/package.html   |    14 +
 .../src/test/java/org/h2/test/mvcc/TestMvcc1.java  |   384 +
 .../src/test/java/org/h2/test/mvcc/TestMvcc2.java  |   171 +
 .../src/test/java/org/h2/test/mvcc/TestMvcc3.java  |   265 +
 .../src/test/java/org/h2/test/mvcc/TestMvcc4.java  |   138 +
 .../org/h2/test/mvcc/TestMvccMultiThreaded.java    |   182 +
 .../org/h2/test/mvcc/TestMvccMultiThreaded2.java   |   188 +
 .../h2/src/test/java/org/h2/test/mvcc/package.html |    14 +
 .../src/test/java/org/h2/test/otherDatabases.txt   |    75 +
 modules/h2/src/test/java/org/h2/test/package.html  |    14 +
 .../test/java/org/h2/test/poweroff/Listener.java   |    83 +
 .../src/test/java/org/h2/test/poweroff/Test.java   |   169 +
 .../java/org/h2/test/poweroff/TestRecover.java     |   375 +
 .../org/h2/test/poweroff/TestRecoverKillLoop.java  |    67 +
 .../org/h2/test/poweroff/TestReorderWrites.java    |   201 +
 .../test/java/org/h2/test/poweroff/TestWrite.java  |   134 +
 .../test/java/org/h2/test/poweroff/package.html    |    14 +
 .../java/org/h2/test/recover/RecoverLobTest.java   |    81 +
 .../src/test/java/org/h2/test/recover/package.html |    14 +
 .../java/org/h2/test/rowlock/TestRowLocks.java     |   117 +
 .../src/test/java/org/h2/test/rowlock/package.html |    14 +
 .../test/java/org/h2/test/scripts/TestScript.java  |   750 ++
 .../java/org/h2/test/scripts/altertable-fk.sql     |    26 +
 .../org/h2/test/scripts/altertable-index-reuse.sql |    33 +
 .../src/test/java/org/h2/test/scripts/comments.sql |    50 +
 .../java/org/h2/test/scripts/datatypes/array.sql   |    96 +
 .../java/org/h2/test/scripts/datatypes/bigint.sql  |    53 +
 .../java/org/h2/test/scripts/datatypes/binary.sql  |    23 +
 .../java/org/h2/test/scripts/datatypes/blob.sql    |    53 +
 .../java/org/h2/test/scripts/datatypes/boolean.sql |     4 +
 .../java/org/h2/test/scripts/datatypes/char.sql    |    75 +
 .../java/org/h2/test/scripts/datatypes/clob.sql    |    55 +
 .../java/org/h2/test/scripts/datatypes/date.sql    |    33 +
 .../java/org/h2/test/scripts/datatypes/decimal.sql |   107 +
 .../h2/test/scripts/datatypes/decimal_decimal.sql  |    47 +
 .../h2/test/scripts/datatypes/decimal_numeric.sql  |    47 +
 .../java/org/h2/test/scripts/datatypes/double.sql  |    32 +
 .../java/org/h2/test/scripts/datatypes/enum.sql    |   314 +
 .../org/h2/test/scripts/datatypes/geometry.sql     |   100 +
 .../org/h2/test/scripts/datatypes/identity.sql     |     4 +
 .../java/org/h2/test/scripts/datatypes/int.sql     |    15 +
 .../org/h2/test/scripts/datatypes/interval.sql     |   786 ++
 .../java/org/h2/test/scripts/datatypes/other.sql   |     4 +
 .../java/org/h2/test/scripts/datatypes/real.sql    |    31 +
 .../java/org/h2/test/scripts/datatypes/row.sql     |    81 +
 .../org/h2/test/scripts/datatypes/smallint.sql     |    15 +
 .../java/org/h2/test/scripts/datatypes/time.sql    |   113 +
 .../scripts/datatypes/timestamp-with-timezone.sql  |   114 +
 .../org/h2/test/scripts/datatypes/timestamp.sql    |   155 +
 .../java/org/h2/test/scripts/datatypes/tinyint.sql |    15 +
 .../java/org/h2/test/scripts/datatypes/uuid.sql    |    47 +
 .../test/scripts/datatypes/varchar-ignorecase.sql  |    17 +
 .../java/org/h2/test/scripts/datatypes/varchar.sql |    25 +
 .../java/org/h2/test/scripts/ddl/alterTableAdd.sql |   103 +
 .../h2/test/scripts/ddl/alterTableAlterColumn.sql  |    70 +
 .../h2/test/scripts/ddl/alterTableDropColumn.sql   |    98 +
 .../org/h2/test/scripts/ddl/alterTableRename.sql   |    61 +
 .../java/org/h2/test/scripts/ddl/createAlias.sql   |   127 +
 .../org/h2/test/scripts/ddl/createSequence.sql     |   100 +
 .../java/org/h2/test/scripts/ddl/createSynonym.sql |    52 +
 .../java/org/h2/test/scripts/ddl/createTable.sql   |   133 +
 .../java/org/h2/test/scripts/ddl/createTrigger.sql |    53 +
 .../java/org/h2/test/scripts/ddl/createView.sql    |    16 +
 .../java/org/h2/test/scripts/ddl/dropDomain.sql    |    48 +
 .../java/org/h2/test/scripts/ddl/dropIndex.sql     |    43 +
 .../java/org/h2/test/scripts/ddl/dropSchema.sql    |    90 +
 .../java/org/h2/test/scripts/ddl/truncateTable.sql |   125 +
 .../org/h2/test/scripts/default-and-on_update.sql  |   111 +
 .../org/h2/test/scripts/derived-column-names.sql   |    82 +
 .../src/test/java/org/h2/test/scripts/distinct.sql |   190 +
 .../test/java/org/h2/test/scripts/dml/delete.sql   |    23 +
 .../org/h2/test/scripts/dml/error_reporting.sql    |    25 +
 .../test/java/org/h2/test/scripts/dml/insert.sql   |    46 +
 .../java/org/h2/test/scripts/dml/insertIgnore.sql  |    98 +
 .../test/java/org/h2/test/scripts/dml/merge.sql    |   107 +
 .../java/org/h2/test/scripts/dml/mergeUsing.sql    |   324 +
 .../test/java/org/h2/test/scripts/dml/replace.sql  |    44 +
 .../test/java/org/h2/test/scripts/dml/script.sql   |    30 +
 .../test/java/org/h2/test/scripts/dml/select.sql   |   715 ++
 .../src/test/java/org/h2/test/scripts/dml/show.sql |   113 +
 .../test/java/org/h2/test/scripts/dml/table.sql    |    55 +
 .../test/java/org/h2/test/scripts/dml/update.sql   |    65 +
 .../test/java/org/h2/test/scripts/dml/values.sql   |    53 +
 .../src/test/java/org/h2/test/scripts/dml/with.sql |   162 +
 .../h2/src/test/java/org/h2/test/scripts/dual.sql  |    46 +
 .../h2/test/scripts/functions/aggregate/any.sql    |    33 +
 .../test/scripts/functions/aggregate/array-agg.sql |   654 +
 .../h2/test/scripts/functions/aggregate/avg.sql    |    30 +
 .../test/scripts/functions/aggregate/bit-and.sql   |    33 +
 .../h2/test/scripts/functions/aggregate/bit-or.sql |    32 +
 .../h2/test/scripts/functions/aggregate/count.sql  |   155 +
 .../test/scripts/functions/aggregate/envelope.sql  |   133 +
 .../h2/test/scripts/functions/aggregate/every.sql  |    21 +
 .../test/scripts/functions/aggregate/histogram.sql |    23 +
 .../test/scripts/functions/aggregate/listagg.sql   |   124 +
 .../h2/test/scripts/functions/aggregate/max.sql    |    36 +
 .../h2/test/scripts/functions/aggregate/min.sql    |    36 +
 .../h2/test/scripts/functions/aggregate/mode.sql   |    94 +
 .../scripts/functions/aggregate/percentile.sql     |   900 ++
 .../h2/test/scripts/functions/aggregate/rank.sql   |   128 +
 .../scripts/functions/aggregate/selectivity.sql    |     4 +
 .../scripts/functions/aggregate/stddev-pop.sql     |     4 +
 .../scripts/functions/aggregate/stddev-samp.sql    |     4 +
 .../h2/test/scripts/functions/aggregate/sum.sql    |   106 +
 .../test/scripts/functions/aggregate/var-pop.sql   |     4 +
 .../test/scripts/functions/aggregate/var-samp.sql  |     4 +
 .../org/h2/test/scripts/functions/numeric/abs.sql  |    32 +
 .../org/h2/test/scripts/functions/numeric/acos.sql |    16 +
 .../org/h2/test/scripts/functions/numeric/asin.sql |    16 +
 .../org/h2/test/scripts/functions/numeric/atan.sql |    16 +
 .../h2/test/scripts/functions/numeric/atan2.sql    |    16 +
 .../h2/test/scripts/functions/numeric/bitand.sql   |    16 +
 .../h2/test/scripts/functions/numeric/bitget.sql   |     4 +
 .../h2/test/scripts/functions/numeric/bitor.sql    |    16 +
 .../h2/test/scripts/functions/numeric/bitxor.sql   |    16 +
 .../org/h2/test/scripts/functions/numeric/ceil.sql |    16 +
 .../h2/test/scripts/functions/numeric/compress.sql |     4 +
 .../org/h2/test/scripts/functions/numeric/cos.sql  |    16 +
 .../org/h2/test/scripts/functions/numeric/cosh.sql |     4 +
 .../org/h2/test/scripts/functions/numeric/cot.sql  |    16 +
 .../h2/test/scripts/functions/numeric/decrypt.sql  |    10 +
 .../h2/test/scripts/functions/numeric/degrees.sql  |    20 +
 .../h2/test/scripts/functions/numeric/encrypt.sql  |    13 +
 .../org/h2/test/scripts/functions/numeric/exp.sql  |    16 +
 .../h2/test/scripts/functions/numeric/expand.sql   |     4 +
 .../h2/test/scripts/functions/numeric/floor.sql    |    16 +
 .../org/h2/test/scripts/functions/numeric/hash.sql |    25 +
 .../h2/test/scripts/functions/numeric/length.sql   |    40 +
 .../org/h2/test/scripts/functions/numeric/log.sql  |    28 +
 .../org/h2/test/scripts/functions/numeric/mod.sql  |    16 +
 .../h2/test/scripts/functions/numeric/ora-hash.sql |    64 +
 .../org/h2/test/scripts/functions/numeric/pi.sql   |    13 +
 .../h2/test/scripts/functions/numeric/power.sql    |    16 +
 .../h2/test/scripts/functions/numeric/radians.sql  |    20 +
 .../org/h2/test/scripts/functions/numeric/rand.sql |    21 +
 .../test/scripts/functions/numeric/random-uuid.sql |    22 +
 .../h2/test/scripts/functions/numeric/round.sql    |    28 +
 .../test/scripts/functions/numeric/roundmagic.sql  |     4 +
 .../test/scripts/functions/numeric/secure-rand.sql |     4 +
 .../org/h2/test/scripts/functions/numeric/sign.sql |    22 +
 .../org/h2/test/scripts/functions/numeric/sin.sql  |    16 +
 .../org/h2/test/scripts/functions/numeric/sinh.sql |     4 +
 .../org/h2/test/scripts/functions/numeric/sqrt.sql |    16 +
 .../org/h2/test/scripts/functions/numeric/tan.sql  |    16 +
 .../org/h2/test/scripts/functions/numeric/tanh.sql |     4 +
 .../h2/test/scripts/functions/numeric/truncate.sql |    25 +
 .../org/h2/test/scripts/functions/numeric/zero.sql |     4 +
 .../org/h2/test/scripts/functions/string/ascii.sql |    16 +
 .../test/scripts/functions/string/bit-length.sql   |     4 +
 .../org/h2/test/scripts/functions/string/char.sql  |    16 +
 .../h2/test/scripts/functions/string/concat-ws.sql |     4 +
 .../h2/test/scripts/functions/string/concat.sql    |    18 +
 .../test/scripts/functions/string/difference.sql   |    22 +
 .../h2/test/scripts/functions/string/hextoraw.sql  |    16 +
 .../h2/test/scripts/functions/string/insert.sql    |    22 +
 .../org/h2/test/scripts/functions/string/instr.sql |    16 +
 .../org/h2/test/scripts/functions/string/left.sql  |    16 +
 .../h2/test/scripts/functions/string/length.sql    |    31 +
 .../h2/test/scripts/functions/string/locate.sql    |    37 +
 .../org/h2/test/scripts/functions/string/lower.sql |    22 +
 .../org/h2/test/scripts/functions/string/lpad.sql  |     7 +
 .../org/h2/test/scripts/functions/string/ltrim.sql |    16 +
 .../test/scripts/functions/string/octet-length.sql |     4 +
 .../h2/test/scripts/functions/string/position.sql  |    16 +
 .../h2/test/scripts/functions/string/rawtohex.sql  |     4 +
 .../scripts/functions/string/regex-replace.sql     |    55 +
 .../test/scripts/functions/string/regexp-like.sql  |    15 +
 .../h2/test/scripts/functions/string/repeat.sql    |    16 +
 .../h2/test/scripts/functions/string/replace.sql   |    31 +
 .../org/h2/test/scripts/functions/string/right.sql |    16 +
 .../org/h2/test/scripts/functions/string/rpad.sql  |     7 +
 .../org/h2/test/scripts/functions/string/rtrim.sql |    16 +
 .../h2/test/scripts/functions/string/soundex.sql   |    26 +
 .../org/h2/test/scripts/functions/string/space.sql |    16 +
 .../test/scripts/functions/string/stringdecode.sql |     4 +
 .../test/scripts/functions/string/stringencode.sql |    16 +
 .../test/scripts/functions/string/stringtoutf8.sql |     4 +
 .../h2/test/scripts/functions/string/substring.sql |    34 +
 .../h2/test/scripts/functions/string/to-char.sql   |     4 +
 .../h2/test/scripts/functions/string/translate.sql |     4 +
 .../org/h2/test/scripts/functions/string/trim.sql  |    16 +
 .../org/h2/test/scripts/functions/string/upper.sql |    22 +
 .../test/scripts/functions/string/utf8tostring.sql |     7 +
 .../h2/test/scripts/functions/string/xmlattr.sql   |     4 +
 .../h2/test/scripts/functions/string/xmlcdata.sql  |    10 +
 .../test/scripts/functions/string/xmlcomment.sql   |    10 +
 .../h2/test/scripts/functions/string/xmlnode.sql   |    19 +
 .../test/scripts/functions/string/xmlstartdoc.sql  |     7 +
 .../h2/test/scripts/functions/string/xmltext.sql   |    16 +
 .../h2/test/scripts/functions/system/array-cat.sql |    22 +
 .../scripts/functions/system/array-contains.sql    |    56 +
 .../h2/test/scripts/functions/system/array-get.sql |     4 +
 .../test/scripts/functions/system/array-length.sql |     4 +
 .../test/scripts/functions/system/array-slice.sql  |    46 +
 .../test/scripts/functions/system/autocommit.sql   |    13 +
 .../scripts/functions/system/cancel-session.sql    |     4 +
 .../h2/test/scripts/functions/system/casewhen.sql  |    46 +
 .../org/h2/test/scripts/functions/system/cast.sql  |   127 +
 .../h2/test/scripts/functions/system/coalesce.sql  |    16 +
 .../h2/test/scripts/functions/system/convert.sql   |    16 +
 .../h2/test/scripts/functions/system/csvread.sql   |     4 +
 .../h2/test/scripts/functions/system/csvwrite.sql  |     4 +
 .../h2/test/scripts/functions/system/currval.sql   |     4 +
 .../scripts/functions/system/database-path.sql     |     4 +
 .../h2/test/scripts/functions/system/database.sql  |    13 +
 .../h2/test/scripts/functions/system/decode.sql    |    31 +
 .../scripts/functions/system/disk-space-used.sql   |     4 +
 .../h2/test/scripts/functions/system/file-read.sql |     4 +
 .../test/scripts/functions/system/file-write.sql   |     4 +
 .../h2/test/scripts/functions/system/greatest.sql  |     4 +
 .../h2/test/scripts/functions/system/h2version.sql |     4 +
 .../h2/test/scripts/functions/system/identity.sql  |     4 +
 .../h2/test/scripts/functions/system/ifnull.sql    |    22 +
 .../org/h2/test/scripts/functions/system/least.sql |     4 +
 .../test/scripts/functions/system/link-schema.sql  |     4 +
 .../h2/test/scripts/functions/system/lock-mode.sql |     4 +
 .../test/scripts/functions/system/lock-timeout.sql |     4 +
 .../test/scripts/functions/system/memory-free.sql  |     4 +
 .../test/scripts/functions/system/memory-used.sql  |     4 +
 .../h2/test/scripts/functions/system/nextval.sql   |     4 +
 .../h2/test/scripts/functions/system/nullif.sql    |    16 +
 .../org/h2/test/scripts/functions/system/nvl2.sql  |     4 +
 .../h2/test/scripts/functions/system/readonly.sql  |    13 +
 .../h2/test/scripts/functions/system/rownum.sql    |    17 +
 .../h2/test/scripts/functions/system/schema.sql    |     4 +
 .../scripts/functions/system/scope-identity.sql    |     4 +
 .../test/scripts/functions/system/session-id.sql   |     4 +
 .../org/h2/test/scripts/functions/system/set.sql   |    89 +
 .../org/h2/test/scripts/functions/system/table.sql |    58 +
 .../scripts/functions/system/transaction-id.sql    |     4 +
 .../scripts/functions/system/truncate-value.sql    |     4 +
 .../h2/test/scripts/functions/system/unnest.sql    |    88 +
 .../org/h2/test/scripts/functions/system/user.sql  |    19 +
 .../scripts/functions/timeanddate/add_months.sql   |    20 +
 .../scripts/functions/timeanddate/current-time.sql |    31 +
 .../scripts/functions/timeanddate/current_date.sql |    28 +
 .../functions/timeanddate/current_timestamp.sql    |   110 +
 .../scripts/functions/timeanddate/date_trunc.sql   |  1072 ++
 .../test/scripts/functions/timeanddate/dateadd.sql |   112 +
 .../scripts/functions/timeanddate/datediff.sql     |   214 +
 .../scripts/functions/timeanddate/day-of-month.sql |    32 +
 .../scripts/functions/timeanddate/day-of-week.sql  |    13 +
 .../scripts/functions/timeanddate/day-of-year.sql  |    13 +
 .../test/scripts/functions/timeanddate/dayname.sql |    13 +
 .../test/scripts/functions/timeanddate/extract.sql |   218 +
 .../functions/timeanddate/formatdatetime.sql       |    25 +
 .../h2/test/scripts/functions/timeanddate/hour.sql |    35 +
 .../test/scripts/functions/timeanddate/minute.sql  |    13 +
 .../test/scripts/functions/timeanddate/month.sql   |    13 +
 .../scripts/functions/timeanddate/monthname.sql    |    13 +
 .../functions/timeanddate/parsedatetime.sql        |    10 +
 .../test/scripts/functions/timeanddate/quarter.sql |    13 +
 .../test/scripts/functions/timeanddate/second.sql  |    13 +
 .../scripts/functions/timeanddate/truncate.sql     |    16 +
 .../h2/test/scripts/functions/timeanddate/week.sql |    24 +
 .../h2/test/scripts/functions/timeanddate/year.sql |    13 +
 .../org/h2/test/scripts/functions/window/lead.sql  |   153 +
 .../h2/test/scripts/functions/window/nth_value.sql |   263 +
 .../org/h2/test/scripts/functions/window/ntile.sql |   129 +
 .../scripts/functions/window/ratio_to_report.sql   |    38 +
 .../test/scripts/functions/window/row_number.sql   |   192 +
 .../src/test/java/org/h2/test/scripts/indexes.sql  |   352 +
 .../org/h2/test/scripts/information_schema.sql     |   105 +
 .../h2/src/test/java/org/h2/test/scripts/joins.sql |   828 ++
 .../test/java/org/h2/test/scripts/other/help.sql   |    26 +
 .../src/test/java/org/h2/test/scripts/package.html |    14 +
 .../org/h2/test/scripts/query-optimisations.sql    |    19 +
 .../test/java/org/h2/test/scripts/range_table.sql  |   224 +
 .../test/java/org/h2/test/scripts/testScript.sql   |  7957 ++++++++++++
 .../test/java/org/h2/test/scripts/testSimple.sql   |  1416 +++
 .../src/test/java/org/h2/test/scripts/window.sql   |   229 +
 .../java/org/h2/test/server/TestAutoServer.java    |   180 +
 .../src/test/java/org/h2/test/server/TestInit.java |    80 +
 .../java/org/h2/test/server/TestNestedLoop.java    |    68 +
 .../src/test/java/org/h2/test/server/TestWeb.java  |  1198 ++
 .../test/java/org/h2/test/server/WebClient.java    |   153 +
 .../src/test/java/org/h2/test/server/package.html  |    14 +
 .../org/h2/test/store/CalculateHashConstant.java   |   554 +
 .../h2/test/store/CalculateHashConstantLong.java   |   435 +
 .../test/java/org/h2/test/store/FreeSpaceList.java |   217 +
 .../test/java/org/h2/test/store/FreeSpaceTree.java |   206 +
 .../test/java/org/h2/test/store/RowDataType.java   |    95 +
 .../test/java/org/h2/test/store/SequenceMap.java   |    78 +
 .../test/java/org/h2/test/store/TestBenchmark.java |   273 +
 .../org/h2/test/store/TestCacheConcurrentLIRS.java |    94 +
 .../test/java/org/h2/test/store/TestCacheLIRS.java |   574 +
 .../org/h2/test/store/TestCacheLongKeyLIRS.java    |   515 +
 .../java/org/h2/test/store/TestConcurrent.java     |   821 ++
 .../test/java/org/h2/test/store/TestDataUtils.java |   360 +
 .../test/java/org/h2/test/store/TestDefrag.java    |    70 +
 .../test/java/org/h2/test/store/TestFreeSpace.java |   145 +
 .../java/org/h2/test/store/TestImmutableArray.java |   162 +
 .../h2/test/store/TestKillProcessWhileWriting.java |   155 +
 .../test/java/org/h2/test/store/TestMVRTree.java   |   447 +
 .../test/java/org/h2/test/store/TestMVStore.java   |  2099 ++++
 .../org/h2/test/store/TestMVStoreBenchmark.java    |   194 +
 .../h2/test/store/TestMVStoreCachePerformance.java |    97 +
 .../org/h2/test/store/TestMVStoreStopCompact.java  |    78 +
 .../java/org/h2/test/store/TestMVStoreTool.java    |   158 +
 .../java/org/h2/test/store/TestMVTableEngine.java  |  1461 +++
 .../java/org/h2/test/store/TestObjectDataType.java |   186 +
 .../java/org/h2/test/store/TestRandomMapOps.java   |   187 +
 .../java/org/h2/test/store/TestShardedMap.java     |    99 +
 .../test/java/org/h2/test/store/TestSpinLock.java  |   155 +
 .../java/org/h2/test/store/TestStreamStore.java    |   483 +
 .../org/h2/test/store/TestTransactionStore.java    |  1021 ++
 .../src/test/java/org/h2/test/store/package.html   |    14 +
 .../src/test/java/org/h2/test/synth/BnfRandom.java |   203 +
 .../test/java/org/h2/test/synth/OutputCatcher.java |    97 +
 .../java/org/h2/test/synth/TestBtreeIndex.java     |   201 +
 .../org/h2/test/synth/TestConcurrentUpdate.java    |   116 +
 .../test/java/org/h2/test/synth/TestCrashAPI.java  |   550 +
 .../test/java/org/h2/test/synth/TestDiskFull.java  |   139 +
 .../org/h2/test/synth/TestFuzzOptimizations.java   |   274 +
 .../src/test/java/org/h2/test/synth/TestHalt.java  |   354 +
 .../test/java/org/h2/test/synth/TestHaltApp.java   |   183 +
 .../src/test/java/org/h2/test/synth/TestJoin.java  |   309 +
 .../src/test/java/org/h2/test/synth/TestKill.java  |   166 +
 .../java/org/h2/test/synth/TestKillProcess.java    |    92 +
 .../java/org/h2/test/synth/TestKillRestart.java    |   232 +
 .../org/h2/test/synth/TestKillRestartMulti.java    |   330 +
 .../src/test/java/org/h2/test/synth/TestLimit.java |    93 +
 .../java/org/h2/test/synth/TestMultiThreaded.java  |   191 +
 .../java/org/h2/test/synth/TestNestedJoins.java    |   657 +
 .../java/org/h2/test/synth/TestOuterJoins.java     |   592 +
 .../java/org/h2/test/synth/TestPowerOffFs.java     |   102 +
 .../java/org/h2/test/synth/TestPowerOffFs2.java    |   229 +
 .../java/org/h2/test/synth/TestRandomCompare.java  |   308 +
 .../test/java/org/h2/test/synth/TestRandomSQL.java |   122 +
 .../org/h2/test/synth/TestReleaseSelectLock.java   |    84 +
 .../java/org/h2/test/synth/TestSimpleIndex.java    |   177 +
 .../h2/test/synth/TestStringAggCompatibility.java  |    79 +
 .../test/java/org/h2/test/synth/TestThreads.java   |   175 +
 .../src/test/java/org/h2/test/synth/TestTimer.java |   145 +
 .../src/test/java/org/h2/test/synth/package.html   |    14 +
 .../test/java/org/h2/test/synth/sql/Column.java    |   228 +
 .../test/java/org/h2/test/synth/sql/Command.java   |   427 +
 .../java/org/h2/test/synth/sql/DbConnection.java   |   209 +
 .../java/org/h2/test/synth/sql/DbInterface.java    |   118 +
 .../test/java/org/h2/test/synth/sql/DbState.java   |   120 +
 .../java/org/h2/test/synth/sql/Expression.java     |   379 +
 .../src/test/java/org/h2/test/synth/sql/Index.java |    52 +
 .../test/java/org/h2/test/synth/sql/RandomGen.java |   345 +
 .../test/java/org/h2/test/synth/sql/Result.java    |   154 +
 .../src/test/java/org/h2/test/synth/sql/Row.java   |    51 +
 .../src/test/java/org/h2/test/synth/sql/Table.java |   264 +
 .../test/java/org/h2/test/synth/sql/TestSynth.java |   346 +
 .../src/test/java/org/h2/test/synth/sql/Value.java |   338 +
 .../test/java/org/h2/test/synth/sql/package.html   |    14 +
 .../java/org/h2/test/synth/thread/TestMulti.java   |    64 +
 .../org/h2/test/synth/thread/TestMultiNews.java    |   134 +
 .../h2/test/synth/thread/TestMultiNewsSimple.java  |    95 +
 .../org/h2/test/synth/thread/TestMultiOrder.java   |   167 +
 .../org/h2/test/synth/thread/TestMultiThread.java  |    72 +
 .../java/org/h2/test/synth/thread/package.html     |    14 +
 .../java/org/h2/test/todo/TestDiskSpaceLeak.java   |    80 +
 .../java/org/h2/test/todo/TestDropTableLarge.java  |    58 +
 .../h2/test/todo/TestLinkedTableFullCondition.java |    44 +
 .../java/org/h2/test/todo/TestTempTableCrash.java  |    82 +
 .../java/org/h2/test/todo/TestUndoLogLarge.java    |    55 +
 .../src/test/java/org/h2/test/todo/columnAlias.txt |    31 +
 .../test/java/org/h2/test/todo/dateFunctions.txt   |    10 +
 .../h2/src/test/java/org/h2/test/todo/package.html |    14 +
 .../java/org/h2/test/todo/recursiveQueries.txt     |   130 +
 .../java/org/h2/test/todo/supportTemplates.txt     |   251 +
 modules/h2/src/test/java/org/h2/test/todo/todo.txt |    94 +
 .../h2/src/test/java/org/h2/test/todo/tools.sql    |    83 +
 .../src/test/java/org/h2/test/todo/versionlist.txt |    65 +
 .../h2/src/test/java/org/h2/test/trace/Arg.java    |    88 +
 .../h2/src/test/java/org/h2/test/trace/Parser.java |   279 +
 .../h2/src/test/java/org/h2/test/trace/Player.java |   179 +
 .../src/test/java/org/h2/test/trace/Statement.java |   165 +
 .../src/test/java/org/h2/test/trace/package.html   |    14 +
 .../java/org/h2/test/unit/TestAnsCompression.java  |   110 +
 .../java/org/h2/test/unit/TestAutoReconnect.java   |   218 +
 .../h2/test/unit/TestBinaryArithmeticStream.java   |   172 +
 .../test/java/org/h2/test/unit/TestBitStream.java  |   160 +
 .../h2/src/test/java/org/h2/test/unit/TestBnf.java |   177 +
 .../src/test/java/org/h2/test/unit/TestCache.java  |   293 +
 .../java/org/h2/test/unit/TestCharsetCollator.java |    70 +
 .../java/org/h2/test/unit/TestClassLoaderLeak.java |   128 +
 .../java/org/h2/test/unit/TestClearReferences.java |   235 +
 .../test/java/org/h2/test/unit/TestCollation.java  |    53 +
 .../test/java/org/h2/test/unit/TestCompress.java   |   329 +
 .../test/java/org/h2/test/unit/TestConcurrent.java |    91 +
 .../java/org/h2/test/unit/TestConnectionInfo.java  |    97 +
 .../test/java/org/h2/test/unit/TestDataPage.java   |   361 +
 .../src/test/java/org/h2/test/unit/TestDate.java   |   476 +
 .../java/org/h2/test/unit/TestDateIso8601.java     |   282 +
 .../java/org/h2/test/unit/TestDateTimeUtils.java   |   272 +
 .../java/org/h2/test/unit/TestDbException.java     |    55 +
 .../src/test/java/org/h2/test/unit/TestExit.java   |   170 +
 .../src/test/java/org/h2/test/unit/TestFile.java   |   204 +
 .../test/java/org/h2/test/unit/TestFileLock.java   |   163 +
 .../java/org/h2/test/unit/TestFileLockProcess.java |   128 +
 .../org/h2/test/unit/TestFileLockSerialized.java   |   704 ++
 .../test/java/org/h2/test/unit/TestFileSystem.java |   873 ++
 .../h2/src/test/java/org/h2/test/unit/TestFtp.java |    82 +
 .../java/org/h2/test/unit/TestGeometryUtils.java   |   494 +
 .../test/java/org/h2/test/unit/TestIntArray.java   |   112 +
 .../java/org/h2/test/unit/TestIntIntHashMap.java   |    79 +
 .../java/org/h2/test/unit/TestIntPerfectHash.java  |   109 +
 .../test/java/org/h2/test/unit/TestInterval.java   |   616 +
 .../h2/src/test/java/org/h2/test/unit/TestJmx.java |   197 +
 .../test/java/org/h2/test/unit/TestKeywords.java   |   175 +
 .../org/h2/test/unit/TestLocalResultFactory.java   |    66 +
 .../src/test/java/org/h2/test/unit/TestLocale.java |    88 +
 .../java/org/h2/test/unit/TestMVTempResult.java    |    81 +
 .../test/java/org/h2/test/unit/TestMathUtils.java  |    65 +
 .../java/org/h2/test/unit/TestMemoryUnmapper.java  |    51 +
 .../src/test/java/org/h2/test/unit/TestMode.java   |    90 +
 .../java/org/h2/test/unit/TestModifyOnWrite.java   |    78 +
 .../org/h2/test/unit/TestMultiThreadedKernel.java  |    90 +
 .../test/java/org/h2/test/unit/TestNetUtils.java   |   274 +
 .../h2/test/unit/TestObjectDeserialization.java    |    76 +
 .../test/java/org/h2/test/unit/TestOldVersion.java |   171 +
 .../test/java/org/h2/test/unit/TestOverflow.java   |   130 +
 .../test/java/org/h2/test/unit/TestPageStore.java  |   910 ++
 .../org/h2/test/unit/TestPageStoreCoverage.java    |   270 +
 .../test/java/org/h2/test/unit/TestPattern.java    |   124 +
 .../java/org/h2/test/unit/TestPerfectHash.java     |   329 +
 .../test/java/org/h2/test/unit/TestPgServer.java   |   578 +
 .../src/test/java/org/h2/test/unit/TestReader.java |    43 +
 .../test/java/org/h2/test/unit/TestRecovery.java   |   371 +
 .../src/test/java/org/h2/test/unit/TestReopen.java |   201 +
 .../test/java/org/h2/test/unit/TestSampleApps.java |   151 +
 .../java/org/h2/test/unit/TestScriptReader.java    |   199 +
 .../test/java/org/h2/test/unit/TestSecurity.java   |   296 +
 .../test/java/org/h2/test/unit/TestServlet.java    |   402 +
 .../src/test/java/org/h2/test/unit/TestShell.java  |   239 +
 .../src/test/java/org/h2/test/unit/TestSort.java   |   166 +
 .../test/java/org/h2/test/unit/TestStreams.java    |   121 +
 .../java/org/h2/test/unit/TestStringCache.java     |   180 +
 .../java/org/h2/test/unit/TestStringUtils.java     |   302 +
 .../h2/test/unit/TestTimeStampWithTimeZone.java    |   253 +
 .../src/test/java/org/h2/test/unit/TestTools.java  |  1343 ++
 .../java/org/h2/test/unit/TestTraceSystem.java     |    76 +
 .../src/test/java/org/h2/test/unit/TestUtils.java  |   325 +
 .../src/test/java/org/h2/test/unit/TestValue.java  |   621 +
 .../java/org/h2/test/unit/TestValueMemory.java     |   351 +
 .../h2/src/test/java/org/h2/test/unit/package.html |    14 +
 .../test/java/org/h2/test/utils/AssertThrows.java  |   121 +
 .../test/java/org/h2/test/utils/FilePathDebug.java |   336 +
 .../org/h2/test/utils/FilePathReorderWrites.java   |   401 +
 .../java/org/h2/test/utils/FilePathUnstable.java   |   307 +
 .../java/org/h2/test/utils/MemoryFootprint.java    |    84 +
 .../test/java/org/h2/test/utils/OutputCatcher.java |   218 +
 .../java/org/h2/test/utils/ProxyCodeGenerator.java |   360 +
 .../java/org/h2/test/utils/ResultVerifier.java     |    26 +
 .../java/org/h2/test/utils/SelfDestructor.java     |   108 +
 .../java/org/h2/test/utils/TestColumnNamer.java    |    57 +
 .../src/test/java/org/h2/test/utils/package.html   |    14 +
 modules/h2/src/test/tools/WEB-INF/console.html     |    15 +
 modules/h2/src/test/tools/WEB-INF/web.xml          |    67 +
 modules/h2/src/test/tools/org/h2/build/Build.java  |  1192 ++
 .../h2/src/test/tools/org/h2/build/BuildBase.java  |  1108 ++
 .../test/tools/org/h2/build/code/AbbaDetect.java   |   101 +
 .../test/tools/org/h2/build/code/CheckJavadoc.java |   130 +
 .../tools/org/h2/build/code/CheckTextFiles.java    |   313 +
 .../src/test/tools/org/h2/build/code/package.html  |    14 +
 .../test/tools/org/h2/build/doc/BnfRailroad.java   |   175 +
 .../src/test/tools/org/h2/build/doc/BnfSyntax.java |   114 +
 .../test/tools/org/h2/build/doc/FileConverter.java |    65 +
 .../test/tools/org/h2/build/doc/GenerateDoc.java   |   298 +
 .../test/tools/org/h2/build/doc/GenerateHelp.java  |    75 +
 .../test/tools/org/h2/build/doc/LinkChecker.java   |   276 +
 .../src/test/tools/org/h2/build/doc/MergeDocs.java |   130 +
 .../tools/org/h2/build/doc/RailroadImages.java     |   130 +
 .../test/tools/org/h2/build/doc/SpellChecker.java  |   305 +
 .../test/tools/org/h2/build/doc/UploadBuild.java   |   261 +
 .../src/test/tools/org/h2/build/doc/WebSite.java   |   168 +
 .../test/tools/org/h2/build/doc/XMLChecker.java    |   149 +
 .../src/test/tools/org/h2/build/doc/XMLParser.java |   511 +
 .../test/tools/org/h2/build/doc/buildNewsfeed.sql  |    31 +
 .../src/test/tools/org/h2/build/doc/dictionary.txt |   813 ++
 .../src/test/tools/org/h2/build/doc/package.html   |    14 +
 .../src/test/tools/org/h2/build/doclet/Doclet.java |   590 +
 .../tools/org/h2/build/doclet/ResourceDoclet.java  |   132 +
 .../test/tools/org/h2/build/doclet/package.html    |    14 +
 .../org/h2/build/i18n/PrepareTranslation.java      |   542 +
 .../tools/org/h2/build/i18n/PropertiesToUTF8.java  |   158 +
 .../src/test/tools/org/h2/build/i18n/package.html  |    14 +
 .../tools/org/h2/build/indexer/HtmlConverter.java  |   190 +
 .../test/tools/org/h2/build/indexer/Indexer.java   |   369 +
 .../src/test/tools/org/h2/build/indexer/Page.java  |    49 +
 .../test/tools/org/h2/build/indexer/Weight.java    |    43 +
 .../src/test/tools/org/h2/build/indexer/Word.java  |    82 +
 .../test/tools/org/h2/build/indexer/package.html   |    14 +
 .../h2/src/test/tools/org/h2/build/package.html    |    14 +
 .../src/test/tools/org/h2/dev/cache/CacheLIRS.java |  1081 ++
 .../src/test/tools/org/h2/dev/cache/package.html   |    14 +
 .../test/tools/org/h2/dev/cluster/ShardedMap.java  |   335 +
 .../src/test/tools/org/h2/dev/cluster/package.html |    14 +
 .../src/test/tools/org/h2/dev/fs/ArchiveTool.java  |  1200 ++
 .../test/tools/org/h2/dev/fs/ArchiveToolStore.java |   532 +
 .../src/test/tools/org/h2/dev/fs/FilePathZip2.java |   447 +
 .../h2/src/test/tools/org/h2/dev/fs/FileShell.java |   516 +
 .../h2/src/test/tools/org/h2/dev/fs/package.html   |    14 +
 .../src/test/tools/org/h2/dev/ftp/FtpClient.java   |   477 +
 .../h2/src/test/tools/org/h2/dev/ftp/package.html  |    14 +
 .../tools/org/h2/dev/ftp/server/FtpControl.java    |   420 +
 .../test/tools/org/h2/dev/ftp/server/FtpData.java  |   145 +
 .../test/tools/org/h2/dev/ftp/server/FtpEvent.java |    48 +
 .../org/h2/dev/ftp/server/FtpEventListener.java    |    34 +
 .../tools/org/h2/dev/ftp/server/FtpServer.java     |   572 +
 .../test/tools/org/h2/dev/ftp/server/package.html  |    14 +
 .../test/tools/org/h2/dev/hash/IntPerfectHash.java |   409 +
 .../tools/org/h2/dev/hash/MinimalPerfectHash.java  |   783 ++
 .../test/tools/org/h2/dev/hash/PerfectHash.java    |   258 +
 .../h2/src/test/tools/org/h2/dev/hash/package.html |    14 +
 .../test/tools/org/h2/dev/mail/SendMail.java.txt   |    45 +
 .../test/tools/org/h2/dev/net/PgTcpRedirect.java   |   559 +
 .../h2/src/test/tools/org/h2/dev/net/package.html  |    14 +
 .../org/h2/dev/security/SecureKeyStoreBuilder.java |   106 +
 .../test/tools/org/h2/dev/security/package.html    |    14 +
 .../org/h2/dev/sort/InPlaceStableMergeSort.java    |   322 +
 .../org/h2/dev/sort/InPlaceStableQuicksort.java    |   310 +
 .../h2/src/test/tools/org/h2/dev/sort/package.html |    14 +
 .../test/tools/org/h2/dev/util/AnsCompression.java |   188 +
 .../src/test/tools/org/h2/dev/util/ArrayUtils.java |    65 +
 .../h2/src/test/tools/org/h2/dev/util/Base64.java  |   234 +
 .../org/h2/dev/util/BinaryArithmeticStream.java    |   269 +
 .../src/test/tools/org/h2/dev/util/BitStream.java  |   298 +
 .../org/h2/dev/util/ConcurrentLinkedList.java      |   153 +
 .../h2/dev/util/ConcurrentLinkedListWithTail.java  |   155 +
 .../test/tools/org/h2/dev/util/ConcurrentRing.java |   155 +
 .../tools/org/h2/dev/util/FileContentHash.java     |   171 +
 .../src/test/tools/org/h2/dev/util/FileViewer.java |   214 +
 .../test/tools/org/h2/dev/util/ImmutableArray.java |   177 +
 .../tools/org/h2/dev/util/ImmutableArray2.java     |   215 +
 .../tools/org/h2/dev/util/ImmutableArray3.java     |   457 +
 .../tools/org/h2/dev/util/JavaProcessKiller.java   |   126 +
 .../h2/src/test/tools/org/h2/dev/util/Migrate.java |   249 +
 .../tools/org/h2/dev/util/ReaderInputStream.java   |    67 +
 .../tools/org/h2/dev/util/RemovePasswords.java     |    85 +
 .../tools/org/h2/dev/util/ThreadDumpCleaner.java   |   144 +
 .../tools/org/h2/dev/util/ThreadDumpFilter.java    |    42 +
 .../tools/org/h2/dev/util/ThreadDumpInliner.java   |    55 +
 .../h2/src/test/tools/org/h2/dev/util/package.html |    14 +
 .../h2/src/test/tools/org/h2/java/ClassObj.java    |   463 +
 modules/h2/src/test/tools/org/h2/java/Expr.java    |   736 ++
 modules/h2/src/test/tools/org/h2/java/Ignore.java  |    13 +
 .../h2/src/test/tools/org/h2/java/JavaParser.java  |  1848 +++
 modules/h2/src/test/tools/org/h2/java/Local.java   |    14 +
 .../h2/src/test/tools/org/h2/java/Statement.java   |   504 +
 modules/h2/src/test/tools/org/h2/java/Test.java    |    92 +
 modules/h2/src/test/tools/org/h2/java/TestApp.java |    58 +
 .../src/test/tools/org/h2/java/io/PrintStream.java |    24 +
 .../h2/src/test/tools/org/h2/java/io/package.html  |    14 +
 .../src/test/tools/org/h2/java/lang/Integer.java   |    61 +
 .../h2/src/test/tools/org/h2/java/lang/Long.java   |    62 +
 .../h2/src/test/tools/org/h2/java/lang/Math.java   |    24 +
 .../h2/src/test/tools/org/h2/java/lang/Object.java |    27 +
 .../h2/src/test/tools/org/h2/java/lang/String.java |   222 +
 .../test/tools/org/h2/java/lang/StringBuilder.java |    66 +
 .../h2/src/test/tools/org/h2/java/lang/System.java |    77 +
 .../src/test/tools/org/h2/java/lang/package.html   |    14 +
 modules/h2/src/test/tools/org/h2/java/package.html |    14 +
 .../h2/src/test/tools/org/h2/java/util/Arrays.java |    74 +
 .../src/test/tools/org/h2/java/util/package.html   |    14 +
 .../h2/src/test/tools/org/h2/jcr/Railroads.java    |   129 +
 modules/h2/src/test/tools/org/h2/jcr/help.csv      |    99 +
 modules/h2/src/test/tools/org/h2/jcr/jcr-sql2.html |    72 +
 modules/h2/src/test/tools/org/h2/jcr/package.html  |    14 +
 .../h2/src/test/tools/org/h2/jcr/stylesheet.css    |   340 +
 modules/hibernate-4.2/pom.xml                      |     6 +-
 modules/hibernate-5.1/pom.xml                      |     6 +-
 modules/hibernate-5.3/pom.xml                      |     6 +-
 modules/indexing/pom.xml                           |     6 +-
 .../processors/query/h2/CommandProcessor.java      |    24 +-
 .../processors/query/h2/H2TableDescriptor.java     |     2 +-
 .../internal/processors/query/h2/H2Utils.java      |     5 +-
 .../processors/query/h2/IgniteH2Indexing.java      |     6 +-
 .../query/h2/affinity/PartitionExtractor.java      |    14 +-
 .../query/h2/database/H2PkHashIndex.java           |    21 +-
 .../processors/query/h2/database/H2Tree.java       |     2 +-
 .../query/h2/database/H2TreeClientIndex.java       |    66 +-
 .../processors/query/h2/database/H2TreeIndex.java  |   196 +-
 .../query/h2/database/H2TreeIndexBase.java         |   110 +-
 .../query/h2/database/InlineIndexHelper.java       |    44 +-
 .../processors/query/h2/dml/DmlAstUtils.java       |     4 +-
 .../internal/processors/query/h2/dml/DmlUtils.java |     3 +-
 .../processors/query/h2/dml/UpdatePlanBuilder.java |     2 +-
 .../query/h2/opt/GridH2DefaultTableEngine.java     |     4 +-
 .../processors/query/h2/opt/GridH2IndexBase.java   |    32 +-
 .../processors/query/h2/opt/GridH2MetaTable.java   |    17 +-
 .../processors/query/h2/opt/GridH2ProxyIndex.java  |     8 +-
 .../query/h2/opt/GridH2ProxySpatialIndex.java      |     9 +-
 .../processors/query/h2/opt/GridH2Table.java       |     3 +-
 .../query/h2/opt/GridH2ValueCacheObject.java       |    17 +-
 .../processors/query/h2/opt/H2CacheRow.java        |     6 +
 .../processors/query/h2/opt/H2PlainRow.java        |     9 +
 .../processors/query/h2/opt/H2PlainRowPair.java    |     9 +
 .../processors/query/h2/opt/H2PlainRowSingle.java  |     9 +
 .../internal/processors/query/h2/opt/H2Row.java    |    38 +-
 .../processors/query/h2/opt/H2ScanIndex.java       |    22 +-
 .../processors/query/h2/opt/H2TableScanIndex.java  |    10 +-
 .../query/h2/opt/join/CollocationModel.java        |     4 +-
 .../query/h2/opt/join/DistributedLookupBatch.java  |     1 +
 .../query/h2/sql/GridSqlAggregateFunction.java     |    22 +-
 .../processors/query/h2/sql/GridSqlAlias.java      |     8 +-
 .../processors/query/h2/sql/GridSqlArray.java      |    16 +-
 .../processors/query/h2/sql/GridSqlColumn.java     |    26 +-
 .../processors/query/h2/sql/GridSqlConst.java      |     2 +-
 .../query/h2/sql/GridSqlCreateIndex.java           |     8 +-
 .../processors/query/h2/sql/GridSqlDelete.java     |     3 +-
 .../processors/query/h2/sql/GridSqlDropIndex.java  |     4 +-
 .../processors/query/h2/sql/GridSqlFunction.java   |    23 +-
 .../query/h2/sql/GridSqlFunctionType.java          |     2 +-
 .../processors/query/h2/sql/GridSqlInsert.java     |    33 +-
 .../processors/query/h2/sql/GridSqlJoin.java       |     5 +-
 .../processors/query/h2/sql/GridSqlKeyword.java    |     2 +-
 .../processors/query/h2/sql/GridSqlMerge.java      |    46 +-
 .../processors/query/h2/sql/GridSqlOperation.java  |     2 +-
 .../query/h2/sql/GridSqlOperationType.java         |     7 +-
 .../processors/query/h2/sql/GridSqlParameter.java  |     2 +-
 .../query/h2/sql/GridSqlPlaceholder.java           |     2 +-
 .../processors/query/h2/sql/GridSqlQuery.java      |    30 +-
 .../query/h2/sql/GridSqlQueryParser.java           |   153 +-
 .../processors/query/h2/sql/GridSqlSelect.java     |    27 +-
 .../processors/query/h2/sql/GridSqlStatement.java  |     2 +-
 .../processors/query/h2/sql/GridSqlSubquery.java   |     2 +-
 .../processors/query/h2/sql/GridSqlTable.java      |    14 +-
 .../processors/query/h2/sql/GridSqlType.java       |    12 +-
 .../processors/query/h2/sql/GridSqlUnion.java      |     5 +-
 .../processors/query/h2/sql/GridSqlUpdate.java     |    14 +-
 .../processors/query/h2/sql/GridSqlValueRow.java   |    49 +
 .../processors/query/h2/sys/SqlSystemIndex.java    |    17 +-
 .../query/h2/twostep/GridReduceQueryExecutor.java  |    15 +-
 .../processors/query/h2/twostep/ReduceIndex.java   |    16 +-
 .../query/h2/twostep/ReduceIndexSorted.java        |     5 +-
 .../query/h2/twostep/ReduceIndexUnsorted.java      |    17 +-
 .../processors/query/h2/twostep/ReduceTable.java   |     6 +-
 .../query/h2/twostep/ReduceTableWrapper.java       |     9 +-
 .../query/h2/twostep/msg/GridH2Array.java          |     2 +-
 .../query/h2/twostep/msg/GridH2Boolean.java        |     2 +-
 .../query/h2/twostep/msg/GridH2Byte.java           |     2 +-
 .../query/h2/twostep/msg/GridH2Bytes.java          |     2 +-
 .../query/h2/twostep/msg/GridH2Date.java           |     2 +-
 .../query/h2/twostep/msg/GridH2Decimal.java        |     2 +-
 .../query/h2/twostep/msg/GridH2Double.java         |     2 +-
 .../query/h2/twostep/msg/GridH2Float.java          |     2 +-
 .../query/h2/twostep/msg/GridH2Geometry.java       |     2 +-
 .../query/h2/twostep/msg/GridH2Integer.java        |     2 +-
 .../query/h2/twostep/msg/GridH2JavaObject.java     |     2 +-
 .../query/h2/twostep/msg/GridH2Long.java           |     2 +-
 .../query/h2/twostep/msg/GridH2Short.java          |     2 +-
 .../query/h2/twostep/msg/GridH2String.java         |     6 +-
 .../query/h2/twostep/msg/GridH2Time.java           |     2 +-
 .../query/h2/twostep/msg/GridH2Timestamp.java      |     2 +-
 .../query/h2/twostep/msg/GridH2Uuid.java           |     2 +-
 .../h2/twostep/msg/GridH2ValueMessageFactory.java  |     2 +-
 .../cache/IgniteCrossCachesJoinsQueryTest.java     |    13 +-
 .../index/ComplexPrimaryKeyUnwrapSelfTest.java     |     4 +-
 .../cache/index/DynamicColumnsAbstractTest.java    |     4 +-
 .../H2DynamicColumnsAbstractBasicSelfTest.java     |     9 +-
 .../index/H2DynamicIndexAbstractSelfTest.java      |     4 +-
 .../cache/index/H2DynamicTableSelfTest.java        |     9 +-
 .../mvcc/CacheMvccSelectForUpdateQueryTest.java    |     6 +-
 .../query/IgniteSqlKeyValueFieldsTest.java         |     4 +-
 .../query/IgniteSqlSplitterSelfTest.java           |     8 +-
 .../query/h2/database/InlineIndexHelperTest.java   |    11 +-
 .../query/h2/sql/GridQueryParsingTest.java         |     9 +-
 modules/ml/pom.xml                                 |     7 +-
 .../platforms/cpp/odbc-test/src/queries_test.cpp   |     2 +-
 modules/platforms/dotnet/build.ps1                 |     4 +-
 modules/spring/pom.xml                             |     7 +-
 parent/pom.xml                                     |    23 +-
 pom.xml                                            |     1 +
 1709 files changed, 417482 insertions(+), 694 deletions(-)

diff --git a/modules/clients/pom.xml b/modules/clients/pom.xml
index 05c40d9..301b901 100644
--- a/modules/clients/pom.xml
+++ b/modules/clients/pom.xml
@@ -112,9 +112,9 @@
         </dependency>
 
         <dependency>
-            <groupId>com.h2database</groupId>
-            <artifactId>h2</artifactId>
-            <version>${h2.version}</version>
+            <groupId>org.gridgain</groupId>
+            <artifactId>ignite-h2</artifactId>
+            <version>${project.version}</version>
             <scope>test</scope>
         </dependency>
     </dependencies>
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDynamicIndexAbstractSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDynamicIndexAbstractSelfTest.java
index 019efc2..ee9f4c9 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDynamicIndexAbstractSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDynamicIndexAbstractSelfTest.java
@@ -151,10 +151,10 @@ public abstract class JdbcDynamicIndexAbstractSelfTest extends JdbcAbstractDmlSt
 
             assertEquals(F.asList(
                 Collections.singletonList("SELECT\n" +
-                    "    ID\n" +
-                    "FROM \"default\".PERSON\n" +
-                    "    /* \"default\".IDX: ID = 5 */\n" +
-                    "WHERE ID = 5")
+                    "    \"ID\"\n" +
+                    "FROM \"default\".\"PERSON\"\n" +
+                    "    /* default.IDX: ID = 5 */\n" +
+                    "WHERE \"ID\" = 5")
             ), locRes);
         }
 
@@ -209,10 +209,10 @@ public abstract class JdbcDynamicIndexAbstractSelfTest extends JdbcAbstractDmlSt
 
             assertEquals(F.asList(
                 Collections.singletonList("SELECT\n" +
-                    "    ID\n" +
-                    "FROM \"default\".PERSON\n" +
-                    "    /* \"default\".PERSON.__SCAN_ */\n" +
-                    "WHERE ID = 5")
+                    "    \"ID\"\n" +
+                    "FROM \"default\".\"PERSON\"\n" +
+                    "    /* default.PERSON.__SCAN_ */\n" +
+                    "WHERE \"ID\" = 5")
             ), locRes);
         }
 
diff --git a/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinDynamicIndexAbstractSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinDynamicIndexAbstractSelfTest.java
index 664e45d..7f2df47 100644
--- a/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinDynamicIndexAbstractSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinDynamicIndexAbstractSelfTest.java
@@ -158,10 +158,10 @@ public abstract class JdbcThinDynamicIndexAbstractSelfTest extends JdbcThinAbstr
 
             assertEquals(F.asList(
                 Collections.singletonList("SELECT\n" +
-                    "    ID\n" +
-                    "FROM \"" + DEFAULT_CACHE_NAME + "\".PERSON\n" +
-                    "    /* \"" + DEFAULT_CACHE_NAME + "\".IDX: ID = 5 */\n" +
-                    "WHERE ID = 5")
+                    "    \"ID\"\n" +
+                    "FROM \"" + DEFAULT_CACHE_NAME + "\".\"PERSON\"\n" +
+                    "    /* " + DEFAULT_CACHE_NAME + ".IDX: ID = 5 */\n" +
+                    "WHERE \"ID\" = 5")
             ), locRes);
         }
 
@@ -220,10 +220,10 @@ public abstract class JdbcThinDynamicIndexAbstractSelfTest extends JdbcThinAbstr
 
             assertEquals(F.asList(
                 Collections.singletonList("SELECT\n" +
-                    "    ID\n" +
-                    "FROM \"" + DEFAULT_CACHE_NAME + "\".PERSON\n" +
-                    "    /* \"" + DEFAULT_CACHE_NAME + "\".PERSON.__SCAN_ */\n" +
-                    "WHERE ID = 5")
+                    "    \"ID\"\n" +
+                    "FROM \"" + DEFAULT_CACHE_NAME + "\".\"PERSON\"\n" +
+                    "    /* " + DEFAULT_CACHE_NAME + ".PERSON.__SCAN_ */\n" +
+                    "WHERE \"ID\" = 5")
             ), locRes);
         }
 
diff --git a/modules/core/pom.xml b/modules/core/pom.xml
index e73f080..3e55208 100644
--- a/modules/core/pom.xml
+++ b/modules/core/pom.xml
@@ -116,9 +116,9 @@
         </dependency>
 
         <dependency>
-            <groupId>com.h2database</groupId>
-            <artifactId>h2</artifactId>
-            <version>${h2.version}</version>
+            <groupId>org.gridgain</groupId>
+            <artifactId>ignite-h2</artifactId>
+            <version>${project.version}</version>
             <scope>test</scope>
         </dependency>
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/H2CacheStoreStrategy.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/H2CacheStoreStrategy.java
index 140aeb5..e7c0d08 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/H2CacheStoreStrategy.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/H2CacheStoreStrategy.java
@@ -80,7 +80,7 @@ public class H2CacheStoreStrategy implements TestCacheStoreStrategy {
         Server srv = null;
 
         try {
-            srv = Server.createTcpServer().start();
+            srv = Server.createTcpServer("-ifNotExists").start();
 
             port = srv.getPort();
 
diff --git a/modules/geospatial/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2SpatialIndex.java b/modules/geospatial/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2SpatialIndex.java
index 012e0ed..d339132 100644
--- a/modules/geospatial/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2SpatialIndex.java
+++ b/modules/geospatial/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2SpatialIndex.java
@@ -18,7 +18,6 @@ package org.apache.ignite.internal.processors.query.h2.opt;
 
 import java.util.ArrayList;
 import java.util.HashMap;
-import java.util.HashSet;
 import java.util.Iterator;
 import java.util.List;
 import java.util.Map;
@@ -34,6 +33,7 @@ import org.apache.ignite.internal.util.GridCursorIteratorWrapper;
 import org.apache.ignite.internal.util.lang.GridCursor;
 import org.apache.ignite.spi.indexing.IndexingQueryCacheFilter;
 import org.apache.ignite.spi.indexing.IndexingQueryFilter;
+import org.h2.command.dml.AllColumnsForPlan;
 import org.h2.engine.Session;
 import org.h2.index.Cursor;
 import org.h2.index.IndexLookupBatch;
@@ -47,7 +47,6 @@ import org.h2.mvstore.rtree.MVRTreeMap;
 import org.h2.mvstore.rtree.SpatialKey;
 import org.h2.result.SearchRow;
 import org.h2.result.SortOrder;
-import org.h2.table.Column;
 import org.h2.table.IndexColumn;
 import org.h2.table.TableFilter;
 import org.h2.value.Value;
@@ -104,8 +103,25 @@ public class GridH2SpatialIndex extends GridH2IndexBase implements SpatialIndex
      */
     @SuppressWarnings("unchecked")
     public GridH2SpatialIndex(GridH2Table tbl, String idxName, int segmentsCnt, IndexColumn... cols) {
-        super(tbl);
+        super(tbl, idxName,  validateColumns(cols), IndexType.createNonUnique(false, false, true));
 
+        // Index in memory
+        store = MVStore.open(null);
+
+        segments = new MVRTreeMap[segmentsCnt];
+
+        for (int i = 0; i < segmentsCnt; i++)
+            segments[i] = store.openMap("spatialIndex-" + i, new MVRTreeMap.Builder<Long>());
+
+        ctx = tbl.rowDescriptor().context();
+    }
+
+    /**
+     * Validate if index is applicable for given columns.
+     * @return {@code cols} as is.
+     * @throws DbException If parameter is invalid.
+     */
+    private static IndexColumn[] validateColumns(IndexColumn[] cols) {
         if (cols.length > 1)
             throw DbException.getUnsupportedException("can only do one column");
 
@@ -118,24 +134,12 @@ public class GridH2SpatialIndex extends GridH2IndexBase implements SpatialIndex
         if ((cols[0].sortType & SortOrder.NULLS_LAST) != 0)
             throw DbException.getUnsupportedException("cannot do nulls last");
 
-        initBaseIndex(tbl, 0, idxName, cols, IndexType.createNonUnique(false, false, true));
-
-        table = tbl;
-
-        if (cols[0].column.getType() != Value.GEOMETRY) {
+        if (cols[0].column.getType().getValueType() != Value.GEOMETRY) {
             throw DbException.getUnsupportedException("spatial index on non-geometry column, " +
                 cols[0].column.getCreateSQL());
         }
 
-        // Index in memory
-        store = MVStore.open(null);
-
-        segments = new MVRTreeMap[segmentsCnt];
-
-        for (int i = 0; i < segmentsCnt; i++)
-            segments[i] = store.openMap("spatialIndex-" + i, new MVRTreeMap.Builder<Long>());
-
-        ctx = tbl.rowDescriptor().context();
+        return cols;
     }
 
     /** {@inheritDoc} */
@@ -295,7 +299,7 @@ public class GridH2SpatialIndex extends GridH2IndexBase implements SpatialIndex
 
     /** {@inheritDoc} */
     @Override public double getCost(Session ses, int[] masks, TableFilter[] filters, int filter,
-        SortOrder sortOrder, HashSet<Column> cols) {
+        SortOrder sortOrder, AllColumnsForPlan cols) {
         return SpatialTreeIndex.getCostRangeIndex(masks, columns) / 10;
     }
 
diff --git a/modules/h2/README.txt b/modules/h2/README.txt
new file mode 100644
index 0000000..c39afaf
--- /dev/null
+++ b/modules/h2/README.txt
@@ -0,0 +1,32 @@
+GridGain Ignite H2 Module
+-----------------------------
+
+GridGain Ignite H2 module provides SQL engine for ignite indexing.
+
+To enable H2 module when starting a standalone node, move 'optional/ignite-h2' folder to
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
+be added to classpath in this case.
+
+Importing h2 Module In Maven Project
+------------------------------------------
+
+If you are using Maven to manage dependencies of your project, you can add H2 module
+dependency like this (replace '${ignite.version}' with actual Ignite version you are
+interested in):
+
+<project xmlns="http://maven.apache.org/POM/4.0.0"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://maven.apache.org/POM/4.0.0
+                        http://maven.apache.org/xsd/maven-4.0.0.xsd">
+    ...
+    <dependencies>
+        ...
+        <dependency>
+            <groupId>org.gridgain</groupId>
+            <artifactId>ignite-h2</artifactId>
+            <version>${ignite.version}</version>
+        </dependency>
+        ...
+    </dependencies>
+    ...
+</project>
diff --git a/modules/h2/licenses/EPL-1.0.txt b/modules/h2/licenses/EPL-1.0.txt
new file mode 100644
index 0000000..3fa0083
--- /dev/null
+++ b/modules/h2/licenses/EPL-1.0.txt
@@ -0,0 +1,86 @@
+Eclipse Public License - v 1.0
+THE ACCOMPANYING PROGRAM IS PROVIDED UNDER THE TERMS OF THIS ECLIPSE PUBLIC LICENSE ("AGREEMENT"). ANY USE, REPRODUCTION OR DISTRIBUTION OF THE PROGRAM CONSTITUTES RECIPIENT'S ACCEPTANCE OF THIS AGREEMENT.
+
+1. DEFINITIONS
+
+"Contribution" means:
+
+a) in the case of the initial Contributor, the initial code and documentation distributed under this Agreement, and
+
+b) in the case of each subsequent Contributor:
+
+i) changes to the Program, and
+
+ii) additions to the Program;
+
+where such changes and/or additions to the Program originate from and are distributed by that particular Contributor. A Contribution 'originates' from a Contributor if it was added to the Program by such Contributor itself or anyone acting on such Contributor's behalf. Contributions do not include additions to the Program which: (i) are separate modules of software distributed in conjunction with the Program under their own license agreement, and (ii) are not derivative works of the Program.
+
+"Contributor" means any person or entity that distributes the Program.
+
+"Licensed Patents" mean patent claims licensable by a Contributor which are necessarily infringed by the use or sale of its Contribution alone or when combined with the Program.
+
+"Program" means the Contributions distributed in accordance with this Agreement.
+
+"Recipient" means anyone who receives the Program under this Agreement, including all Contributors.
+
+2. GRANT OF RIGHTS
+
+a) Subject to the terms of this Agreement, each Contributor hereby grants Recipient a non-exclusive, worldwide, royalty-free copyright license to reproduce, prepare derivative works of, publicly display, publicly perform, distribute and sublicense the Contribution of such Contributor, if any, and such derivative works, in source code and object code form.
+
+b) Subject to the terms of this Agreement, each Contributor hereby grants Recipient a non-exclusive, worldwide, royalty-free patent license under Licensed Patents to make, use, sell, offer to sell, import and otherwise transfer the Contribution of such Contributor, if any, in source code and object code form. This patent license shall apply to the combination of the Contribution and the Program if, at the time the Contribution is added by the Contributor, such addition of the Contributio [...]
+
+c) Recipient understands that although each Contributor grants the licenses to its Contributions set forth herein, no assurances are provided by any Contributor that the Program does not infringe the patent or other intellectual property rights of any other entity. Each Contributor disclaims any liability to Recipient for claims brought by any other entity based on infringement of intellectual property rights or otherwise. As a condition to exercising the rights and licenses granted here [...]
+
+d) Each Contributor represents that to its knowledge it has sufficient copyright rights in its Contribution, if any, to grant the copyright license set forth in this Agreement.
+
+3. REQUIREMENTS
+
+A Contributor may choose to distribute the Program in object code form under its own license agreement, provided that:
+
+a) it complies with the terms and conditions of this Agreement; and
+
+b) its license agreement:
+
+i) effectively disclaims on behalf of all Contributors all warranties and conditions, express and implied, including warranties or conditions of title and non-infringement, and implied warranties or conditions of merchantability and fitness for a particular purpose;
+
+ii) effectively excludes on behalf of all Contributors all liability for damages, including direct, indirect, special, incidental and consequential damages, such as lost profits;
+
+iii) states that any provisions which differ from this Agreement are offered by that Contributor alone and not by any other party; and
+
+iv) states that source code for the Program is available from such Contributor, and informs licensees how to obtain it in a reasonable manner on or through a medium customarily used for software exchange.
+
+When the Program is made available in source code form:
+
+a) it must be made available under this Agreement; and
+
+b) a copy of this Agreement must be included with each copy of the Program.
+
+Contributors may not remove or alter any copyright notices contained within the Program.
+
+Each Contributor must identify itself as the originator of its Contribution, if any, in a manner that reasonably allows subsequent Recipients to identify the originator of the Contribution.
+
+4. COMMERCIAL DISTRIBUTION
+
+Commercial distributors of software may accept certain responsibilities with respect to end users, business partners and the like. While this license is intended to facilitate the commercial use of the Program, the Contributor who includes the Program in a commercial product offering should do so in a manner which does not create potential liability for other Contributors. Therefore, if a Contributor includes the Program in a commercial product offering, such Contributor ("Commercial Con [...]
+
+For example, a Contributor might include the Program in a commercial product offering, Product X. That Contributor is then a Commercial Contributor. If that Commercial Contributor then makes performance claims, or offers warranties related to Product X, those performance claims and warranties are such Commercial Contributor's responsibility alone. Under this section, the Commercial Contributor would have to defend claims against the other Contributors related to those performance claims  [...]
+
+5. NO WARRANTY
+
+EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, THE PROGRAM IS PROVIDED ON AN "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, EITHER EXPRESS OR IMPLIED INCLUDING, WITHOUT LIMITATION, ANY WARRANTIES OR CONDITIONS OF TITLE, NON-INFRINGEMENT, MERCHANTABILITY OR FITNESS FOR A PARTICULAR PURPOSE. Each Recipient is solely responsible for determining the appropriateness of using and distributing the Program and assumes all risks associated with its exercise of rights under this Ag [...]
+
+6. DISCLAIMER OF LIABILITY
+
+EXCEPT AS EXPRESSLY SET FORTH IN THIS AGREEMENT, NEITHER RECIPIENT NOR ANY CONTRIBUTORS SHALL HAVE ANY LIABILITY FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING WITHOUT LIMITATION LOST PROFITS), HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OR DISTRIBUTION OF THE PROGRAM OR THE EXERCISE OF ANY RIGHTS GRANTED HEREUNDER, EVEN IF [...]
+
+7. GENERAL
+
+If any provision of this Agreement is invalid or unenforceable under applicable law, it shall not affect the validity or enforceability of the remainder of the terms of this Agreement, and without further action by the parties hereto, such provision shall be reformed to the minimum extent necessary to make such provision valid and enforceable.
+
+If Recipient institutes patent litigation against any entity (including a cross-claim or counterclaim in a lawsuit) alleging that the Program itself (excluding combinations of the Program with other software or hardware) infringes such Recipient's patent(s), then such Recipient's rights granted under Section 2(b) shall terminate as of the date such litigation is filed.
+
+All Recipient's rights under this Agreement shall terminate if it fails to comply with any of the material terms or conditions of this Agreement and does not cure such failure in a reasonable period of time after becoming aware of such noncompliance. If all Recipient's rights under this Agreement terminate, Recipient agrees to cease use and distribution of the Program as soon as reasonably practicable. However, Recipient's obligations under this Agreement and any licenses granted by Reci [...]
+
+Everyone is permitted to copy and distribute copies of this Agreement, but in order to avoid inconsistency the Agreement is copyrighted and may only be modified in the following manner. The Agreement Steward reserves the right to publish new versions (including revisions) of this Agreement from time to time. No one other than the Agreement Steward has the right to modify this Agreement. The Eclipse Foundation is the initial Agreement Steward. The Eclipse Foundation may assign the respons [...]
+
+This Agreement is governed by the laws of the State of New York and the intellectual property laws of the United States of America. No party to this Agreement will bring a legal action under this Agreement more than one year after the cause of action arose. Each party waives its rights to a jury trial in any resulting litigation.
\ No newline at end of file
diff --git a/modules/h2/licenses/MPL-2.0.txt b/modules/h2/licenses/MPL-2.0.txt
new file mode 100644
index 0000000..4fb8136
--- /dev/null
+++ b/modules/h2/licenses/MPL-2.0.txt
@@ -0,0 +1,151 @@
+Mozilla Public License Version 2.0
+
+1. Definitions
+1.1. “Contributor”
+means each individual or legal entity that creates, contributes to the creation of, or owns Covered Software.
+
+1.2. “Contributor Version”
+means the combination of the Contributions of others (if any) used by a Contributor and that particular Contributor’s Contribution.
+
+1.3. “Contribution”
+means Covered Software of a particular Contributor.
+
+1.4. “Covered Software”
+means Source Code Form to which the initial Contributor has attached the notice in Exhibit A, the Executable Form of such Source Code Form, and Modifications of such Source Code Form, in each case including portions thereof.
+
+1.5. “Incompatible With Secondary Licenses”
+means
+
+that the initial Contributor has attached the notice described in Exhibit B to the Covered Software; or
+
+that the Covered Software was made available under the terms of version 1.1 or earlier of the License, but not also under the terms of a Secondary License.
+
+1.6. “Executable Form”
+means any form of the work other than Source Code Form.
+
+1.7. “Larger Work”
+means a work that combines Covered Software with other material, in a separate file or files, that is not Covered Software.
+
+1.8. “License”
+means this document.
+
+1.9. “Licensable”
+means having the right to grant, to the maximum extent possible, whether at the time of the initial grant or subsequently, any and all of the rights conveyed by this License.
+
+1.10. “Modifications”
+means any of the following:
+
+any file in Source Code Form that results from an addition to, deletion from, or modification of the contents of Covered Software; or
+
+any new file in Source Code Form that contains any Covered Software.
+
+1.11. “Patent Claims” of a Contributor
+means any patent claim(s), including without limitation, method, process, and apparatus claims, in any patent Licensable by such Contributor that would be infringed, but for the grant of the License, by the making, using, selling, offering for sale, having made, import, or transfer of either its Contributions or its Contributor Version.
+
+1.12. “Secondary License”
+means either the GNU General Public License, Version 2.0, the GNU Lesser General Public License, Version 2.1, the GNU Affero General Public License, Version 3.0, or any later versions of those licenses.
+
+1.13. “Source Code Form”
+means the form of the work preferred for making modifications.
+
+1.14. “You” (or “Your”)
+means an individual or a legal entity exercising rights under this License. For legal entities, “You” includes any entity that controls, is controlled by, or is under common control with You. For purposes of this definition, “control” means (a) the power, direct or indirect, to cause the direction or management of such entity, whether by contract or otherwise, or (b) ownership of more than fifty percent (50%) of the outstanding shares or beneficial ownership of such entity.
+
+2. License Grants and Conditions
+2.1. Grants
+Each Contributor hereby grants You a world-wide, royalty-free, non-exclusive license:
+
+under intellectual property rights (other than patent or trademark) Licensable by such Contributor to use, reproduce, make available, modify, display, perform, distribute, and otherwise exploit its Contributions, either on an unmodified basis, with Modifications, or as part of a Larger Work; and
+
+under Patent Claims of such Contributor to make, use, sell, offer for sale, have made, import, and otherwise transfer either its Contributions or its Contributor Version.
+
+2.2. Effective Date
+The licenses granted in Section 2.1 with respect to any Contribution become effective for each Contribution on the date the Contributor first distributes such Contribution.
+
+2.3. Limitations on Grant Scope
+The licenses granted in this Section 2 are the only rights granted under this License. No additional rights or licenses will be implied from the distribution or licensing of Covered Software under this License. Notwithstanding Section 2.1(b) above, no patent license is granted by a Contributor:
+
+for any code that a Contributor has removed from Covered Software; or
+
+for infringements caused by: (i) Your and any other third party’s modifications of Covered Software, or (ii) the combination of its Contributions with other software (except as part of its Contributor Version); or
+
+under Patent Claims infringed by Covered Software in the absence of its Contributions.
+
+This License does not grant any rights in the trademarks, service marks, or logos of any Contributor (except as may be necessary to comply with the notice requirements in Section 3.4).
+
+2.4. Subsequent Licenses
+No Contributor makes additional grants as a result of Your choice to distribute the Covered Software under a subsequent version of this License (see Section 10.2) or under the terms of a Secondary License (if permitted under the terms of Section 3.3).
+
+2.5. Representation
+Each Contributor represents that the Contributor believes its Contributions are its original creation(s) or it has sufficient rights to grant the rights to its Contributions conveyed by this License.
+
+2.6. Fair Use
+This License is not intended to limit any rights You have under applicable copyright doctrines of fair use, fair dealing, or other equivalents.
+
+2.7. Conditions
+Sections 3.1, 3.2, 3.3, and 3.4 are conditions of the licenses granted in Section 2.1.
+
+3. Responsibilities
+3.1. Distribution of Source Form
+All distribution of Covered Software in Source Code Form, including any Modifications that You create or to which You contribute, must be under the terms of this License. You must inform recipients that the Source Code Form of the Covered Software is governed by the terms of this License, and how they can obtain a copy of this License. You may not attempt to alter or restrict the recipients’ rights in the Source Code Form.
+
+3.2. Distribution of Executable Form
+If You distribute Covered Software in Executable Form then:
+
+such Covered Software must also be made available in Source Code Form, as described in Section 3.1, and You must inform recipients of the Executable Form how they can obtain a copy of such Source Code Form by reasonable means in a timely manner, at a charge no more than the cost of distribution to the recipient; and
+
+You may distribute such Executable Form under the terms of this License, or sublicense it under different terms, provided that the license for the Executable Form does not attempt to limit or alter the recipients’ rights in the Source Code Form under this License.
+
+3.3. Distribution of a Larger Work
+You may create and distribute a Larger Work under terms of Your choice, provided that You also comply with the requirements of this License for the Covered Software. If the Larger Work is a combination of Covered Software with a work governed by one or more Secondary Licenses, and the Covered Software is not Incompatible With Secondary Licenses, this License permits You to additionally distribute such Covered Software under the terms of such Secondary License(s), so that the recipient of [...]
+
+3.4. Notices
+You may not remove or alter the substance of any license notices (including copyright notices, patent notices, disclaimers of warranty, or limitations of liability) contained within the Source Code Form of the Covered Software, except that You may alter any license notices to the extent required to remedy known factual inaccuracies.
+
+3.5. Application of Additional Terms
+You may choose to offer, and to charge a fee for, warranty, support, indemnity or liability obligations to one or more recipients of Covered Software. However, You may do so only on Your own behalf, and not on behalf of any Contributor. You must make it absolutely clear that any such warranty, support, indemnity, or liability obligation is offered by You alone, and You hereby agree to indemnify every Contributor for any liability incurred by such Contributor as a result of warranty, supp [...]
+
+4. Inability to Comply Due to Statute or Regulation
+If it is impossible for You to comply with any of the terms of this License with respect to some or all of the Covered Software due to statute, judicial order, or regulation then You must: (a) comply with the terms of this License to the maximum extent possible; and (b) describe the limitations and the code they affect. Such description must be placed in a text file included with all distributions of the Covered Software under this License. Except to the extent prohibited by statute or r [...]
+
+5. Termination
+5.1. The rights granted under this License will terminate automatically if You fail to comply with any of its terms. However, if You become compliant, then the rights granted under this License from a particular Contributor are reinstated (a) provisionally, unless and until such Contributor explicitly and finally terminates Your grants, and (b) on an ongoing basis, if such Contributor fails to notify You of the non-compliance by some reasonable means prior to 60 days after You have come  [...]
+
+5.2. If You initiate litigation against any entity by asserting a patent infringement claim (excluding declaratory judgment actions, counter-claims, and cross-claims) alleging that a Contributor Version directly or indirectly infringes any patent, then the rights granted to You by any and all Contributors for the Covered Software under Section 2.1 of this License shall terminate.
+
+5.3. In the event of termination under Sections 5.1 or 5.2 above, all end user license agreements (excluding distributors and resellers) which have been validly granted by You or Your distributors under this License prior to termination shall survive termination.
+
+6. Disclaimer of Warranty
+Covered Software is provided under this License on an “as is” basis, without warranty of any kind, either expressed, implied, or statutory, including, without limitation, warranties that the Covered Software is free of defects, merchantable, fit for a particular purpose or non-infringing. The entire risk as to the quality and performance of the Covered Software is with You. Should any Covered Software prove defective in any respect, You (not any Contributor) assume the cost of any necess [...]
+
+7. Limitation of Liability
+Under no circumstances and under no legal theory, whether tort (including negligence), contract, or otherwise, shall any Contributor, or anyone who distributes Covered Software as permitted above, be liable to You for any direct, indirect, special, incidental, or consequential damages of any character including, without limitation, damages for lost profits, loss of goodwill, work stoppage, computer failure or malfunction, or any and all other commercial damages or losses, even if such pa [...]
+
+8. Litigation
+Any litigation relating to this License may be brought only in the courts of a jurisdiction where the defendant maintains its principal place of business and such litigation shall be governed by laws of that jurisdiction, without reference to its conflict-of-law provisions. Nothing in this Section shall prevent a party’s ability to bring cross-claims or counter-claims.
+
+9. Miscellaneous
+This License represents the complete agreement concerning the subject matter hereof. If any provision of this License is held to be unenforceable, such provision shall be reformed only to the extent necessary to make it enforceable. Any law or regulation which provides that the language of a contract shall be construed against the drafter shall not be used to construe this License against a Contributor.
+
+10. Versions of the License
+10.1. New Versions
+Mozilla Foundation is the license steward. Except as provided in Section 10.3, no one other than the license steward has the right to modify or publish new versions of this License. Each version will be given a distinguishing version number.
+
+10.2. Effect of New Versions
+You may distribute the Covered Software under the terms of the version of the License under which You originally received the Covered Software, or under the terms of any subsequent version published by the license steward.
+
+10.3. Modified Versions
+If you create software not governed by this License, and you want to create a new license for such software, you may create and use a modified version of this License if you rename the license and remove any references to the name of the license steward (except to note that such modified license differs from this License).
+
+10.4. Distributing Source Code Form that is Incompatible With Secondary Licenses
+If You choose to distribute Source Code Form that is Incompatible With Secondary Licenses under the terms of this version of the License, the notice described in Exhibit B of this License must be attached.
+
+Exhibit A - Source Code Form License Notice
+This Source Code Form is subject to the terms of the Mozilla Public License, v. 2.0. If a copy of the MPL was not distributed with this file, You can obtain one at https://mozilla.org/MPL/2.0/.
+
+If it is not possible or desirable to put the notice in a particular file, then You may include the notice in a location (such as a LICENSE file in a relevant directory) where a recipient would be likely to look for such a notice.
+
+You may add additional accurate notices of copyright ownership.
+
+Exhibit B - “Incompatible With Secondary Licenses” Notice
+This Source Code Form is “Incompatible With Secondary Licenses”, as defined by the Mozilla Public License, v. 2.0.
\ No newline at end of file
diff --git a/modules/h2/licenses/gg-community.txt b/modules/h2/licenses/gg-community.txt
new file mode 100644
index 0000000..4f2f7db
--- /dev/null
+++ b/modules/h2/licenses/gg-community.txt
@@ -0,0 +1,13 @@
+Copyright 2019 GridGain Systems, Inc. and Contributors.
+
+Licensed under the GridGain Community Edition License (the "License");
+you may not use this file except in compliance with the License.
+You may obtain a copy of the License at
+
+    https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+
+Unless required by applicable law or agreed to in writing, software
+distributed under the License is distributed on an "AS IS" BASIS,
+WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+See the License for the specific language governing permissions and
+limitations under the License.
\ No newline at end of file
diff --git a/modules/h2/pom.xml b/modules/h2/pom.xml
new file mode 100644
index 0000000..480e68a
--- /dev/null
+++ b/modules/h2/pom.xml
@@ -0,0 +1,232 @@
+<?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+ Copyright 2019 GridGain Systems, Inc. and Contributors.
+
+ Licensed under the GridGain Community Edition License (the "License");
+ you may not use this file except in compliance with the License.
+ You may obtain a copy of the License at
+
+     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+
+ Unless required by applicable law or agreed to in writing, software
+ distributed under the License is distributed on an "AS IS" BASIS,
+ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ See the License for the specific language governing permissions and
+ limitations under the License.
+-->
+
+<!--
+    POM file.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0"
+         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+
+    <modelVersion>4.0.0</modelVersion>
+    <parent>
+        <groupId>org.gridgain</groupId>
+        <artifactId>community.parent</artifactId>
+        <version>1</version>
+        <relativePath>../../parent</relativePath>
+    </parent>
+
+    <artifactId>ignite-h2</artifactId>
+    <version>8.8.0-SNAPSHOT</version>
+    <description>H2 Database Engine Fork</description>
+
+    <licenses>
+        <license>
+            <name>MPL 2.0</name>
+            <url>https://www.mozilla.org/en-US/MPL/2.0/</url>
+            <distribution>repo</distribution>
+        </license>
+        <license>
+            <name>EPL 1.0</name>
+            <url>https://opensource.org/licenses/eclipse-1.0.php</url>
+            <distribution>repo</distribution>
+        </license>
+    </licenses>
+
+    <properties>
+        <maven.compiler.source>1.7</maven.compiler.source>
+        <osgi.version>4.2.0</osgi.version>
+        <h2.lucene.version>5.5.5</h2.lucene.version>
+        <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
+    </properties>
+
+    <dependencies>
+        <!-- START COMPILE DEPENDENCIES !-->
+        <dependency>
+            <groupId>javax.servlet</groupId>
+            <artifactId>javax.servlet-api</artifactId>
+            <version>3.1.0</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.lucene</groupId>
+            <artifactId>lucene-core</artifactId>
+            <version>${h2.lucene.version}</version>
+            <scope>provided</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.lucene</groupId>
+            <artifactId>lucene-analyzers-common</artifactId>
+            <version>${h2.lucene.version}</version>
+            <scope>provided</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.lucene</groupId>
+            <artifactId>lucene-queryparser</artifactId>
+            <version>${h2.lucene.version}</version>
+            <scope>provided</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.slf4j</groupId>
+            <artifactId>slf4j-api</artifactId>
+            <version>${slf4j16.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.osgi</groupId>
+            <artifactId>org.osgi.core</artifactId>
+            <version>${osgi.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.osgi</groupId>
+            <artifactId>org.osgi.enterprise</artifactId>
+            <version>${osgi.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.locationtech.jts</groupId>
+            <artifactId>jts-core</artifactId>
+            <version>1.15.0</version>
+        </dependency>
+        <!-- END COMPILE DEPENDENCIES !-->
+
+
+        <!-- START TEST DEPENDENCIES !-->
+        <dependency>
+            <groupId>org.slf4j</groupId>
+            <artifactId>slf4j-simple</artifactId>
+            <version>${slf4j16.version}</version>
+            <scope>test</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.postgresql</groupId>
+            <artifactId>postgresql</artifactId>
+            <version>42.2.5.jre7</version>
+            <scope>test</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.ow2.asm</groupId>
+            <artifactId>asm</artifactId>
+            <version>7.0</version>
+            <scope>test</scope>
+        </dependency>
+        <!-- END TEST DEPENDENCIES !-->
+    </dependencies>
+
+    <!-- The test code creates proxy files using javac or tools.jar. Through maven we need to tell it
+         where to possibly find tools.jar and annoyingly its called classes.jar on OSX -->
+    <profiles>
+        <profile>
+            <id>java9+</id>
+            <activation>
+                <jdk>[1.9,)</jdk>
+            </activation>
+            <dependencies/>
+        </profile>
+    </profiles>
+
+    <build>
+        <sourceDirectory>src/main/java</sourceDirectory>
+        <testSourceDirectory>src/test/java</testSourceDirectory>
+        <!-- Resources do not follow maven project layout. We need to manually copy them -->
+        <resources>
+            <resource>
+                <directory>src/main/java</directory>
+                <includes>
+                    <include>**/*.prop</include>
+                    <include>**/*.png</include>
+                    <include>**/*.jsp</include>
+                    <include>**/*.ico</include>
+                    <include>**/*.gif</include>
+                    <include>**/*.css</include>
+                    <include>**/*.js</include>
+                    <include>org/h2/res/help.csv</include>
+                    <include>org/h2/res/javadoc.properties</include>
+                    <include>org/h2/server/pg/pg_catalog.sql</include>
+                    <include>META-INF/**</include>
+                </includes>
+            </resource>
+            <resource>
+                <directory>src/main/resources/precompiled</directory>
+                <targetPath>META-INF/versions/9</targetPath>
+            </resource>
+        </resources>
+        <testResources>
+            <testResource>
+                <directory>src/test/java</directory>
+                <includes>
+                    <include>org/h2/test/scripts/**/*.sql</include>
+                    <include>org/h2/samples/newsfeed.sql</include>
+                    <include>org/h2/samples/optimizations.sql</include>
+                </includes>
+            </testResource>
+        </testResources>
+        <plugins>
+            <!-- Add tools folder to test sources but consider moving them to src/test -->
+            <plugin>
+                <groupId>org.codehaus.mojo</groupId>
+                <artifactId>build-helper-maven-plugin</artifactId>
+                <version>3.0.0</version>
+                <executions>
+                    <execution>
+                        <phase>generate-test-sources</phase>
+                        <goals>
+                            <goal>add-test-source</goal>
+                        </goals>
+                        <configuration>
+                            <sources>
+                                <source>src/test/tools</source>
+                                <source>src/test/java/META-INF/**</source>
+                            </sources>
+                        </configuration>
+                    </execution>
+                </executions>
+            </plugin>
+
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-javadoc-plugin</artifactId>
+                <configuration>
+                    <skip>true</skip>
+                </configuration>
+            </plugin>
+
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-surefire-plugin</artifactId>
+                <configuration>
+                    <systemPropertyVariables>
+                        <h2.maxMemoryRows>100</h2.maxMemoryRows>
+                        <h2.delayWrongPasswordMin>0</h2.delayWrongPasswordMin>
+                        <h2.delayWrongPasswordMax>0</h2.delayWrongPasswordMax>
+                        <h2.useThreadContextClassLoader>true</h2.useThreadContextClassLoader>
+                        <h2.clientTraceDirectory>target/trace.db/</h2.clientTraceDirectory>
+                        <h2.javaSystemCompiler>false</h2.javaSystemCompiler>
+                        <!--<java.io.tmpdir>./target/temp</java.io.tmpdir>-->
+                    </systemPropertyVariables>
+                    <additionalClasspathElements>
+                        <additionalClasspathElement>${project.build.outputDirectory}</additionalClasspathElement>
+                        <additionalClasspathElement>${project.build.testOutputDirectory}</additionalClasspathElement>
+                    </additionalClasspathElements>
+                    <excludes>
+                        <exclude>TestAllJunit.java</exclude>
+                        <exclude>H2TestCase.java</exclude>
+                    </excludes>
+                </configuration>
+            </plugin>
+        </plugins>
+    </build>
+
+</project>
\ No newline at end of file
diff --git a/modules/h2/src/docsrc/help/help.csv b/modules/h2/src/docsrc/help/help.csv
new file mode 100644
index 0000000..f85898d
--- /dev/null
+++ b/modules/h2/src/docsrc/help/help.csv
@@ -0,0 +1,5739 @@
+# Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
+# and the EPL 1.0 (http://h2database.com/html/license.html).
+# Initial Developer: H2 Group
+
+"SECTION","TOPIC","SYNTAX","TEXT","EXAMPLE"
+
+"Commands (DML)","SELECT","
+SELECT [ TOP term [ PERCENT ] [ WITH TIES ] ]
+[ DISTINCT [ ON ( expression [,...] ) ] | ALL ]
+selectExpression [,...]
+[ FROM tableExpression [,...] ]
+[ WHERE expression ]
+[ GROUP BY expression [,...] ] [ HAVING expression ]
+[ WINDOW { { windowName AS windowSpecification } [,...] } ]
+[ QUALIFY expression ]
+[ { UNION [ ALL ] | EXCEPT | MINUS | INTERSECT } select ]
+[ ORDER BY order [,...] ]
+[ LIMIT expression [ OFFSET expression ] [ SAMPLE_SIZE rowCountInt ] ]
+[ [ OFFSET expression { ROW | ROWS } ]
+    [ FETCH { FIRST | NEXT } [ expression [ PERCENT ] ] { ROW | ROWS }
+        { ONLY | WITH TIES } ] [ SAMPLE_SIZE rowCountInt ] ]
+[ FOR UPDATE ]
+","
+Selects data from a table or multiple tables.
+
+Command is executed in the following logical order:
+
+1. Data is taken from table value expressions that are specified in the FROM clause, joins are executed.
+If FROM clause is not specified a single row is constructed.
+
+2. WHERE filters rows. Aggregate or window functions are not allowed in this clause.
+
+3. GROUP BY groups the result by the given expression(s).
+If GROUP BY clause is not specified, but non-window aggregate functions are used or HAVING is specified
+all rows are grouped together.
+
+4. Aggregate functions are evaluated, SAMPLE_SIZE limits the number of rows read.
+
+5. HAVING filters rows after grouping and evaluation of aggregate functions.
+Non-window aggregate functions are allowed in this clause.
+
+6. Window functions are evaluated.
+
+7. QUALIFY filters rows after evaluation of window functions.
+Aggregate and window functions are allowed in this clause.
+
+8. DISTINCT removes duplicates.
+If DISTINCT ON is used only the specified expressions are checked for duplicates;
+ORDER BY clause, if any, is used to determine preserved rows.
+First row is each DISTINCT ON group is preserved.
+In absence of ORDER BY preserved rows are not determined, database may choose any row from each DISTINCT ON group.
+
+9. UNION, EXCEPT (MINUS), and INTERSECT combine the result of this query with the results of another query.
+Multiple set operators (UNION, INTERSECT, MINUS, EXCEPT) are evaluated from left to right.
+For compatibility with other databases and future versions of H2 please use parentheses.
+
+10. ORDER BY sorts the result by the given column(s) or expression(s).
+
+11. Number of rows in output can be limited either with standard OFFSET / FETCH,
+with non-standard LIMIT / OFFSET, or with non-standard TOP clauses.
+Different clauses cannot be used together.
+OFFSET specifies how many rows to skip.
+Please note that queries with high offset values can be slow.
+FETCH FIRST/NEXT, LIMIT or TOP limits the number of rows returned by the query (no limit if null or smaller than zero).
+If PERCENT is specified number of rows is specified as a percent of the total number of rows
+and should be an integer value between 0 and 100 inclusive.
+WITH TIES can be used only together with ORDER BY and means that all additional rows that have the same sorting position
+as the last row will be also returned.
+
+WINDOW clause specifies window definitions for window functions and window aggregate functions.
+This clause can be used to reuse the same definition in multiple functions.
+
+If FOR UPDATE is specified, the tables or rows are locked for writing.
+This clause is not allowed in DISTINCT queries and in queries with non-window aggregates, GROUP BY, or HAVING clauses.
+When using default MVStore engine only the selected rows are locked as in an UPDATE statement.
+Rows from the right side of a left join and from the left side of a right join, including nested joins, aren't locked.
+Locking behavior for rows that were excluded from result using OFFSET / FETCH / LIMIT / TOP or QUALIFY is undefined,
+to avoid possible locking of excessive rows try to filter out unneeded rows with the WHERE criteria when possible.
+Rows are processed one by one. Committed row is read, tested with WHERE criteria, locked, read again and re-tested,
+because its value may be changed by concurrent transaction before lock acquisition.
+Note that new uncommitted rows from other transactions are not visible due to read committed isolation level
+and therefore cannot be locked.
+With PageStore engine the whole tables are locked;
+to avoid deadlocks with this engine always lock the tables in the same order in all transactions.
+","
+SELECT * FROM TEST;
+SELECT * FROM TEST ORDER BY NAME;
+SELECT ID, COUNT(*) FROM TEST GROUP BY ID;
+SELECT NAME, COUNT(*) FROM TEST GROUP BY NAME HAVING COUNT(*) > 2;
+SELECT 'ID' COL, MAX(ID) AS MAX FROM TEST UNION SELECT 'NAME', MAX(NAME) FROM TEST;
+SELECT * FROM TEST OFFSET 1000 ROWS FETCH FIRST 1000 ROWS ONLY;
+SELECT A, B FROM TEST ORDER BY A FETCH FIRST 10 ROWS WITH TIES;
+SELECT * FROM (SELECT ID, COUNT(*) FROM TEST
+    GROUP BY ID UNION SELECT NULL, COUNT(*) FROM TEST)
+    ORDER BY 1 NULLS LAST;
+SELECT DISTINCT C1, C2 FROM TEST;
+SELECT DISTINCT ON(C1) C1, C2 FROM TEST ORDER BY C1;
+"
+
+"Commands (DML)","INSERT","
+INSERT INTO tableName insertColumnsAndSource
+","
+Inserts a new row / new rows into a table.
+
+When using DIRECT, then the results from the query are directly applied in the target table without any intermediate step.
+
+When using SORTED, b-tree pages are split at the insertion point. This can improve performance and reduce disk usage.
+","
+INSERT INTO TEST VALUES(1, 'Hello')
+"
+
+"Commands (DML)","UPDATE","
+UPDATE tableName [ [ AS ] newTableAlias ] SET setClauseList
+[ WHERE expression ] [ ORDER BY order [,...] ] [ LIMIT expression ]
+","
+Updates data in a table.
+ORDER BY is supported for MySQL compatibility, but it is ignored.
+","
+UPDATE TEST SET NAME='Hi' WHERE ID=1;
+UPDATE PERSON P SET NAME=(SELECT A.NAME FROM ADDRESS A WHERE A.ID=P.ID);
+"
+
+"Commands (DML)","DELETE","
+DELETE [ TOP term ] FROM tableName [ WHERE expression ] [ LIMIT term ]
+","
+Deletes rows form a table.
+If TOP or LIMIT is specified, at most the specified number of rows are deleted (no limit if null or smaller than zero).
+","
+DELETE FROM TEST WHERE ID=2
+"
+
+"Commands (DML)","BACKUP","
+BACKUP TO fileNameString
+","
+Backs up the database files to a .zip file. Objects are not locked, but
+the backup is transactionally consistent because the transaction log is also copied.
+Admin rights are required to execute this command.
+","
+BACKUP TO 'backup.zip'
+"
+
+"Commands (DML)","CALL","
+CALL expression
+","
+Calculates a simple expression. This statement returns a result set with one row,
+except if the called function returns a result set itself.
+If the called function returns an array, then each element in this array is returned as a column.
+","
+CALL 15*25
+"
+
+"Commands (DML)","EXPLAIN","
+EXPLAIN { [ PLAN FOR ] | ANALYZE }
+{ select | insert | update | delete | merge }
+","
+Shows the execution plan for a statement.
+When using EXPLAIN ANALYZE, the statement is actually executed, and the query plan
+will include the actual row scan count for each table.
+","
+EXPLAIN SELECT * FROM TEST WHERE ID=1
+"
+
+"Commands (DML)","MERGE","
+MERGE INTO tableName [ ( columnName [,...] ) ]
+[ KEY ( columnName [,...] ) ]
+{ insertValues | select }
+","
+Updates existing rows, and insert rows that don't exist. If no key column is
+specified, the primary key columns are used to find the row. If more than one
+row per new row is affected, an exception is thrown.
+","
+MERGE INTO TEST KEY(ID) VALUES(2, 'World')
+"
+
+"Commands (DML)","MERGE USING","
+MERGE INTO targetTableName [ [AS] targetAlias]
+USING { ( select ) | sourceTableName }[ [AS] sourceAlias ]
+ON expression
+mergeWhenClause [,...]
+","
+Updates or deletes existing rows, and insert rows that don't exist.
+
+The ON clause specifies the matching column expression.
+Different rows from a source table may not match with the same target row,
+but one source row may be matched with multiple target rows.
+
+If statement doesn't need a source table a DUAL table can be substituted.
+","
+MERGE INTO TARGET_TABLE AS T USING SOURCE_TABLE AS S
+    ON T.ID = S.ID
+    WHEN MATCHED AND T.COL2 <> 'FINAL' THEN
+        UPDATE SET T.COL1 = S.COL1
+    WHEN MATCHED AND T.COL2 = 'FINAL' THEN
+        DELETE
+    WHEN NOT MATCHED THEN
+        INSERT (ID, COL1, COL2) VALUES(S.ID, S.COL1, S.COL2)
+MERGE INTO TARGET_TABLE AS T USING (SELECT * FROM SOURCE_TABLE) AS S
+    ON T.ID = S.ID
+    WHEN MATCHED AND T.COL2 <> 'FINAL' THEN
+        UPDATE SET T.COL1 = S.COL1
+    WHEN MATCHED AND T.COL2 = 'FINAL' THEN
+        DELETE
+    WHEN NOT MATCHED THEN
+        INSERT VALUES (S.ID, S.COL1, S.COL2)
+MERGE INTO TARGET_TABLE USING DUAL ON ID = 1
+    WHEN NOT MATCHED THEN INSERT VALUES (1, 'Test')
+    WHEN MATCHED THEN UPDATE SET NAME = 'Test'
+"
+
+"Commands (DML)","RUNSCRIPT","
+RUNSCRIPT FROM fileNameString scriptCompressionEncryption
+[ CHARSET charsetString ]
+","
+Runs a SQL script from a file. The script is a text file containing SQL
+statements; each statement must end with ';'. This command can be used to
+restore a database from a backup. The password must be in single quotes; it is
+case sensitive and can contain spaces.
+
+Instead of a file name, an URL may be used.
+To read a stream from the classpath, use the prefix 'classpath:'.
+See the Pluggable File System section on the Advanced page.
+
+The compression algorithm must match the one used when creating the script.
+Instead of a file, an URL may be used.
+
+Admin rights are required to execute this command.
+","
+RUNSCRIPT FROM 'backup.sql'
+RUNSCRIPT FROM 'classpath:/com/acme/test.sql'
+"
+
+"Commands (DML)","SCRIPT","
+SCRIPT { [ NODATA ] | [ SIMPLE ] [ COLUMNS ] }
+[ NOPASSWORDS ] [ NOSETTINGS ]
+[ DROP ] [ BLOCKSIZE blockSizeInt ]
+[ TO fileNameString scriptCompressionEncryption
+    [ CHARSET charsetString ] ]
+[ TABLE tableName [, ...] ]
+[ SCHEMA schemaName [, ...] ]
+","
+Creates a SQL script from the database.
+
+NODATA will not emit INSERT statements.
+SIMPLE does not use multi-row insert statements.
+COLUMNS includes column name lists into insert statements.
+If the DROP option is specified, drop statements are created for tables, views,
+and sequences. If the block size is set, CLOB and BLOB values larger than this
+size are split into separate blocks.
+BLOCKSIZE is used when writing out LOB data, and specifies the point at the
+values transition from being inserted as inline values, to be inserted using
+out-of-line commands.
+NOSETTINGS turns off dumping the database settings (the SET XXX commands)
+
+If no 'TO fileName' clause is specified, the
+script is returned as a result set. This command can be used to create a backup
+of the database. For long term storage, it is more portable than copying the
+database files.
+
+If a 'TO fileName' clause is specified, then the whole
+script (including insert statements) is written to this file, and a result set
+without the insert statements is returned.
+
+The password must be in single quotes; it is case sensitive and can contain spaces.
+
+This command locks objects while it is running.
+Admin rights are required to execute this command.
+
+When using the TABLE or SCHEMA option, only the selected table(s) / schema(s) are included.
+","
+SCRIPT NODATA
+"
+
+"Commands (DML)","SHOW","
+SHOW { SCHEMAS | TABLES [ FROM schemaName ] |
+    COLUMNS FROM tableName [ FROM schemaName ] }
+","
+Lists the schemas, tables, or the columns of a table.
+","
+SHOW TABLES
+"
+
+"Commands (DML)","Explicit table","
+TABLE [schemaName.]tableName
+[ ORDER BY order [,...] ]
+[ OFFSET expression { ROW | ROWS } ]
+[ FETCH { FIRST | NEXT } [ expression [ PERCENT ] ] { ROW | ROWS }
+    { ONLY | WITH TIES } ]
+","
+Selects data from a table.
+
+This command is an equivalent to SELECT * FROM tableName.
+See SELECT command for description of ORDER BY, OFFSET, and FETCH.
+","
+TABLE TEST;
+TABLE TEST ORDER BY ID FETCH FIRST ROW ONLY;
+"
+
+"Commands (DML)","Table value","
+VALUES rowValueExpression [,...]
+[ ORDER BY order [,...] ]
+[ OFFSET expression { ROW | ROWS } ]
+[ FETCH { FIRST | NEXT } [ expression [ PERCENT ] ] { ROW | ROWS }
+    { ONLY | WITH TIES } ]
+","
+A list of rows that can be used like a table.
+See SELECT command for description of ORDER BY, OFFSET, and FETCH.
+The column list of the resulting table is C1, C2, and so on.
+","
+VALUES (1, 'Hello'), (2, 'World');
+"
+
+"Commands (DML)","WITH","
+WITH [ RECURSIVE ] { name [( columnName [,...] )] AS ( select ) [,...] }
+{ select | insert | update | merge | delete | createTable }
+","
+Can be used to create a recursive or non-recursive query (common table expression).
+For recursive queries the first select has to be a UNION.
+One or more common table entries can be referred to by name.
+Column name declarations are now optional - the column names will be inferred from the named select queries.
+The final action in a WITH statement can be a select, insert, update, merge, delete or create table.
+","
+WITH RECURSIVE cte(n) AS (
+        SELECT 1
+    UNION ALL
+        SELECT n + 1
+        FROM cte
+        WHERE n < 100
+)
+SELECT sum(n) FROM cte;
+
+Example 2:
+WITH cte1 AS (
+        SELECT 1 AS FIRST_COLUMN
+), cte2 AS (
+        SELECT FIRST_COLUMN+1 AS FIRST_COLUMN FROM cte1
+)
+SELECT sum(FIRST_COLUMN) FROM cte2;
+"
+
+"Commands (DDL)","ALTER INDEX RENAME","
+ALTER INDEX [ IF EXISTS ] indexName RENAME TO newIndexName
+","
+Renames an index.
+This command commits an open transaction in this connection.
+","
+ALTER INDEX IDXNAME RENAME TO IDX_TEST_NAME
+"
+
+"Commands (DDL)","ALTER SCHEMA RENAME","
+ALTER SCHEMA [ IF EXISTS ] schema RENAME TO newSchemaName
+","
+Renames a schema.
+This command commits an open transaction in this connection.
+","
+ALTER SCHEMA TEST RENAME TO PRODUCTION
+"
+
+"Commands (DDL)","ALTER SEQUENCE","
+ALTER SEQUENCE [ IF EXISTS ] sequenceName
+[ RESTART WITH long ]
+[ INCREMENT BY long ]
+[ MINVALUE long | NOMINVALUE | NO MINVALUE ]
+[ MAXVALUE long | NOMAXVALUE | NO MAXVALUE ]
+[ CYCLE long | NOCYCLE | NO CYCLE ]
+[ CACHE long | NOCACHE | NO CACHE ]
+","
+Changes the parameters of a sequence.
+This command does not commit the current transaction; however the new value is used by other
+transactions immediately, and rolling back this command has no effect.
+","
+ALTER SEQUENCE SEQ_ID RESTART WITH 1000
+"
+
+"Commands (DDL)","ALTER TABLE ADD","
+ALTER TABLE [ IF EXISTS ] tableName ADD [ COLUMN ]
+{ [ IF NOT EXISTS ] columnName columnDefinition
+    | ( { columnName columnDefinition | constraint } [,...] ) }
+[ { { BEFORE | AFTER } columnName } | FIRST ]
+","
+Adds a new column to a table.
+This command commits an open transaction in this connection.
+","
+ALTER TABLE TEST ADD CREATEDATE TIMESTAMP
+"
+
+"Commands (DDL)","ALTER TABLE ADD CONSTRAINT","
+ALTER TABLE [ IF EXISTS ] tableName ADD constraint [ CHECK | NOCHECK ]
+","
+Adds a constraint to a table. If NOCHECK is specified, existing rows are not
+checked for consistency (the default is to check consistency for existing rows).
+The required indexes are automatically created if they don't exist yet.
+It is not possible to disable checking for unique constraints.
+This command commits an open transaction in this connection.
+","
+ALTER TABLE TEST ADD CONSTRAINT NAME_UNIQUE UNIQUE(NAME)
+"
+
+"Commands (DDL)","ALTER TABLE RENAME CONSTRAINT","
+ALTER TABLE [ IF EXISTS ] tableName RENAME oldConstraintName
+TO newConstraintName
+","
+Renames a constraint.
+This command commits an open transaction in this connection.
+","
+ALTER TABLE TEST RENAME CONSTRAINT FOO TO BAR
+"
+
+"Commands (DDL)","ALTER TABLE ALTER COLUMN","
+ALTER TABLE [ IF EXISTS ] tableName ALTER COLUMN columnName
+{ { columnDefinition }
+    | { RENAME TO name }
+    | { RESTART WITH long }
+    | { SELECTIVITY int }
+    | { SET DEFAULT expression }
+    | { DROP DEFAULT }
+    | { SET ON UPDATE expression }
+    | { DROP ON UPDATE }
+    | { SET NOT NULL }
+    | { DROP NOT NULL } | { SET NULL }
+    | { SET DATA TYPE dataType }
+    | { SET { VISIBLE | INVISIBLE } } }
+","
+Changes the data type of a column, rename a column,
+change the identity value, or change the selectivity.
+
+Changing the data type fails if the data can not be converted.
+
+RESTART changes the next value of an auto increment column.
+The column must already be an auto increment column.
+For RESTART, the same transactional rules as for ALTER SEQUENCE apply.
+
+SELECTIVITY sets the selectivity (1-100) for a column.
+Setting the selectivity to 0 means the default value.
+Selectivity is used by the cost based optimizer to calculate the estimated cost of an index.
+Selectivity 100 means values are unique, 10 means every distinct value appears 10 times on average.
+
+SET DEFAULT changes the default value of a column.
+
+DROP DEFAULT removes the default value of a column.
+
+SET ON UPDATE changes the value that is set on update if value for this column is not specified in update statement.
+
+DROP ON UPDATE removes the value that is set on update of a column.
+
+SET NOT NULL sets a column to not allow NULL. Rows may not contains NULL in this column.
+
+DROP NOT NULL and SET NULL set a column to allow NULL. The row may not be part of a primary key.
+
+SET DATA TYPE changes the data type of a column.
+
+SET INVISIBLE makes the column hidden, i.e. it will not appear in SELECT * results.
+SET VISIBLE has the reverse effect.
+
+This command commits an open transaction in this connection.
+","
+ALTER TABLE TEST ALTER COLUMN NAME CLOB;
+ALTER TABLE TEST ALTER COLUMN NAME RENAME TO TEXT;
+ALTER TABLE TEST ALTER COLUMN ID RESTART WITH 10000;
+ALTER TABLE TEST ALTER COLUMN NAME SELECTIVITY 100;
+ALTER TABLE TEST ALTER COLUMN NAME SET DEFAULT '';
+ALTER TABLE TEST ALTER COLUMN NAME SET NOT NULL;
+ALTER TABLE TEST ALTER COLUMN NAME SET NULL;
+ALTER TABLE TEST ALTER COLUMN NAME SET VISIBLE;
+ALTER TABLE TEST ALTER COLUMN NAME SET INVISIBLE;
+"
+
+"Commands (DDL)","ALTER TABLE DROP COLUMN","
+ALTER TABLE [ IF EXISTS ] tableName DROP COLUMN [ IF EXISTS ]
+columnName [,...] | ( columnName [,...] )
+","
+Removes column(s) from a table.
+This command commits an open transaction in this connection.
+","
+ALTER TABLE TEST DROP COLUMN NAME
+ALTER TABLE TEST DROP COLUMN NAME1, NAME2
+ALTER TABLE TEST DROP COLUMN (NAME1, NAME2)
+"
+
+"Commands (DDL)","ALTER TABLE DROP CONSTRAINT","
+ALTER TABLE [ IF EXISTS ] tableName DROP
+{ CONSTRAINT [ IF EXISTS ] constraintName | PRIMARY KEY }
+","
+Removes a constraint or a primary key from a table.
+This command commits an open transaction in this connection.
+","
+ALTER TABLE TEST DROP CONSTRAINT UNIQUE_NAME
+"
+
+"Commands (DDL)","ALTER TABLE SET","
+ALTER TABLE [ IF EXISTS ] tableName SET REFERENTIAL_INTEGRITY
+{ FALSE | TRUE } [ CHECK | NOCHECK ]
+","
+Disables or enables referential integrity checking for a table. This command can
+be used inside a transaction. Enabling referential integrity does not check
+existing data, except if CHECK is specified. Use SET REFERENTIAL_INTEGRITY to
+disable it for all tables; the global flag and the flag for each table are
+independent.
+
+This command commits an open transaction in this connection.
+","
+ALTER TABLE TEST SET REFERENTIAL_INTEGRITY FALSE
+"
+
+"Commands (DDL)","ALTER TABLE RENAME","
+ALTER TABLE [ IF EXISTS ] tableName RENAME TO newName
+","
+Renames a table.
+This command commits an open transaction in this connection.
+","
+ALTER TABLE TEST RENAME TO MY_DATA
+"
+
+"Commands (DDL)","ALTER USER ADMIN","
+ALTER USER userName ADMIN { TRUE | FALSE }
+","
+Switches the admin flag of a user on or off.
+
+Only unquoted or uppercase user names are allowed.
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+ALTER USER TOM ADMIN TRUE
+"
+
+"Commands (DDL)","ALTER USER RENAME","
+ALTER USER userName RENAME TO newUserName
+","
+Renames a user.
+After renaming a user, the password becomes invalid and needs to be changed as well.
+
+Only unquoted or uppercase user names are allowed.
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+ALTER USER TOM RENAME TO THOMAS
+"
+
+"Commands (DDL)","ALTER USER SET PASSWORD","
+ALTER USER userName SET { PASSWORD string | SALT bytes HASH bytes }
+","
+Changes the password of a user.
+Only unquoted or uppercase user names are allowed.
+The password must be enclosed in single quotes. It is case sensitive
+and can contain spaces. The salt and hash values are hex strings.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+ALTER USER SA SET PASSWORD 'rioyxlgt'
+"
+
+"Commands (DDL)","ALTER VIEW RECOMPILE","
+ALTER VIEW [ IF EXISTS ] viewName RECOMPILE
+","
+Recompiles a view after the underlying tables have been changed or created.
+This command is used for views created using CREATE FORCE VIEW.
+This command commits an open transaction in this connection.
+","
+ALTER VIEW ADDRESS_VIEW RECOMPILE
+"
+
+"Commands (DDL)","ALTER VIEW RENAME","
+ALTER VIEW [ IF EXISTS ] viewName RENAME TO newName
+","
+Renames a view.
+This command commits an open transaction in this connection.
+","
+ALTER VIEW TEST RENAME TO MY_VIEW
+"
+
+"Commands (DDL)","ANALYZE","
+ANALYZE [ TABLE tableName ] [ SAMPLE_SIZE rowCountInt ]
+","
+Updates the selectivity statistics of tables.
+If no table name is given, all tables are analyzed.
+The selectivity is used by the
+cost based optimizer to select the best index for a given query. If no sample
+size is set, up to 10000 rows per table are read. The value 0 means all rows are
+read. The selectivity can be set manually using ALTER TABLE ALTER COLUMN
+SELECTIVITY. Manual values are overwritten by this statement. The selectivity is
+available in the INFORMATION_SCHEMA.COLUMNS table.
+
+This command commits an open transaction in this connection.
+","
+ANALYZE SAMPLE_SIZE 1000
+"
+
+"Commands (DDL)","COMMENT","
+COMMENT ON
+{ { COLUMN [ schemaName. ] tableName.columnName }
+    | { { TABLE | VIEW | CONSTANT | CONSTRAINT | ALIAS | INDEX | ROLE
+    | SCHEMA | SEQUENCE | TRIGGER | USER | DOMAIN } [ schemaName. ] objectName } }
+IS expression
+","
+Sets the comment of a database object. Use NULL to remove the comment.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+COMMENT ON TABLE TEST IS 'Table used for testing'
+"
+
+"Commands (DDL)","CREATE AGGREGATE","
+CREATE AGGREGATE [ IF NOT EXISTS ] newAggregateName FOR className
+","
+Creates a new user-defined aggregate function. The method name must be the full
+qualified class name. The class must implement the interface
+""org.h2.api.Aggregate"" or ""org.h2.api.AggregateFunction"".
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+CREATE AGGREGATE SIMPLE_MEDIAN FOR ""com.acme.db.Median""
+"
+
+"Commands (DDL)","CREATE ALIAS","
+CREATE ALIAS [ IF NOT EXISTS ] newFunctionAliasName [ DETERMINISTIC ]
+[ NOBUFFER ] { FOR classAndMethodName | AS sourceCodeString }
+","
+Creates a new function alias. If this is a ResultSet returning function,
+by default the return value is cached in a local temporary file.
+
+NOBUFFER - disables caching of ResultSet return value to temporary file.
+
+DETERMINISTIC - Deterministic functions must always return the same value for the same parameters.
+
+The method name must be the full qualified class and method name,
+and may optionally include the parameter classes as in
+""java.lang.Integer.parseInt(java.lang.String, int)"". The class and the method
+must both be public, and the method must be static. The class must be available
+in the classpath of the database engine (when using the server mode,
+it must be in the classpath of the server).
+
+When defining a function alias with source code, the Sun ""javac"" is compiler
+is used if the file ""tools.jar"" is in the classpath. If not, ""javac"" is run as a separate process.
+Only the source code is stored in the database; the class is compiled each time
+the database is re-opened. Source code is usually passed
+as dollar quoted text to avoid escaping problems. If import statements are used,
+then the tag @CODE must be added before the method.
+
+If the method throws an SQLException, it is directly re-thrown to the calling application;
+all other exceptions are first converted to a SQLException.
+
+If the first parameter of the Java function is a ""java.sql.Connection"", then a
+connection to the database is provided. This connection must not be closed.
+If the class contains multiple methods with the given name but different
+parameter count, all methods are mapped.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+
+If you have the Groovy jar in your classpath, it is also possible to write methods using Groovy.
+","
+CREATE ALIAS MY_SQRT FOR ""java.lang.Math.sqrt"";
+CREATE ALIAS GET_SYSTEM_PROPERTY FOR ""java.lang.System.getProperty"";
+CALL GET_SYSTEM_PROPERTY('java.class.path');
+CALL GET_SYSTEM_PROPERTY('com.acme.test', 'true');
+CREATE ALIAS REVERSE AS $$ String reverse(String s) { return new StringBuilder(s).reverse().toString(); } $$;
+CALL REVERSE('Test');
+CREATE ALIAS tr AS $$@groovy.transform.CompileStatic
+    static String tr(String str, String sourceSet, String replacementSet){
+        return str.tr(sourceSet, replacementSet);
+    }
+$$
+"
+
+"Commands (DDL)","CREATE CONSTANT","
+CREATE CONSTANT [ IF NOT EXISTS ] newConstantName VALUE expression
+","
+Creates a new constant.
+This command commits an open transaction in this connection.
+","
+CREATE CONSTANT ONE VALUE 1
+"
+
+"Commands (DDL)","CREATE DOMAIN","
+CREATE DOMAIN [ IF NOT EXISTS ] newDomainName AS dataType
+[ DEFAULT expression ] [ [ NOT ] NULL ] [ SELECTIVITY selectivity ]
+[ CHECK condition ]
+","
+Creates a new data type (domain). The check condition must evaluate to true or
+to NULL (to prevent NULL, use ""NOT NULL""). In the condition, the term VALUE refers
+to the value being tested.
+
+Domains are usable within the whole database. They can not be created in a specific schema.
+
+This command commits an open transaction in this connection.
+","
+CREATE DOMAIN EMAIL AS VARCHAR(255) CHECK (POSITION('@', VALUE) > 1)
+"
+
+"Commands (DDL)","CREATE INDEX","
+CREATE
+{ [ UNIQUE ] [ HASH | SPATIAL] INDEX [ [ IF NOT EXISTS ] newIndexName ]
+    | PRIMARY KEY [ HASH ] }
+ON tableName ( indexColumn [,...] )
+","
+Creates a new index.
+This command commits an open transaction in this connection.
+
+Hash indexes are meant for in-memory databases and memory tables (CREATE MEMORY TABLE) when PageStore engine is used.
+For other tables, or if the index contains multiple columns, the HASH keyword is ignored.
+Hash indexes can only test for equality, do not support range queries (similar to a hash table), use more memory,
+but can perform lookups faster.
+Non-unique keys are supported.
+
+Spatial indexes are supported only on Geometry columns.
+","
+CREATE INDEX IDXNAME ON TEST(NAME)
+"
+
+"Commands (DDL)","CREATE LINKED TABLE","
+CREATE [ FORCE ] [ [ GLOBAL | LOCAL ] TEMPORARY ]
+LINKED TABLE [ IF NOT EXISTS ]
+name ( driverString, urlString, userString, passwordString,
+[ originalSchemaString, ] originalTableString ) [ EMIT UPDATES | READONLY ]
+","
+Creates a table link to an external table. The driver name may be empty if the
+driver is already loaded. If the schema name is not set, only one table with
+that name may exist in the target database.
+
+FORCE - Create the LINKED TABLE even if the remote database/table does not exist.
+
+EMIT UPDATES - Usually, for update statements, the old rows are deleted first and then the new
+rows are inserted. It is possible to emit update statements (except on
+rollback), however in this case multi-row unique key updates may not always
+work. Linked tables to the same database share one connection.
+
+READONLY - is set, the remote table may not be updated. This is enforced by H2.
+
+If the connection to the source database is lost, the connection is re-opened
+(this is a workaround for MySQL that disconnects after 8 hours of inactivity by default).
+
+If a query is used instead of the original table name, the table is read only.
+Queries must be enclosed in parenthesis: ""(SELECT * FROM ORDERS)"".
+
+To use JNDI to get the connection, the driver class must be a
+javax.naming.Context (for example ""javax.naming.InitialContext""), and the URL must
+be the resource name (for example ""java:comp/env/jdbc/Test"").
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+CREATE LINKED TABLE LINK('org.h2.Driver', 'jdbc:h2:test2',
+    'sa', 'sa', 'TEST');
+CREATE LINKED TABLE LINK('', 'jdbc:h2:test2', 'sa', 'sa',
+    '(SELECT * FROM TEST WHERE ID>0)');
+CREATE LINKED TABLE LINK('javax.naming.InitialContext',
+    'java:comp/env/jdbc/Test', NULL, NULL,
+    '(SELECT * FROM TEST WHERE ID>0)');
+"
+
+"Commands (DDL)","CREATE ROLE","
+CREATE ROLE [ IF NOT EXISTS ] newRoleName
+","
+Creates a new role.
+This command commits an open transaction in this connection.
+","
+CREATE ROLE READONLY
+"
+
+"Commands (DDL)","CREATE SCHEMA","
+CREATE SCHEMA [ IF NOT EXISTS ] name
+[ AUTHORIZATION ownerUserName ]
+[ WITH tableEngineParamName [,...] ]
+","
+Creates a new schema. If no owner is specified, the current user is used. The
+user that executes the command must have admin rights, as well as the owner.
+Specifying the owner currently has no effect.
+Optional table engine parameters are used when CREATE TABLE command
+is run on this schema without having its engine params set.
+
+This command commits an open transaction in this connection.
+","
+CREATE SCHEMA TEST_SCHEMA AUTHORIZATION SA
+"
+
+"Commands (DDL)","CREATE SEQUENCE","
+CREATE SEQUENCE [ IF NOT EXISTS ] newSequenceName
+sequenceOptions
+","
+Creates a new sequence.
+The data type of a sequence is BIGINT.
+Used values are never re-used, even when the transaction is rolled back.
+
+The cache is the number of pre-allocated numbers.
+If the system crashes without closing the database, at most this many numbers are lost.
+The default cache size is 32.
+To disable caching, use the cache size 1 or lower.
+
+This command commits an open transaction in this connection.
+","
+CREATE SEQUENCE SEQ_ID
+"
+
+"Commands (DDL)","CREATE TABLE","
+CREATE [ CACHED | MEMORY ] [ TEMP | [ GLOBAL | LOCAL ] TEMPORARY ]
+TABLE [ IF NOT EXISTS ] name
+[ ( { columnName [columnDefinition] | constraint } [,...] ) ]
+[ ENGINE tableEngineName ]
+[ WITH tableEngineParamName [,...] ]
+[ NOT PERSISTENT ] [ TRANSACTIONAL ]
+[ AS select [ WITH [ NO ] DATA ] ]","
+Creates a new table.
+
+Cached tables (the default for regular tables) are persistent,
+and the number of rows is not limited by the main memory.
+Memory tables (the default for temporary tables) are persistent,
+but the index data is kept in main memory,
+that means memory tables should not get too large.
+
+Temporary tables are deleted when closing or opening a database.
+Temporary tables can be global (accessible by all connections)
+or local (only accessible by the current connection).
+The default for temporary tables is global.
+Indexes of temporary tables are kept fully in main memory,
+unless the temporary table is created using CREATE CACHED TABLE.
+
+The ENGINE option is only required when custom table implementations are used.
+The table engine class must implement the interface ""org.h2.api.TableEngine"".
+Any table engine parameters are passed down in the tableEngineParams field of the CreateTableData object.
+
+Either ENGINE, or WITH (table engine params), or both may be specified. If ENGINE is not specified
+in CREATE TABLE, then the engine specified by DEFAULT_TABLE_ENGINE option of database params is used.
+
+Tables with the NOT PERSISTENT modifier are kept fully in memory, and all
+rows are lost when the database is closed.
+
+The column definitions are optional if a query is specified.
+In that case the column list of the query is used.
+If the query is specified its results are inserted into created table unless WITH NO DATA is specified.
+
+This command commits an open transaction, except when using
+TRANSACTIONAL (only supported for temporary tables).
+","
+CREATE TABLE TEST(ID INT PRIMARY KEY, NAME VARCHAR(255))
+"
+
+"Commands (DDL)","CREATE TRIGGER","
+CREATE TRIGGER [ IF NOT EXISTS ] newTriggerName
+{ BEFORE | AFTER | INSTEAD OF }
+{ INSERT | UPDATE | DELETE | SELECT | ROLLBACK }
+[,...] ON tableName [ FOR EACH ROW ]
+[ QUEUE int ] [ NOWAIT ]
+{ CALL triggeredClassName | AS sourceCodeString }
+","
+Creates a new trigger.
+The trigger class must be public and implement ""org.h2.api.Trigger"".
+Inner classes are not supported.
+The class must be available in the classpath of the database engine
+(when using the server mode, it must be in the classpath of the server).
+
+The sourceCodeString must define a single method with no parameters that returns ""org.h2.api.Trigger"".
+See CREATE ALIAS for requirements regarding the compilation.
+Alternatively, javax.script.ScriptEngineManager can be used to create an instance of ""org.h2.api.Trigger"".
+Currently javascript (included in every JRE) and ruby (with JRuby) are supported.
+In that case the source must begin respectively with ""//javascript"" or ""#ruby"".
+
+BEFORE triggers are called after data conversion is made, default values are set,
+null and length constraint checks have been made;
+but before other constraints have been checked.
+If there are multiple triggers, the order in which they are called is undefined.
+
+ROLLBACK can be specified in combination with INSERT, UPDATE, and DELETE.
+Only row based AFTER trigger can be called on ROLLBACK.
+Exceptions that occur within such triggers are ignored.
+As the operations that occur within a trigger are part of the transaction,
+ROLLBACK triggers are only required if an operation communicates outside of the database.
+
+INSTEAD OF triggers are implicitly row based and behave like BEFORE triggers.
+Only the first such trigger is called. Such triggers on views are supported.
+They can be used to make views updatable.
+
+A BEFORE SELECT trigger is fired just before the database engine tries to read from the table.
+The trigger can be used to update a table on demand.
+The trigger is called with both 'old' and 'new' set to null.
+
+The MERGE statement will call both INSERT and UPDATE triggers.
+Not supported are SELECT triggers with the option FOR EACH ROW,
+and AFTER SELECT triggers.
+
+Committing or rolling back a transaction within a trigger is not allowed, except for SELECT triggers.
+
+By default a trigger is called once for each statement, without the old and new rows.
+FOR EACH ROW triggers are called once for each inserted, updated, or deleted row.
+
+QUEUE is implemented for syntax compatibility with HSQL and has no effect.
+
+The trigger need to be created in the same schema as the table.
+The schema name does not need to be specified when creating the trigger.
+
+This command commits an open transaction in this connection.
+","
+CREATE TRIGGER TRIG_INS BEFORE INSERT ON TEST FOR EACH ROW CALL ""MyTrigger"";
+CREATE TRIGGER TRIG_SRC BEFORE INSERT ON TEST AS $$org.h2.api.Trigger create() { return new MyTrigger(""constructorParam""); } $$;
+CREATE TRIGGER TRIG_JS BEFORE INSERT ON TEST AS $$//javascript\nreturn new Packages.MyTrigger(""constructorParam""); $$;
+CREATE TRIGGER TRIG_RUBY BEFORE INSERT ON TEST AS $$#ruby\nJava::MyPackage::MyTrigger.new(""constructorParam"") $$;
+"
+"Commands (DDL)","CREATE USER","
+CREATE USER [ IF NOT EXISTS ] newUserName
+{ PASSWORD string | SALT bytes HASH bytes } [ ADMIN ]
+","
+Creates a new user. For compatibility, only unquoted or uppercase user names are allowed.
+The password must be in single quotes. It is case sensitive and can contain spaces.
+The salt and hash values are hex strings.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+CREATE USER GUEST PASSWORD 'abc'
+"
+
+"Commands (DDL)","CREATE VIEW","
+CREATE [ OR REPLACE ] [ FORCE ] VIEW [ IF NOT EXISTS ] newViewName
+[ ( columnName [,...] ) ] AS select
+","
+Creates a new view. If the force option is used, then the view is created even
+if the underlying table(s) don't exist.
+
+If the OR REPLACE clause is used an existing view will be replaced, and any
+dependent views will not need to be recreated. If dependent views will become
+invalid as a result of the change an error will be generated, but this error
+can be ignored if the FORCE clause is also used.
+
+Views are not updatable except when using 'instead of' triggers.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+CREATE VIEW TEST_VIEW AS SELECT * FROM TEST WHERE ID < 100
+"
+
+"Commands (DDL)","DROP AGGREGATE","
+DROP AGGREGATE [ IF EXISTS ] aggregateName
+","
+Drops an existing user-defined aggregate function.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+DROP AGGREGATE SIMPLE_MEDIAN
+"
+
+"Commands (DDL)","DROP ALIAS","
+DROP ALIAS [ IF EXISTS ] existingFunctionAliasName
+","
+Drops an existing function alias.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+DROP ALIAS MY_SQRT
+"
+
+"Commands (DDL)","DROP ALL OBJECTS","
+DROP ALL OBJECTS [ DELETE FILES ]
+","
+Drops all existing views, tables, sequences, schemas, function aliases, roles,
+user-defined aggregate functions, domains, and users (except the current user).
+If DELETE FILES is specified, the database files will be removed when the last
+user disconnects from the database. Warning: this command can not be rolled
+back.
+
+Admin rights are required to execute this command.
+","
+DROP ALL OBJECTS
+"
+
+"Commands (DDL)","DROP CONSTANT","
+DROP CONSTANT [ IF EXISTS ] constantName
+","
+Drops a constant.
+This command commits an open transaction in this connection.
+","
+DROP CONSTANT ONE
+"
+
+"Commands (DDL)","DROP DOMAIN","
+DROP DOMAIN [ IF EXISTS ] domainName [ RESTRICT | CASCADE ]
+","
+Drops a data type (domain).
+The command will fail if it is referenced by a column (the default).
+Column descriptors are replaced with original definition of specified domain if the CASCADE clause is used.
+This command commits an open transaction in this connection.
+","
+DROP DOMAIN EMAIL
+"
+
+"Commands (DDL)","DROP INDEX","
+DROP INDEX [ IF EXISTS ] indexName
+","
+Drops an index.
+This command commits an open transaction in this connection.
+","
+DROP INDEX IF EXISTS IDXNAME
+"
+
+"Commands (DDL)","DROP ROLE","
+DROP ROLE [ IF EXISTS ] roleName
+","
+Drops a role.
+This command commits an open transaction in this connection.
+","
+DROP ROLE READONLY
+"
+
+"Commands (DDL)","DROP SCHEMA","
+DROP SCHEMA [ IF EXISTS ] schemaName [ RESTRICT | CASCADE ]
+","
+Drops a schema.
+The command will fail if objects in this schema exist and the RESTRICT clause is used (the default).
+All objects in this schema are dropped as well if the CASCADE clause is used.
+This command commits an open transaction in this connection.
+","
+DROP SCHEMA TEST_SCHEMA
+"
+
+"Commands (DDL)","DROP SEQUENCE","
+DROP SEQUENCE [ IF EXISTS ] sequenceName
+","
+Drops a sequence.
+This command commits an open transaction in this connection.
+","
+DROP SEQUENCE SEQ_ID
+"
+
+"Commands (DDL)","DROP TABLE","
+DROP TABLE [ IF EXISTS ] tableName [,...] [ RESTRICT | CASCADE ]
+","
+Drops an existing table, or a list of tables.
+The command will fail if dependent objects exist and the RESTRICT clause is used (the default).
+All dependent views and constraints are dropped as well if the CASCADE clause is used.
+This command commits an open transaction in this connection.
+","
+DROP TABLE TEST
+"
+
+"Commands (DDL)","DROP TRIGGER","
+DROP TRIGGER [ IF EXISTS ] triggerName
+","
+Drops an existing trigger.
+This command commits an open transaction in this connection.
+","
+DROP TRIGGER TRIG_INS
+"
+
+"Commands (DDL)","DROP USER","
+DROP USER [ IF EXISTS ] userName
+","
+Drops a user. The current user cannot be dropped.
+For compatibility, only unquoted or uppercase user names are allowed.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+DROP USER TOM
+"
+
+"Commands (DDL)","DROP VIEW","
+DROP VIEW [ IF EXISTS ] viewName [ RESTRICT | CASCADE ]
+","
+Drops an existing view.
+All dependent views are dropped as well if the CASCADE clause is used (the default).
+The command will fail if dependent views exist and the RESTRICT clause is used.
+This command commits an open transaction in this connection.
+","
+DROP VIEW TEST_VIEW
+"
+
+"Commands (DDL)","TRUNCATE TABLE","
+TRUNCATE TABLE tableName [ [ CONTINUE | RESTART ] IDENTITY ]
+","
+Removes all rows from a table.
+Unlike DELETE FROM without where clause, this command can not be rolled back.
+This command is faster than DELETE without where clause.
+Only regular data tables without foreign key constraints can be truncated
+(except if referential integrity is disabled for this database or for this table).
+Linked tables can't be truncated.
+If RESTART IDENTITY is specified next values for auto-incremented columns are restarted.
+
+This command commits an open transaction in this connection.
+","
+TRUNCATE TABLE TEST
+"
+
+"Commands (Other)","CHECKPOINT","
+CHECKPOINT
+","
+Flushes the data to disk.
+
+Admin rights are required to execute this command.
+","
+CHECKPOINT
+"
+
+"Commands (Other)","CHECKPOINT SYNC","
+CHECKPOINT SYNC
+","
+Flushes the data to disk and forces all system buffers be written
+to the underlying device.
+
+Admin rights are required to execute this command.
+","
+CHECKPOINT SYNC
+"
+
+"Commands (Other)","COMMIT","
+COMMIT [ WORK ]
+","
+Commits a transaction.
+","
+COMMIT
+"
+
+"Commands (Other)","COMMIT TRANSACTION","
+COMMIT TRANSACTION transactionName
+","
+Sets the resolution of an in-doubt transaction to 'commit'.
+
+Admin rights are required to execute this command.
+This command is part of the 2-phase-commit protocol.
+","
+COMMIT TRANSACTION XID_TEST
+"
+
+"Commands (Other)","GRANT RIGHT","
+GRANT { SELECT | INSERT | UPDATE | DELETE | ALL } [,...] ON
+{ { SCHEMA schemaName } | { tableName [,...] } }
+TO { PUBLIC | userName | roleName }
+","
+Grants rights for a table to a user or role.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+GRANT SELECT ON TEST TO READONLY
+"
+
+"Commands (Other)","GRANT ALTER ANY SCHEMA","
+GRANT ALTER ANY SCHEMA TO userName
+","
+Grant schema altering rights to a user.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+GRANT ALTER ANY SCHEMA TO Bob
+"
+
+"Commands (Other)","GRANT ROLE","
+GRANT roleName TO { PUBLIC | userName | roleName }
+","
+Grants a role to a user or role.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+GRANT READONLY TO PUBLIC
+"
+
+"Commands (Other)","HELP","
+HELP [ anything [...] ]
+","
+Displays the help pages of SQL commands or keywords.
+","
+HELP SELECT
+"
+
+"Commands (Other)","PREPARE COMMIT","
+PREPARE COMMIT newTransactionName
+","
+Prepares committing a transaction.
+This command is part of the 2-phase-commit protocol.
+","
+PREPARE COMMIT XID_TEST
+"
+
+"Commands (Other)","REVOKE RIGHT","
+REVOKE { SELECT | INSERT | UPDATE | DELETE | ALL } [,...] ON
+{ { SCHEMA schemaName } | { tableName [,...] } }
+FROM { PUBLIC | userName | roleName }
+","
+Removes rights for a table from a user or role.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+REVOKE SELECT ON TEST FROM READONLY
+"
+
+"Commands (Other)","REVOKE ROLE","
+REVOKE roleName FROM { PUBLIC | userName | roleName }
+","
+Removes a role from a user or role.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+REVOKE READONLY FROM TOM
+"
+
+"Commands (Other)","ROLLBACK","
+ROLLBACK [ TO SAVEPOINT savepointName ]
+","
+Rolls back a transaction. If a savepoint name is used, the transaction is only
+rolled back to the specified savepoint.
+","
+ROLLBACK
+"
+
+"Commands (Other)","ROLLBACK TRANSACTION","
+ROLLBACK TRANSACTION transactionName
+","
+Sets the resolution of an in-doubt transaction to 'rollback'.
+
+Admin rights are required to execute this command.
+This command is part of the 2-phase-commit protocol.
+","
+ROLLBACK TRANSACTION XID_TEST
+"
+
+"Commands (Other)","SAVEPOINT","
+SAVEPOINT savepointName
+","
+Create a new savepoint. See also ROLLBACK.
+Savepoints are only valid until the transaction is committed or rolled back.
+","
+SAVEPOINT HALF_DONE
+"
+
+"Commands (Other)","SET @","
+SET @variableName [ = ] expression
+","
+Updates a user-defined variable.
+Variables are not persisted and session scoped, that means only visible from within the session in which they are defined.
+This command does not commit a transaction, and rollback does not affect it.
+","
+SET @TOTAL=0
+"
+
+"Commands (Other)","SET ALLOW_LITERALS","
+SET ALLOW_LITERALS { NONE | ALL | NUMBERS }
+","
+This setting can help solve the SQL injection problem. By default, text and
+number literals are allowed in SQL statements. However, this enables SQL
+injection if the application dynamically builds SQL statements. SQL injection is
+not possible if user data is set using parameters ('?').
+
+NONE means literals of any kind are not allowed, only parameters and constants
+are allowed. NUMBERS mean only numerical and boolean literals are allowed. ALL
+means all literals are allowed (default).
+
+See also CREATE CONSTANT.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+This setting can be appended to the database URL: ""jdbc:h2:test;ALLOW_LITERALS=NONE""
+","
+SET ALLOW_LITERALS NONE
+"
+
+"Commands (Other)","SET AUTOCOMMIT","
+SET AUTOCOMMIT { TRUE | ON | FALSE | OFF }
+","
+Switches auto commit on or off.
+This setting can be appended to the database URL: ""jdbc:h2:test;AUTOCOMMIT=OFF"" -
+however this will not work as expected when using a connection pool
+(the connection pool manager will re-enable autocommit when returning
+the connection to the pool, so autocommit will only be disabled the first
+time the connection is used.
+","
+SET AUTOCOMMIT OFF
+"
+
+"Commands (Other)","SET CACHE_SIZE","
+SET CACHE_SIZE int
+","
+Sets the size of the cache in KB (each KB being 1024 bytes) for the current database.
+The default is 65536 per available GB of RAM, i.e. 64 MB per GB.
+The value is rounded to the next higher power of two.
+Depending on the virtual machine, the actual memory required may be higher.
+
+This setting is persistent and affects all connections as there is only one cache per database.
+Using a very small value (specially 0) will reduce performance a lot.
+This setting only affects the database engine (the server in a client/server environment;
+in embedded mode, the database engine is in the same process as the application).
+It has no effect for in-memory databases.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+This setting can be appended to the database URL: ""jdbc:h2:test;CACHE_SIZE=8192""
+","
+SET CACHE_SIZE 8192
+"
+
+"Commands (Other)","SET CLUSTER","
+SET CLUSTER serverListString
+","
+This command should not be used directly by an application, the statement is
+executed automatically by the system. The behavior may change in future
+releases. Sets the cluster server list. An empty string switches off the cluster
+mode. Switching on the cluster mode requires admin rights, but any user can
+switch it off (this is automatically done when the client detects the other
+server is not responding).
+
+This command is effective immediately, but does not commit an open transaction.
+","
+SET CLUSTER ''
+"
+
+"Commands (Other)","SET BINARY_COLLATION","
+SET BINARY_COLLATION { UNSIGNED | SIGNED }
+","
+Sets the collation used for comparing BINARY columns, the default is SIGNED
+for version 1.3 and older, and UNSIGNED for version 1.4 and newer.
+This command can only be executed if there are no tables defined.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+This setting is persistent.
+","
+SET BINARY_COLLATION SIGNED
+"
+
+"Commands (Other)","SET UUID_COLLATION","
+SET UUID_COLLATION { UNSIGNED | SIGNED }
+","
+Sets the collation used for comparing UUID columns, the default is SIGNED.
+This command can only be executed if there are no tables defined.
+
+SIGNED means signed comparison between first 64 bits of compared values treated as long values
+and if they are equal a signed comparison of the last 64 bits of compared values treated as long values.
+See also Java ""UUID.compareTo()"".
+UNSIGNED means RFC 4122 compatible unsigned comparison.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+This setting is persistent.
+","
+SET UUID_COLLATION UNSIGNED
+"
+
+"Commands (Other)","SET BUILTIN_ALIAS_OVERRIDE","
+SET BUILTIN_ALIAS_OVERRIDE { TRUE | FALSE }
+","
+Allows the overriding of the builtin system date/time functions
+for unit testing purposes.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+SET BUILTIN_ALIAS_OVERRIDE TRUE
+"
+
+"Commands (Other)","SET COLLATION","
+SET [ DATABASE ] COLLATION
+{ OFF | collationName
+    [ STRENGTH { PRIMARY | SECONDARY | TERTIARY | IDENTICAL } ] }
+","
+Sets the collation used for comparing strings.
+This command can only be executed if there are no tables defined.
+See ""java.text.Collator"" for details about the supported collations and the STRENGTH
+(PRIMARY is usually case- and umlaut-insensitive; SECONDARY is case-insensitive but umlaut-sensitive;
+TERTIARY is both case- and umlaut-sensitive; IDENTICAL is sensitive to all differences and only affects ordering).
+
+The ICU4J collator is used if it is in the classpath.
+It is also used if the collation name starts with ICU4J_
+(in that case, the ICU4J must be in the classpath, otherwise an exception is thrown).
+The default collator is used if the collation name starts with DEFAULT_
+(even if ICU4J is in the classpath).
+The charset collator is used if the collation name starts with CHARSET_ (e.g. CHARSET_CP500). This collator sorts
+strings according to the binary representation in the given charset.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+This setting is persistent.
+This setting can be appended to the database URL: ""jdbc:h2:test;COLLATION='ENGLISH'""
+","
+SET COLLATION ENGLISH
+SET COLLATION CHARSET_CP500
+"
+
+"Commands (Other)","SET COMPRESS_LOB","
+SET COMPRESS_LOB { NO | LZF | DEFLATE }
+","
+This feature is only available for the PageStore storage engine.
+For the MVStore engine (the default for H2 version 1.4.x),
+append "";COMPRESS=TRUE"" to the database URL instead.
+
+Sets the compression algorithm for BLOB and CLOB data. Compression is usually
+slower, but needs less disk space. LZF is faster but uses more space.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+","
+SET COMPRESS_LOB LZF
+"
+
+"Commands (Other)","SET DATABASE_EVENT_LISTENER","
+SET DATABASE_EVENT_LISTENER classNameString
+","
+Sets the event listener class. An empty string ('') means no listener should be
+used. This setting is not persistent.
+
+Admin rights are required to execute this command, except if it is set when
+opening the database (in this case it is reset just after opening the database).
+This setting can be appended to the database URL: ""jdbc:h2:test;DATABASE_EVENT_LISTENER='sample.MyListener'""
+","
+SET DATABASE_EVENT_LISTENER 'sample.MyListener'
+"
+
+"Commands (Other)","SET DB_CLOSE_DELAY","
+SET DB_CLOSE_DELAY int
+","
+Sets the delay for closing a database if all connections are closed.
+The value -1 means the database is never closed until the close delay is set to some other value or SHUTDOWN is called.
+The value 0 means no delay (default; the database is closed if the last connection to it is closed).
+Values 1 and larger mean the number of seconds the database is left open after closing the last connection.
+
+If the application exits normally or System.exit is called, the database is closed immediately, even if a delay is set.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+This setting can be appended to the database URL: ""jdbc:h2:test;DB_CLOSE_DELAY=-1""
+","
+SET DB_CLOSE_DELAY -1
+"
+
+"Commands (Other)","SET DEFAULT_LOCK_TIMEOUT","
+SET DEFAULT LOCK_TIMEOUT int
+","
+Sets the default lock timeout (in milliseconds) in this database that is used
+for the new sessions. The default value for this setting is 1000 (one second).
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+","
+SET DEFAULT_LOCK_TIMEOUT 5000
+"
+
+"Commands (Other)","SET DEFAULT_TABLE_TYPE","
+SET DEFAULT_TABLE_TYPE { MEMORY | CACHED }
+","
+Sets the default table storage type that is used when creating new tables.
+Memory tables are kept fully in the main memory (including indexes), however
+the data is still stored in the database file. The size of memory tables is
+limited by the memory. The default is CACHED.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+It has no effect for in-memory databases.
+","
+SET DEFAULT_TABLE_TYPE MEMORY
+"
+
+"Commands (Other)","SET EXCLUSIVE","
+SET EXCLUSIVE { 0 | 1 | 2 }
+","
+Switched the database to exclusive mode (1, 2) and back to normal mode (0).
+
+In exclusive mode, new connections are rejected, and operations by
+other connections are paused until the exclusive mode is disabled.
+When using the value 1, existing connections stay open.
+When using the value 2, all existing connections are closed
+(and current transactions are rolled back) except the connection
+that executes SET EXCLUSIVE.
+Only the connection that set the exclusive mode can disable it.
+When the connection is closed, it is automatically disabled.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+","
+SET EXCLUSIVE 1
+"
+
+"Commands (Other)","SET IGNORECASE","
+SET IGNORECASE { TRUE | FALSE }
+","
+If IGNORECASE is enabled, text columns in newly created tables will be
+case-insensitive. Already existing tables are not affected. The effect of
+case-insensitive columns is similar to using a collation with strength PRIMARY.
+Case-insensitive columns are compared faster than when using a collation.
+String literals and parameters are however still considered case sensitive even if this option is set.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+This setting can be appended to the database URL: ""jdbc:h2:test;IGNORECASE=TRUE""
+","
+SET IGNORECASE TRUE
+"
+
+"Commands (Other)","SET JAVA_OBJECT_SERIALIZER","
+SET JAVA_OBJECT_SERIALIZER
+{ null | className }
+","
+Sets the object used to serialize and deserialize java objects being stored in column of type OTHER.
+The serializer class must be public and implement ""org.h2.api.JavaObjectSerializer"".
+Inner classes are not supported.
+The class must be available in the classpath of the database engine
+(when using the server mode, it must be both in the classpath of the server and the client).
+This command can only be executed if there are no tables defined.
+
+Admin rights are required to execute this command.
+This command commits an open transaction in this connection.
+This setting is persistent.
+This setting can be appended to the database URL: ""jdbc:h2:test;JAVA_OBJECT_SERIALIZER='com.acme.SerializerClassName'""
+","
+SET JAVA_OBJECT_SERIALIZER 'com.acme.SerializerClassName'
+"
+
+"Commands (Other)","SET LAZY_QUERY_EXECUTION","
+SET LAZY_QUERY_EXECUTION int
+","
+Sets the lazy query execution mode. The values 0, 1 are supported.
+
+If true, then large results are retrieved in chunks.
+
+Note that not all queries support this feature, queries which do not are processed normally.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is not persistent.
+This setting can be appended to the database URL: ""jdbc:h2:test;LAZY_QUERY_EXECUTION=1""
+","
+SET LAZY_QUERY_EXECUTION 1
+"
+
+"Commands (Other)","SET LOG","
+SET LOG int
+","
+Sets the transaction log mode. The values 0, 1, and 2 are supported, the default is 2.
+This setting affects all connections.
+
+LOG 0 means the transaction log is disabled completely. It is the fastest mode,
+but also the most dangerous: if the process is killed while the database is open in this mode,
+the data might be lost. It must only be used if this is not a problem, for example when
+initially loading a database, or when running tests.
+
+LOG 1 means the transaction log is enabled, but FileDescriptor.sync is disabled.
+This setting is about half as fast as with LOG 0. This setting is useful if no protection
+against power failure is required, but the data must be protected against killing the process.
+
+LOG 2 (the default) means the transaction log is enabled, and FileDescriptor.sync is called
+for each checkpoint. This setting is about half as fast as LOG 1. Depending on the
+file system, this will also protect against power failure in the majority if cases.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is not persistent.
+This setting can be appended to the database URL: ""jdbc:h2:test;LOG=0""
+","
+SET LOG 1
+"
+
+"Commands (Other)","SET LOCK_MODE","
+SET LOCK_MODE int
+","
+Sets the lock mode. The values 0, 1, 2, and 3 are supported. The default is 3
+(READ_COMMITTED). This setting affects all connections.
+
+The value 0 means no locking (should only be used for testing; also known as
+READ_UNCOMMITTED). Please note that using SET LOCK_MODE 0 while at the same time
+using multiple connections may result in inconsistent transactions.
+
+The value 1 means table level locking (also known as SERIALIZABLE).
+
+The value 2 means table level locking with garbage collection (if the
+application does not close all connections).
+
+The value 3 means table level locking, but read locks are released immediately
+(default; also known as READ_COMMITTED).
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+This setting can be appended to the database URL: ""jdbc:h2:test;LOCK_MODE=3""
+","
+SET LOCK_MODE 1
+"
+
+"Commands (Other)","SET LOCK_TIMEOUT","
+SET LOCK_TIMEOUT int
+","
+Sets the lock timeout (in milliseconds) for the current session. The default
+value for this setting is 1000 (one second).
+
+This command does not commit a transaction, and rollback does not affect it.
+This setting can be appended to the database URL: ""jdbc:h2:test;LOCK_TIMEOUT=10000""
+","
+SET LOCK_TIMEOUT 1000
+"
+
+"Commands (Other)","SET MAX_LENGTH_INPLACE_LOB","
+SET MAX_LENGTH_INPLACE_LOB int
+","
+Sets the maximum size of an in-place LOB object.
+
+This is the maximum length of an LOB that is stored with the record itself,
+and the default value is 128.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+","
+SET MAX_LENGTH_INPLACE_LOB 128
+"
+
+"Commands (Other)","SET MAX_LOG_SIZE","
+SET MAX_LOG_SIZE int
+","
+Sets the maximum size of the transaction log, in megabytes.
+If the log is larger, and if there is no open transaction, the transaction log is truncated.
+If there is an open transaction, the transaction log will continue to grow however.
+The default max size is 16 MB.
+This setting has no effect for in-memory databases.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+","
+SET MAX_LOG_SIZE 2
+"
+
+"Commands (Other)","SET MAX_MEMORY_ROWS","
+SET MAX_MEMORY_ROWS int
+","
+The maximum number of rows in a result set that are kept in-memory. If more rows
+are read, then the rows are buffered to disk.
+The default is 40000 per GB of available RAM.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+It has no effect for in-memory databases.
+","
+SET MAX_MEMORY_ROWS 1000
+"
+
+"Commands (Other)","SET MAX_MEMORY_UNDO","
+SET MAX_MEMORY_UNDO int
+","
+The maximum number of undo records per a session that are kept in-memory.
+If a transaction is larger, the records are buffered to disk.
+The default value is 50000.
+Changes to tables without a primary key can not be buffered to disk.
+This setting is not supported when using multi-version concurrency.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+It has no effect for in-memory databases.
+","
+SET MAX_MEMORY_UNDO 1000
+"
+
+"Commands (Other)","SET MAX_OPERATION_MEMORY","
+SET MAX_OPERATION_MEMORY int
+","
+Sets the maximum memory used for large operations (delete and insert), in bytes.
+Operations that use more memory are buffered to disk, slowing down the
+operation. The default max size is 100000. 0 means no limit.
+
+This setting is not persistent.
+Admin rights are required to execute this command, as it affects all connections.
+It has no effect for in-memory databases.
+This setting can be appended to the database URL: ""jdbc:h2:test;MAX_OPERATION_MEMORY=10000""
+","
+SET MAX_OPERATION_MEMORY 0
+"
+
+"Commands (Other)","SET MODE","
+SET MODE { REGULAR | DB2 | DERBY | HSQLDB | MSSQLSERVER | MYSQL | ORACLE | POSTGRESQL }
+","
+Changes to another database compatibility mode. For details, see Compatibility
+Modes in the feature section.
+
+This setting is not persistent.
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting can be appended to the database URL: ""jdbc:h2:test;MODE=MYSQL""
+","
+SET MODE HSQLDB
+"
+
+"Commands (Other)","SET MULTI_THREADED","
+SET MULTI_THREADED { 0 | 1 }
+","
+Enabled (1) or disabled (0) multi-threading inside the database engine.
+MULTI_THREADED is enabled by default with default MVStore storage engine.
+MULTI_THREADED is disabled by default when using PageStore storage engine, enabling this with PageStore is experimental only.
+
+This is a global setting, which means it is not possible to open multiple databases with different modes at the same time in the same virtual machine.
+This setting is not persistent, however the value is kept until the virtual machine exits or it is changed.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting can be appended to the database URL: ""jdbc:h2:test;MULTI_THREADED=1""
+","
+SET MULTI_THREADED 1
+"
+
+"Commands (Other)","SET OPTIMIZE_REUSE_RESULTS","
+SET OPTIMIZE_REUSE_RESULTS { 0 | 1 }
+","
+Enabled (1) or disabled (0) the result reuse optimization. If enabled,
+subqueries and views used as subqueries are only re-run if the data in one of
+the tables was changed. This option is enabled by default.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting can be appended to the database URL: ""jdbc:h2:test;OPTIMIZE_REUSE_RESULTS=0""
+","
+SET OPTIMIZE_REUSE_RESULTS 0
+"
+
+"Commands (Other)","SET PASSWORD","
+SET PASSWORD string
+","
+Changes the password of the current user. The password must be in single quotes.
+It is case sensitive and can contain spaces.
+
+This command commits an open transaction in this connection.
+","
+SET PASSWORD 'abcstzri!.5'
+"
+
+"Commands (Other)","SET QUERY_STATISTICS","
+SET QUERY_STATISTICS { TRUE | FALSE }
+","
+Disabled or enables query statistics gathering for the whole database.
+The statistics are reflected in the INFORMATION_SCHEMA.QUERY_STATISTICS meta-table.
+
+This setting is not persistent.
+This command commits an open transaction in this connection.
+Admin rights are required to execute this command, as it affects all connections.
+","
+SET QUERY_STATISTICS FALSE
+"
+
+"Commands (Other)","SET QUERY_STATISTICS_MAX_ENTRIES","
+SET QUERY_STATISTICS int
+","
+Set the maximum number of entries in query statistics meta-table.
+Default value is 100.
+
+This setting is not persistent.
+This command commits an open transaction in this connection.
+Admin rights are required to execute this command, as it affects all connections.
+","
+SET QUERY_STATISTICS_MAX_ENTRIES 500
+"
+
+"Commands (Other)","SET QUERY_TIMEOUT","
+SET QUERY_TIMEOUT int
+","
+Set the query timeout of the current session to the given value. The timeout is
+in milliseconds. All kinds of statements will throw an exception if they take
+longer than the given value. The default timeout is 0, meaning no timeout.
+
+This command does not commit a transaction, and rollback does not affect it.
+","
+SET QUERY_TIMEOUT 10000
+"
+
+"Commands (Other)","SET REFERENTIAL_INTEGRITY","
+SET REFERENTIAL_INTEGRITY { TRUE | FALSE }
+","
+Disabled or enables referential integrity checking for the whole database.
+Enabling it does not check existing data. Use ALTER TABLE SET to disable it only
+for one table.
+
+This setting is not persistent.
+This command commits an open transaction in this connection.
+Admin rights are required to execute this command, as it affects all connections.
+","
+SET REFERENTIAL_INTEGRITY FALSE
+"
+
+"Commands (Other)","SET RETENTION_TIME","
+SET RETENTION_TIME int
+","
+This property is only used when using the MVStore storage engine.
+How long to retain old, persisted data, in milliseconds.
+The default is 45000 (45 seconds), 0 means overwrite data as early as possible.
+It is assumed that a file system and hard disk will flush all write buffers within this time.
+Using a lower value might be dangerous, unless the file system and hard disk flush the buffers earlier.
+To manually flush the buffers, use CHECKPOINT SYNC,
+however please note that according to various tests this does not always work as expected
+depending on the operating system and hardware.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting is persistent.
+This setting can be appended to the database URL: ""jdbc:h2:test;RETENTION_TIME=0""
+","
+SET RETENTION_TIME 0
+"
+
+"Commands (Other)","SET SALT HASH","
+SET SALT bytes HASH bytes
+","
+Sets the password salt and hash for the current user. The password must be in
+single quotes. It is case sensitive and can contain spaces.
+
+This command commits an open transaction in this connection.
+","
+SET SALT '00' HASH '1122'
+"
+
+"Commands (Other)","SET SCHEMA","
+SET SCHEMA schemaName
+","
+Changes the default schema of the current connection. The default schema is used
+in statements where no schema is set explicitly. The default schema for new
+connections is PUBLIC.
+
+This command does not commit a transaction, and rollback does not affect it.
+This setting can be appended to the database URL: ""jdbc:h2:test;SCHEMA=ABC""
+","
+SET SCHEMA INFORMATION_SCHEMA
+"
+
+"Commands (Other)","SET SCHEMA_SEARCH_PATH","
+SET SCHEMA_SEARCH_PATH schemaName [,...]
+","
+Changes the schema search path of the current connection. The default schema is
+used in statements where no schema is set explicitly. The default schema for new
+connections is PUBLIC.
+
+This command does not commit a transaction, and rollback does not affect it.
+This setting can be appended to the database URL: ""jdbc:h2:test;SCHEMA_SEARCH_PATH=ABC,DEF""
+","
+SET SCHEMA_SEARCH_PATH INFORMATION_SCHEMA, PUBLIC
+"
+
+"Commands (Other)","SET THROTTLE","
+SET THROTTLE int
+","
+Sets the throttle for the current connection. The value is the number of
+milliseconds delay after each 50 ms. The default value is 0 (throttling
+disabled).
+
+This command does not commit a transaction, and rollback does not affect it.
+This setting can be appended to the database URL: ""jdbc:h2:test;THROTTLE=50""
+","
+SET THROTTLE 200
+"
+
+"Commands (Other)","SET TRACE_LEVEL","
+SET { TRACE_LEVEL_FILE | TRACE_LEVEL_SYSTEM_OUT } int
+","
+Sets the trace level for file the file or system out stream. Levels are: 0=off,
+1=error, 2=info, 3=debug. The default level is 1 for file and 0 for system out.
+To use SLF4J, append "";TRACE_LEVEL_FILE=4"" to the database URL when opening the database.
+
+This setting is not persistent.
+Admin rights are required to execute this command, as it affects all connections.
+This command does not commit a transaction, and rollback does not affect it.
+This setting can be appended to the database URL: ""jdbc:h2:test;TRACE_LEVEL_SYSTEM_OUT=3""
+","
+SET TRACE_LEVEL_SYSTEM_OUT 3
+"
+
+"Commands (Other)","SET TRACE_MAX_FILE_SIZE","
+SET TRACE_MAX_FILE_SIZE int
+","
+Sets the maximum trace file size. If the file exceeds the limit, the file is
+renamed to .old and a new file is created. If another .old file exists, it is
+deleted. The default max size is 16 MB.
+
+This setting is persistent.
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting can be appended to the database URL: ""jdbc:h2:test;TRACE_MAX_FILE_SIZE=3""
+","
+SET TRACE_MAX_FILE_SIZE 10
+"
+
+"Commands (Other)","SET UNDO_LOG","
+SET UNDO_LOG int
+","
+Enables (1) or disables (0) the per session undo log. The undo log is enabled by
+default. When disabled, transactions can not be rolled back. This setting should
+only be used for bulk operations that don't need to be atomic.
+
+This command commits an open transaction in this connection.
+","
+SET UNDO_LOG 0
+"
+
+"Commands (Other)","SET WRITE_DELAY","
+SET WRITE_DELAY int
+","
+Set the maximum delay between a commit and flushing the log, in milliseconds.
+This setting is persistent. The default is 500 ms.
+
+Admin rights are required to execute this command, as it affects all connections.
+This command commits an open transaction in this connection.
+This setting can be appended to the database URL: ""jdbc:h2:test;WRITE_DELAY=0""
+","
+SET WRITE_DELAY 2000
+"
+
+"Commands (Other)","SHUTDOWN","
+SHUTDOWN [ IMMEDIATELY | COMPACT | DEFRAG ]
+","
+This statement closes all open connections to the database and closes the
+database. This command is usually not required, as the database is
+closed automatically when the last connection to it is closed.
+
+If no option is used, then the database is closed normally.
+All connections are closed, open transactions are rolled back.
+
+SHUTDOWN COMPACT fully compacts the database (re-creating the database may further reduce the database size).
+If the database is closed normally (using SHUTDOWN or by closing all connections), then the database is also compacted,
+but only for at most the time defined by the database setting ""h2.maxCompactTime"" in milliseconds (see there).
+
+SHUTDOWN IMMEDIATELY closes the database files without any cleanup and without compacting.
+
+SHUTDOWN DEFRAG re-orders the pages when closing the database so that table scans are faster. In case of MVStore it is currently equivalent to COMPACT.
+
+Admin rights are required to execute this command.
+","
+SHUTDOWN COMPACT
+"
+
+"Literals","Value","
+string | dollarQuotedString | numeric | dateAndTime | boolean | bytes
+    | interval | array | null
+","
+A literal value of any data type, or null.
+","
+10
+"
+
+"Literals","Array","
+ARRAY '[' [ expression, [,...] ] ']'
+","
+An array of values.
+","
+ARRAY[1, 2]
+ARRAY[1]
+ARRAY[]
+"
+
+"Literals","Boolean","
+TRUE | FALSE
+","
+A boolean value.
+","
+TRUE
+"
+
+"Literals","Bytes","
+X'hex'
+","
+A binary value. The hex value is not case sensitive.
+","
+X'01FF'
+"
+
+"Literals","Date","
+DATE 'yyyy-MM-dd'
+","
+A date literal. The limitations are the same as for the Java data type
+""java.sql.Date"", but for compatibility with other databases the suggested minimum
+and maximum years are 0001 and 9999.
+","
+DATE '2004-12-31'
+"
+
+"Literals","Date and time","
+date | time | timestamp | timestampWithTimeZone
+","
+A literal value of any date-time data type.
+","
+TIMESTAMP '1999-01-31 10:00:00'
+"
+
+"Literals","Decimal","
+[ + | - ] { { number [ . number ] } | { . number } }
+[ E [ + | - ] expNumber [...] ] ]
+","
+A decimal number with fixed precision and scale.
+Internally, ""java.lang.BigDecimal"" is used.
+To ensure the floating point representation is used, use CAST(X AS DOUBLE).
+There are some special decimal values: to represent positive infinity, use ""POWER(0, -1)"";
+for negative infinity, use ""(-POWER(0, -1))""; for -0.0, use ""(-CAST(0 AS DOUBLE))"";
+for ""NaN"" (not a number), use ""SQRT(-1)"".
+","
+SELECT -1600.05
+SELECT CAST(0 AS DOUBLE)
+SELECT -1.4e-10
+"
+
+"Literals","Dollar Quoted String","
+$$anythingExceptTwoDollarSigns$$
+","
+A string starts and ends with two dollar signs. Two dollar signs are not allowed
+within the text. A whitespace is required before the first set of dollar signs.
+No escaping is required within the text.
+","
+$$John's car$$
+"
+
+"Literals","Hex Number","
+[ + | - ] 0x hex
+","
+A number written in hexadecimal notation.
+","
+0xff
+"
+
+"Literals","Int","
+[ + | - ] number
+","
+The maximum integer number is 2147483647, the minimum is -2147483648.
+","
+10
+"
+
+"Literals","Long","
+[ + | - ] number
+","
+Long numbers are between -9223372036854775808 and 9223372036854775807.
+","
+100000
+"
+
+"Literals","Null","
+NULL
+","
+NULL is a value without data type and means 'unknown value'.
+","
+NULL
+"
+
+"Literals","Number","
+digit [...]
+","
+The maximum length of the number depends on the data type used.
+","
+100
+"
+
+"Literals","Numeric","
+decimal | int | long | hexNumber
+","
+The data type of a numeric value is always the lowest possible for the given value.
+If the number contains a dot this is decimal; otherwise it is int, long, or decimal (depending on the value).
+","
+SELECT -1600.05
+SELECT CAST(0 AS DOUBLE)
+SELECT -1.4e-10
+"
+
+"Literals","String","
+'anythingExceptSingleQuote'
+","
+A string starts and ends with a single quote. Two single quotes can be used to
+create a single quote inside a string.
+","
+'John''s car'
+"
+
+"Literals","Time","
+TIME [ WITHOUT TIME ZONE ] 'hh:mm:ss[.nnnnnnnnn]'
+","
+A time literal. A value is between 0:00:00 and 23:59:59.999999999
+and has nanosecond resolution.
+","
+TIME '23:59:59'
+"
+
+"Literals","Timestamp","
+TIMESTAMP [ WITHOUT TIME ZONE ] 'yyyy-MM-dd hh:mm:ss[.nnnnnnnnn]'
+","
+A timestamp literal. The limitations are the same as for the Java data type
+""java.sql.Timestamp"", but for compatibility with other databases the suggested
+minimum and maximum years are 0001 and 9999.
+","
+TIMESTAMP '2005-12-31 23:59:59'
+"
+
+"Literals","Timestamp with time zone","
+TIMESTAMP WITH TIME ZONE 'yyyy-MM-dd hh:mm:ss[.nnnnnnnnn]
+[Z | { - | + } timeZoneOffsetString | timeZoneNameString ]'
+","
+A timestamp with time zone literal.
+If name of time zone is specified it will be converted to time zone offset.
+","
+TIMESTAMP WITH TIME ZONE '2005-12-31 23:59:59Z'
+TIMESTAMP WITH TIME ZONE '2005-12-31 23:59:59-10:00'
+TIMESTAMP WITH TIME ZONE '2005-12-31 23:59:59.123+05'
+TIMESTAMP WITH TIME ZONE '2005-12-31 23:59:59.123456789 Europe/London'
+"
+
+"Literals","Interval","
+intervalYear | intervalMonth | intervalDay | intervalHour | intervalMinute
+    | intervalSecond | intervalYearToMonth | intervalDayToHour
+    | intervalDayToMinute | intervalDayToSecond | intervalHourToMinute
+    | intervalHourToSecond | intervalMinuteToSecond
+","
+An interval literal.
+","
+INTERVAL '1-2' YEAR TO MONTH
+"
+
+"Literals","INTERVAL YEAR","
+INTERVAL [-|+] '[-|+]yearInt' YEAR
+","
+An INTERVAL YEAR literal.
+","
+INTERVAL '10' YEAR
+"
+
+"Literals","INTERVAL MONTH","
+INTERVAL [-|+] '[-|+]monthInt' MONTH
+","
+An INTERVAL MONTH literal.
+","
+INTERVAL '10' MONTH
+"
+
+"Literals","INTERVAL DAY","
+INTERVAL [-|+] '[-|+]dayInt' DAY
+","
+An INTERVAL DAY literal.
+","
+INTERVAL '10' DAY
+"
+
+"Literals","INTERVAL HOUR","
+INTERVAL [-|+] '[-|+]hourInt' HOUR
+","
+An INTERVAL HOUR literal.
+","
+INTERVAL '10' HOUR
+"
+
+"Literals","INTERVAL MINUTE","
+INTERVAL [-|+] '[-|+]minuteInt' MINUTE
+","
+An INTERVAL MINUTE literal.
+","
+INTERVAL '10' MINUTE
+"
+
+"Literals","INTERVAL SECOND","
+INTERVAL [-|+] '[-|+]secondInt[.nnnnnnnnn]' SECOND
+","
+An INTERVAL SECOND literal.
+","
+INTERVAL '10.123' SECOND
+"
+
+"Literals","INTERVAL YEAR TO MONTH","
+INTERVAL [-|+] '[-|+]yearInt-monthInt' YEAR TO MONTH
+","
+An INTERVAL YEAR TO MONTH literal.
+","
+INTERVAL '1-6' YEAR TO MONTH
+"
+
+"Literals","INTERVAL DAY TO HOUR","
+INTERVAL [-|+] '[-|+]dayInt hoursInt' DAY TO HOUR
+","
+An INTERVAL DAY TO HOUR literal.
+","
+INTERVAL '10 11' DAY TO HOUR
+"
+
+"Literals","INTERVAL DAY TO MINUTE","
+INTERVAL [-|+] '[-|+]dayInt hh:mm' DAY TO MINUTE
+","
+An INTERVAL DAY TO MINUTE literal.
+","
+INTERVAL '10 11:12' DAY TO MINUTE
+"
+
+"Literals","INTERVAL DAY TO SECOND","
+INTERVAL [-|+] '[-|+]dayInt hh:mm:ss[.nnnnnnnnn]' DAY TO SECOND
+","
+An INTERVAL DAY TO SECOND literal.
+","
+INTERVAL '10 11:12:13.123' DAY TO SECOND
+"
+
+"Literals","INTERVAL HOUR TO MINUTE","
+INTERVAL [-|+] '[-|+]hh:mm' HOUR TO MINUTE
+","
+An INTERVAL HOUR TO MINUTE literal.
+","
+INTERVAL '10:11' HOUR TO MINUTE
+"
+
+"Literals","INTERVAL HOUR TO SECOND","
+INTERVAL [-|+] '[-|+]hh:mm:ss[.nnnnnnnnn]' HOUR TO SECOND
+","
+An INTERVAL HOUR TO SECOND literal.
+","
+INTERVAL '10:11:12.123' HOUR TO SECOND
+"
+
+"Literals","INTERVAL MINUTE TO SECOND","
+INTERVAL [-|+] '[-|+]mm:ss[.nnnnnnnnn]' MINUTE TO SECOND
+","
+An INTERVAL MINUTE TO SECOND literal.
+","
+INTERVAL '11:12.123' MINUTE TO SECOND
+"
+
+"Datetime fields","Datetime field","
+yearField | monthField | dayOfMonthField
+    | hourField | minuteField | secondField
+    | millisecondField | microsecondField | nanosecondField
+    | timezoneHourField | timezoneMinuteField
+    | dayOfWeekField | isoWeekYearField | isoDayOfWeekField
+    | weekOfYearField | isoWeekOfYearField
+    | quarterField | dayOfYearField | epochField
+","
+Fields for EXTRACT, DATEADD, and DATEDIFF functions.
+","
+YEAR
+"
+
+"Datetime fields","Year field","
+YEAR | YYYY | YY | SQL_TSI_YEAR
+","
+Year.
+","
+YEAR
+"
+
+"Datetime fields","Month field","
+MONTH | MM | M | SQL_TSI_MONTH
+","
+Month (1-12).
+","
+MONTH
+"
+
+"Datetime fields","Day of month field","
+DAY | DD | D | SQL_TSI_DAY
+","
+Day of month (1-31).
+","
+DAY
+"
+
+"Datetime fields","Hour field","
+HOUR | HH | SQL_TSI_HOUR
+","
+Hour (0-23).
+","
+HOUR
+"
+
+"Datetime fields","Minute field","
+MINUTE | MI | N | SQL_TSI_MINUTE
+","
+Minute (0-59).
+","
+MINUTE
+"
+
+"Datetime fields","Second field","
+SECOND | SS | S | SQL_TSI_SECOND
+","
+Second (0-59).
+","
+SECOND
+"
+
+"Datetime fields","Millisecond field","
+MILLISECOND | MS
+","
+Millisecond (0-999).
+","
+MILLISECOND
+"
+
+"Datetime fields","Microsecond field","
+MICROSECOND | MCS
+","
+Microsecond (0-999999).
+","
+MICROSECOND
+"
+
+"Datetime fields","Nanosecond field","
+NANOSECOND | NS
+","
+Nanosecond (0-999999999).
+","
+NANOSECOND
+"
+
+"Datetime fields","Timezone hour field","
+TIMEZONE_HOUR
+","
+Timezone hour (from -18 to +18).
+","
+TIMEZONE_HOUR
+"
+
+"Datetime fields","Timezone minute field","
+TIMEZONE_MINUTE
+","
+Timezone minute (from -59 to +59).
+","
+TIMEZONE_MINUTE
+"
+
+"Datetime fields","Day of week field","
+DAY_OF_WEEK | DAYOFWEEK | DOW
+","
+Day of week (1-7). Sunday is 1.
+","
+DAY_OF_WEEK
+"
+
+"Datetime fields","ISO week year field","
+ISO_YEAR | ISOYEAR
+","
+Returns the ISO week year from a date/time value.
+","
+ISO_YEAR
+"
+
+"Datetime fields","ISO day of week field","
+ISO_DAY_OF_WEEK | ISODOW
+","
+ISO day of week (1-7). Monday is 1.
+","
+ISO_DAY_OF_WEEK
+"
+
+"Datetime fields","Week of year field","
+WEEK | WW | W | SQL_TSI_WEEK
+","
+Week of year (1-53).
+EXTRACT function uses local rules to get number of week in year.
+DATEDIFF function uses Sunday as a first day of week.
+","
+WEEK
+"
+
+"Datetime fields","ISO week of year field","
+ISO_WEEK
+","
+ISO week of year (1-53).
+ISO definition is used when first week of year should have at least four days
+and week is started with Monday.
+","
+ISO_WEEK
+"
+
+"Datetime fields","Quarter field","
+QUARTER
+","
+Quarter (1-4).
+","
+QUARTER
+"
+
+"Datetime fields","Day of year field","
+DAYOFYEAR | DAY_OF_YEAR | DOY | DY
+","
+Day of year (1-366).
+","
+DAYOFYEAR
+"
+
+"Datetime fields","Epoch field","
+EPOCH
+","
+For TIMESTAMP values number of seconds since 1970-01-01 00:00:00 in local time zone.
+For TIMESTAMP WITH TIME ZONE values number of seconds since 1970-01-01 00:00:00 in UTC time zone.
+For DATE values number of seconds since 1970-01-01.
+For TIME values number of seconds since midnight.
+","
+EPOCH
+"
+
+"Other Grammar","Alias","
+name
+","
+An alias is a name that is only valid in the context of the statement.
+","
+A
+"
+
+"Other Grammar","And Condition","
+condition [ { AND condition } [...] ]
+","
+Value or condition.
+","
+ID=1 AND NAME='Hi'
+"
+
+"Other Grammar","Case","
+CASE expression { WHEN expression THEN expression } [...]
+[ ELSE expression ] END
+","
+Returns the first expression where the value is equal to the test expression. If
+no else part is specified, return NULL.
+","
+CASE CNT WHEN 0 THEN 'No' WHEN 1 THEN 'One' ELSE 'Some' END
+"
+
+"Other Grammar","Case When","
+CASE { WHEN expression THEN expression} [...]
+[ ELSE expression ] END
+","
+Returns the first expression where the condition is true. If no else part is
+specified, return NULL.
+","
+CASE WHEN CNT<10 THEN 'Low' ELSE 'High' END
+"
+
+"Other Grammar","Cipher","
+AES
+","
+Only the algorithm AES (""AES-128"") is supported currently.
+","
+AES
+"
+
+"Other Grammar","Column Definition","
+dataType [ VISIBLE | INVISIBLE ]
+[ { DEFAULT expression
+    | AS computedColumnExpression
+    | GENERATED {ALWAYS | BY DEFAULT} AS IDENTITY [(sequenceOptions)]} ]
+[ ON UPDATE expression ] [ [ NOT ] NULL ]
+[ { AUTO_INCREMENT | IDENTITY } [ ( startInt [, incrementInt ] ) ] ]
+[ SELECTIVITY selectivity ] [ COMMENT expression ]
+[ PRIMARY KEY [ HASH ] | UNIQUE ] [ CHECK condition ]
+","
+Default expressions are used if no explicit value was used when adding a row.
+The computed column expression is evaluated and assigned whenever the row changes.
+On update column expression is used if row is updated,
+at least one column have a new value that is different from its previous value
+and value for this column is not set explicitly in update statement.
+
+Identity, auto-increment, or generated as identity columns are columns with a sequence as the default.
+The column declared as the identity columns with IDENTITY data type or with IDENTITY () clause
+is implicitly the primary key column of this table.
+AUTO_INCREMENT and GENERATED clauses do not create the primary key constraint.
+GENERATED ALWAYS is accepted by treated in the same way as GENERATED BY DEFAULT.
+
+The invisible column will not be displayed as a result of SELECT * query.
+Otherwise, it works as normal column.
+
+The options PRIMARY KEY, UNIQUE, and CHECK are not supported for ALTER statements.
+
+Check constraints can reference columns of the table,
+and they can reference objects that exist while the statement is executed.
+Conditions are only checked when a row is added or modified
+in the table where the constraint exists.
+
+","
+CREATE TABLE TEST(ID INT PRIMARY KEY, NAME VARCHAR(255) DEFAULT '');
+CREATE TABLE TEST(ID BIGINT IDENTITY);
+CREATE TABLE TEST(QUANTITY INT, PRICE DECIMAL, AMOUNT DECIMAL AS QUANTITY*PRICE);
+"
+
+"Other Grammar","Comments","
+-- anythingUntilEndOfLine | // anythingUntilEndOfLine | /* anythingUntilEndComment */
+","
+Comments can be used anywhere in a command and are ignored by the database. Line
+comments end with a newline. Block comments cannot be nested, but can be
+multiple lines long.
+","
+// This is a comment
+"
+
+"Other Grammar","Compare","
+<> | <= | >= | = | < | > | != | &&
+","
+Comparison operator. The operator != is the same as <>.
+The operator ""&&"" means overlapping; it can only be used with geometry types.
+","
+<>
+"
+
+"Other Grammar","Condition","
+operand [ conditionRightHandSide ] | NOT condition | EXISTS ( select )
+","
+Boolean value or condition.
+","
+ID<>2
+"
+
+"Other Grammar","Condition Right Hand Side","
+compare { { { ALL | ANY | SOME } ( select ) } | operand }
+    | IS [ NOT ] NULL
+    | IS [ NOT ] [ DISTINCT FROM ] operand
+    | BETWEEN operand AND operand
+    | IN ( { select | expression [,...] } )
+    | [ NOT ] [ LIKE | ILIKE ] operand [ ESCAPE string ]
+    | [ NOT ] REGEXP operand
+","
+The right hand side of a condition.
+
+Quantified comparison predicate ALL returns TRUE if specified comparison operation between
+left size of condition and each row from a subquery returns TRUE, including case when there are no rows.
+ALL predicate returns FALSE if at least one such comparison returns FALSE.
+Otherwise it returns NULL.
+
+Quantified comparison predicates ANY and SOME return TRUE if specified comparison operation between
+left size of condition and at least one row from a subquery returns TRUE.
+ANY and SOME predicates return FALSE if all such comparisons return FALSE.
+Otherwise it returns NULL.
+Note that these predicates have priority over ANY and SOME aggregate functions with subquery on the right side.
+Use parentheses around aggregate function.
+
+The conditions ""IS [ NOT ]"" and ""IS [ NOT ] DISTINCT FROM"" are null-safe, meaning
+NULL is considered the same as NULL, and the condition never evaluates to NULL.
+
+When comparing with LIKE, the wildcards characters are ""_"" (any one character)
+and ""%"" (any characters). The database uses an index when comparing with LIKE
+except if the operand starts with a wildcard. To search for the characters ""%"" and
+""_"", the characters need to be escaped. The default escape character is "" \ "" (backslash).
+To select no escape character, use ""ESCAPE ''"" (empty string).
+At most one escape character is allowed.
+Each character that follows the escape character in the pattern needs to match exactly.
+Patterns that end with an escape character are invalid and the expression returns NULL.
+
+ILIKE does a case-insensitive compare.
+
+When comparing with REGEXP, regular expression matching is used.
+See Java ""Matcher.find"" for details.
+","
+VALUE > 10
+A IS NOT DISTINCT FROM B
+LIKE 'Jo%'
+"
+
+"Other Grammar","Constraint","
+[ constraintNameDefinition ]
+{ CHECK expression
+    | UNIQUE ( columnName [,...] )
+    | referentialConstraint
+    | PRIMARY KEY [ HASH ] ( columnName [,...] ) }
+","
+Defines a constraint.
+The check condition must evaluate to TRUE, FALSE or NULL.
+TRUE and NULL mean the operation is to be permitted,
+and FALSE means the operation is to be rejected.
+To prevent NULL in a column, use NOT NULL instead of a check constraint.
+","
+PRIMARY KEY(ID, NAME)
+"
+
+"Other Grammar","Constraint Name Definition","
+CONSTRAINT [ IF NOT EXISTS ] newConstraintName
+","
+Defines a constraint name.
+","
+CONSTRAINT CONST_ID
+"
+
+"Other Grammar","Csv Options","
+charsetString [, fieldSepString [, fieldDelimString [, escString [, nullString]]]]]
+    | optionString
+","
+Optional parameters for CSVREAD and CSVWRITE.
+Instead of setting the options one by one, all options can be
+combined into a space separated key-value pairs, as follows:
+""STRINGDECODE('charset=UTF-8 escape=\"" fieldDelimiter=\"" fieldSeparator=, ' ||""
+""'lineComment=# lineSeparator=\n null= rowSeparator=')"".
+The following options are supported:
+
+""caseSensitiveColumnNames"" (true or false; disabled by default),
+
+""charset"" (for example 'UTF-8'),
+
+""escape"" (the character that escapes the field delimiter),
+
+""fieldDelimiter"" (a double quote by default),
+
+""fieldSeparator"" (a comma by default),
+
+""lineComment"" (disabled by default),
+
+""lineSeparator"" (the line separator used for writing; ignored for reading),
+
+""null"", Support reading existing CSV files that contain explicit ""null"" delimiters.
+Note that an empty, unquoted values are also treated as null.
+
+""preserveWhitespace"" (true or false; disabled by default),
+
+""writeColumnHeader"" (true or false; enabled by default).
+
+For a newline or other special character, use STRINGDECODE as in the example above.
+A space needs to be escaped with a backslash (""'\ '""), and
+a backslash needs to be escaped with another backslash (""'\\'"").
+All other characters are not to be escaped, that means
+newline and tab characters are written as such.
+","
+CALL CSVWRITE('test2.csv', 'SELECT * FROM TEST', 'charset=UTF-8 fieldSeparator=|');
+"
+
+"Other Grammar","Data Type","
+intType | booleanType | tinyintType | smallintType | bigintType | identityType
+    | decimalType | doubleType | realType | dateType | timeType | timestampType
+    | timestampWithTimeZoneType | binaryType | otherType | varcharType
+    | varcharIgnorecaseType | charType | blobType | clobType | uuidType
+    | arrayType | enumType | intervalType
+","
+A data type definition.
+","
+INT
+"
+
+"Other Grammar","Digit","
+0-9
+","
+A digit.
+","
+0
+"
+
+"Other Grammar","Expression","
+andCondition [ { OR andCondition } [...] ]
+","
+Value or condition.
+","
+ID=1 OR NAME='Hi'
+"
+
+"Other Grammar","Factor","
+term [ { { * | / | % } term } [...] ]
+","
+A value or a numeric factor.
+","
+ID * 10
+"
+
+"Other Grammar","Hex","
+{ { digit | a-f | A-F } { digit | a-f | A-F } } [...]
+","
+The hexadecimal representation of a number or of bytes. Two characters are one
+byte.
+","
+cafe
+"
+
+"Other Grammar","Index Column","
+columnName [ ASC | DESC ] [ NULLS { FIRST | LAST } ]
+","
+Indexes this column in ascending or descending order. Usually it is not required
+to specify the order; however doing so will speed up large queries that order
+the column in the same way.
+","
+NAME
+"
+
+"Other Grammar","Insert columns and source","
+{ [ ( columnName [,...] ) ]
+    { insertValues | [ DIRECT ] [ SORTED ] select | DEFAULT VALUES } }
+    | { SET { columnName = { DEFAULT | expression } } [,...] }
+","
+Names of columns and their values for INSERT statement.
+","
+(ID, NAME) VALUES (1, 'Test')
+"
+
+"Other Grammar","Insert values","
+VALUES { DEFAULT|expression | [ROW] ({DEFAULT|expression} [,...]) }, [,...]
+","
+Values for INSERT statement.
+","
+VALUES (1, 'Test')
+"
+
+"Other Grammar","Merge when clause","
+mergeWhenMatchedClause|mergeWhenNotMatchedClause
+","
+WHEN MATCHED or WHEN NOT MATCHED clause for MERGE USING command.
+","
+WHEN MATCHED THEN DELETE
+"
+
+"Other Grammar","Merge when matched clause","
+WHEN MATCHED [ AND expression ] THEN
+UPDATE SET setClauseList
+    | DELETE
+    | {UPDATE SET setClauseList [ WHERE expression ] DELETE [ WHERE expression ]}
+","
+WHEN MATCHED clause for MERGE USING command.
+
+If both UPDATE and DELETE are specified, DELETE can delete only rows that were updated,
+WHERE condition in DELETE clause can be used to specify which updated rows should be deleted.
+This condition checks values in updated row.
+","
+WHEN MATCHED THEN UPDATE SET VALUE = S.VALUE
+WHEN MATCHED THEN DELETE
+"
+
+"Other Grammar","Merge when not matched clause","
+WHEN NOT MATCHED [ AND expression ] THEN INSERT insertColumnsAndSource
+","
+WHEN NOT MATCHED clause for MERGE USING command.
+","
+WHEN NOT MATCHED THEN INSERT (ID, NAME) VALUES (S.ID, S.NAME)
+"
+
+"Other Grammar","Name","
+{ { A-Z|_ } [ { A-Z|_|0-9 } [...] ] } | quotedName
+","
+Names are not case sensitive. There is no maximum name length.
+","
+TEST
+"
+
+"Other Grammar","Operand","
+summand [ { || summand } [...] ]
+","
+A value or a concatenation of values.
+In the default mode, the result is NULL if either parameter is NULL.
+","
+'Hi' || ' Eva'
+"
+
+"Other Grammar","Order","
+{ int | expression } [ ASC | DESC ] [ NULLS { FIRST | LAST } ]
+","
+Sorts the result by the given column number, or by an expression. If the
+expression is a single parameter, then the value is interpreted as a column
+number. Negative column numbers reverse the sort order.
+","
+NAME DESC NULLS LAST
+"
+
+"Other Grammar","Quoted Name","
+""anythingExceptDoubleQuote""
+","
+Quoted names are case sensitive, and can contain spaces. There is no maximum
+name length. Two double quotes can be used to create a single double quote
+inside an identifier.
+","
+""FirstName""
+"
+
+"Other Grammar","Referential Constraint","
+FOREIGN KEY ( columnName [,...] )
+REFERENCES [ refTableName ] [ ( refColumnName [,...] ) ]
+[ ON DELETE referentialAction ] [ ON UPDATE referentialAction ]
+","
+Defines a referential constraint.
+If the table name is not specified, then the same table is referenced.
+RESTRICT is the default action.
+If the referenced columns are not specified, then the primary key columns are used.
+The required indexes are automatically created if required.
+Some tables may not be referenced, such as metadata tables.
+","
+FOREIGN KEY(ID) REFERENCES TEST(ID)
+"
+
+"Other Grammar","Referential Action","
+CASCADE | RESTRICT | NO ACTION | SET { DEFAULT | NULL }
+","
+The action CASCADE will cause conflicting rows in the referencing (child) table to be deleted or updated.
+RESTRICT is the default action.
+As this database does not support deferred checking, RESTRICT and NO ACTION will both throw an exception if the constraint is violated.
+The action SET DEFAULT will set the column in the referencing (child) table to the default value, while SET NULL will set it to NULL.
+","
+FOREIGN KEY(ID) REFERENCES TEST(ID) ON UPDATE CASCADE
+"
+
+"Other Grammar","Script Compression Encryption","
+[ COMPRESSION { DEFLATE | LZF | ZIP | GZIP } ]
+[ CIPHER cipher PASSWORD string ]
+","
+The compression and encryption algorithm to use for script files.
+When using encryption, only DEFLATE and LZF are supported.
+LZF is faster but uses more space.
+","
+COMPRESSION LZF
+"
+
+"Other Grammar","Row value expression","
+ROW (expression, [,...])
+    | ( [ expression, expression [,...] ] )
+    | expression
+","
+A row value expression.
+","
+ROW (1)
+(1, 2)
+1
+"
+
+"Other Grammar","Select Expression","
+wildcardExpression | expression [ [ AS ] columnAlias ]
+","
+An expression in a SELECT statement.
+","
+ID AS VALUE
+"
+
+"Other Grammar","Sequence options","
+[ START WITH long ]
+[ INCREMENT BY long ]
+[ MINVALUE long | NOMINVALUE | NO MINVALUE ]
+[ MAXVALUE long | NOMAXVALUE | NO MAXVALUE ]
+[ CYCLE long | NOCYCLE | NO CYCLE ]
+[ CACHE long | NOCACHE | NO CACHE ]
+","
+Options of a sequence.
+","
+START WITH 1
+"
+
+"Other Grammar","Set clause list","
+{ { columnName = { DEFAULT | expression } } [,...] }
+    | { ( columnName [,...] ) = {rowValueExpression|(select)} }
+","
+List of SET clauses.
+","
+NAME = 'Test', VALUE = 2
+(A, B) = (1, 2)
+(A, B) = (SELECT X, Y FROM OTHER T2 WHERE T1.ID = T2.ID)
+"
+
+"Other Grammar","Summand","
+factor [ { { + | - } factor } [...] ]
+","
+A value or a numeric sum.
+
+Please note the text concatenation operator is ""||"".
+","
+ID + 20
+"
+
+"Other Grammar","Table Expression","
+{ [ schemaName. ] tableName | ( select ) | valuesExpression }
+[ [ AS ] newTableAlias [ ( columnName [,...] ) ] ]
+[ USE INDEX ([ indexName [,...] ]) ]
+[ { { LEFT | RIGHT } [ OUTER ] | [ INNER ] | CROSS | NATURAL }
+    JOIN tableExpression [ ON expression ] ]
+","
+Joins a table. The join expression is not supported for cross and natural joins.
+A natural join is an inner join, where the condition is automatically on the
+columns with the same name.
+","
+TEST AS T LEFT JOIN TEST AS T1 ON T.ID = T1.ID
+"
+
+"Other Grammar","Within group specification","
+WITHIN GROUP (ORDER BY {expression [ASC|DESC]} [,...])
+","
+Group specification for ordered set functions.
+","
+WITHIN GROUP (ORDER BY ID DESC)
+"
+
+"Other Grammar","Wildcard expression","
+{* | tableAlias.*} [EXCEPT ([tableAlias.]columnName, [,...])]
+","
+A wildcard expression in a SELECT statement.
+A wildcard expression represents all visible columns. Some columns can be excluded with optional EXCEPT clause.
+","
+*
+* EXCEPT (DATA)
+"
+
+"Other Grammar","Window name or specification","
+windowName | windowSpecification
+","
+A window name or inline specification for a window function or aggregate.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+W1
+(ORDER BY ID)
+"
+
+"Other Grammar","Window specification","
+([existingWindowName]
+[PARTITION BY expression [,...]] [ORDER BY order [,...]]
+[windowFrame])
+","
+A window specification for a window, window function or aggregate.
+
+If name of an existing window is specified its clauses are used by default.
+
+Optional window partition clause separates rows into independent partitions.
+Each partition is processed separately.
+If this clause is not present there is one implicit partition with all rows.
+
+Optional window order clause specifies order of rows in the partition.
+If some rows have the same order position they are considered as a group of rows in optional window frame clause.
+
+Optional window frame clause specifies which rows are processed by a window function,
+see its documentation for a more details.
+","
+()
+(W1 ORDER BY ID)
+(PARTITION BY CATEGORY)
+(PARTITION BY CATEGORY ORDER BY NAME, ID)
+(ORDER BY Y RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW EXCLUDE TIES)
+"
+
+"Other Grammar","Window frame","
+ROWS|RANGE|GROUP
+{windowFramePreceding|BETWEEN windowFrameBound AND windowFrameBound}
+[EXCLUDE {CURRENT ROW|GROUP|TIES|NO OTHERS}]
+","
+A window frame clause.
+May be specified only for aggregates and FIRST_VALUE(), LAST_VALUE(), and NTH_VALUE() window functions.
+
+If this clause is not specified for an aggregate or window function that supports this clause
+the default window frame depends on window order clause.
+If window order clause is also not specified
+the default window frame contains all the rows in the partition.
+If window order clause is specified
+the default window frame contains all preceding rows and all rows from the current group.
+
+Window frame unit determines how rows or groups of rows are selected and counted.
+If ROWS is specified rows are not grouped in any way and relative numbers of rows are used in bounds.
+If RANGE is specified rows are grouped according window order clause,
+preceding and following values mean the difference between value in the current row and in the target rows,
+and CURRENT ROW in bound specification means current group of rows.
+If GROUPS is specified rows are grouped according window order clause,
+preceding and following values means relative number of groups of rows,
+and CURRENT ROW in bound specification means current group of rows.
+
+If only window frame preceding clause is specified it is treated as
+BETWEEN windowFramePreceding AND CURRENT ROW.
+
+Optional window frame exclusion clause specifies rows that should be excluded from the frame.
+EXCLUDE CURRENT ROW excludes only the current row regardless the window frame unit.
+EXCLUDE GROUP excludes the whole current group of rows, including the current row.
+EXCLUDE TIES excludes the current group of rows, but not the current row.
+EXCLUDE NO OTHERS is default and it does not exclude anything.
+","
+ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW EXCLUDE TIES
+"
+
+"Other Grammar","Window frame preceding","
+UNBOUNDED PRECEDING|value PRECEDING|CURRENT ROW
+","
+A window frame preceding clause.
+If value is specified it should not be negative.
+","
+UNBOUNDED PRECEDING
+1 PRECEDING
+CURRENT ROW
+"
+
+"Other Grammar","Window frame bound","
+UNBOUNDED PRECEDING|value PRECEDING|CURRENT ROW
+    |value FOLLOWING|UNBOUNDED FOLLOWING
+","
+A window frame bound clause.
+If value is specified it should not be negative.
+","
+UNBOUNDED PRECEDING
+UNBOUNDED FOLLOWING
+1 FOLLOWING
+CURRENT ROW
+"
+
+"Other Grammar","Term","
+value
+    | column
+    | ?[ int ]
+    | NEXT VALUE FOR sequenceName
+    | function
+    | { - | + } term
+    | ( expression )
+    | select
+    | case
+    | caseWhen
+    | userDefinedFunctionName
+","
+A value. Parameters can be indexed, for example ""?1"" meaning the first parameter.
+","
+'Hello'
+"
+
+"Other Grammar","Column","
+[[schemaName.]tableAlias.] { columnName | _ROWID_ }
+","
+A column name with optional table alias and schema.
+_ROWID_ can be used to access unique row identifier.
+","
+ID
+"
+
+"Data Types","INT Type","
+INT | INTEGER | MEDIUMINT | INT4 | SIGNED
+","
+Possible values: -2147483648 to 2147483647.
+
+Mapped to ""java.lang.Integer"".
+","
+INT
+"
+
+"Data Types","BOOLEAN Type","
+BOOLEAN | BIT | BOOL
+","
+Possible values: TRUE and FALSE.
+
+Mapped to ""java.lang.Boolean"".
+","
+BOOLEAN
+"
+
+"Data Types","TINYINT Type","
+TINYINT
+","
+Possible values are: -128 to 127.
+
+Mapped to ""java.lang.Byte"".
+","
+TINYINT
+"
+
+"Data Types","SMALLINT Type","
+SMALLINT | INT2 | YEAR
+","
+Possible values: -32768 to 32767.
+
+Mapped to ""java.lang.Short"".
+","
+SMALLINT
+"
+
+"Data Types","BIGINT Type","
+BIGINT | INT8
+","
+Possible values: -9223372036854775808 to 9223372036854775807.
+
+Mapped to ""java.lang.Long"".
+","
+BIGINT
+"
+
+"Data Types","IDENTITY Type","
+IDENTITY
+","
+Auto-Increment value. Possible values: -9223372036854775808 to
+9223372036854775807. Used values are never re-used, even when the transaction is
+rolled back.
+
+Mapped to ""java.lang.Long"".
+","
+IDENTITY
+"
+
+"Data Types","DECIMAL Type","
+{ DECIMAL | NUMBER | DEC | NUMERIC } ( precisionInt [ , scaleInt ] )
+","
+Data type with fixed precision and scale. This data type is recommended for
+storing currency values.
+
+Mapped to ""java.math.BigDecimal"".
+","
+DECIMAL(20, 2)
+"
+
+"Data Types","DOUBLE Type","
+{ DOUBLE [ PRECISION ] | FLOAT [ ( precisionInt ) ] | FLOAT8 }
+","
+A floating point number. Should not be used to represent currency values, because
+of rounding problems.
+If precision value is specified for FLOAT type name, it should be from 25 to 53.
+
+Mapped to ""java.lang.Double"".
+","
+DOUBLE
+"
+
+"Data Types","REAL Type","
+{ REAL | FLOAT ( precisionInt ) | FLOAT4 }
+","
+A single precision floating point number. Should not be used to represent currency
+values, because of rounding problems.
+Precision value for FLOAT type name should be from 0 to 24.
+
+Mapped to ""java.lang.Float"".
+","
+REAL
+"
+
+"Data Types","TIME Type","
+TIME [ ( precisionInt ) ] [ WITHOUT TIME ZONE ]
+","
+The time data type. The format is hh:mm:ss[.nnnnnnnnn].
+If fractional seconds precision is specified it should be from 0 to 9, 0 is default.
+
+Mapped to ""java.sql.Time"". When converted to a ""java.sql.Date"", the date is set to ""1970-01-01"".
+""java.time.LocalTime"" is also supported on Java 8 and later versions.
+Use ""java.time.LocalTime"" or ""String"" instead of ""java.sql.Time"" when non-zero precision is needed.
+Cast from higher fractional seconds precision to lower fractional seconds precision performs round half up;
+if result of rounding is higher than maximum supported value 23:59:59.999999999 it is saturated to 23:59:59.999999999.
+","
+TIME
+TIME(9)
+"
+
+"Data Types","DATE Type","
+DATE
+","
+The date data type. The format is yyyy-MM-dd.
+
+Mapped to ""java.sql.Date"", with the time set to ""00:00:00""
+(or to the next possible time if midnight doesn't exist for the given date and timezone due to a daylight saving change).
+""java.time.LocalDate"" is also supported on Java 8 and later versions.
+","
+DATE
+"
+
+"Data Types","TIMESTAMP Type","
+{ TIMESTAMP [ ( precisionInt ) ] [ WITHOUT TIME ZONE ]
+    | DATETIME [ ( precisionInt ) ] | SMALLDATETIME }
+","
+The timestamp data type. The format is yyyy-MM-dd hh:mm:ss[.nnnnnnnnn].
+Stored internally as a BCD-encoded date, and nanoseconds since midnight.
+If fractional seconds precision is specified it should be from 0 to 9, 6 is default.
+Fractional seconds precision of SMALLDATETIME is always 0 and cannot be specified.
+
+Mapped to ""java.sql.Timestamp"" (""java.util.Date"" may be used too).
+""java.time.LocalDateTime"" is also supported on Java 8 and later versions.
+Cast from higher fractional seconds precision to lower fractional seconds precision performs round half up.
+","
+TIMESTAMP
+TIMESTAMP(9)
+"
+
+"Data Types","TIMESTAMP WITH TIME ZONE Type","
+TIMESTAMP [ ( precisionInt ) ] WITH TIME ZONE
+","
+The timestamp with time zone data type.
+Stored internally as a BCD-encoded date, nanoseconds since midnight, and time zone offset in minutes.
+If fractional seconds precision is specified it should be from 0 to 9, 6 is default.
+
+Mapped to ""org.h2.api.TimestampWithTimeZone"".
+""java.time.OffsetDateTime"" and ""java.time.Instant"" are also supported on Java 8 and later versions.
+
+Values of this data type are compared by UTC values. It means that ""2010-01-01 10:00:00+01"" is greater than ""2010-01-01 11:00:00+03"".
+
+Conversion to ""TIMESTAMP"" uses time zone offset to get UTC time and converts it to local time using the system time zone.
+Conversion from ""TIMESTAMP"" does the same operations in reverse and sets time zone offset to offset of the system time zone.
+Cast from higher fractional seconds precision to lower fractional seconds precision performs round half up.
+","
+TIMESTAMP WITH TIME ZONE
+TIMESTAMP(9) WITH TIME ZONE
+"
+
+"Data Types","BINARY Type","
+{ BINARY | VARBINARY | BINARY VARYING
+    | LONGVARBINARY | RAW | BYTEA }
+[ ( precisionInt ) ]
+","
+Represents a byte array. For very long arrays, use BLOB.
+The maximum size is 2 GB, but the whole object is kept in
+memory when using this data type. The precision is a size constraint;
+only the actual data is persisted. For large text data BLOB or CLOB
+should be used.
+
+Mapped to byte[].
+","
+BINARY(1000)
+"
+
+"Data Types","OTHER Type","
+OTHER
+","
+This type allows storing serialized Java objects. Internally, a byte array is used.
+Serialization and deserialization is done on the client side only.
+Deserialization is only done when ""getObject"" is called.
+Java operations cannot be executed inside the database engine for security reasons.
+Use ""PreparedStatement.setObject"" to store values.
+
+Mapped to ""java.lang.Object"" (or any subclass).
+","
+OTHER
+"
+
+"Data Types","VARCHAR Type","
+{ VARCHAR | CHARACTER VARYING | LONGVARCHAR | VARCHAR2 | NVARCHAR
+    | NVARCHAR2 | VARCHAR_CASESENSITIVE} [ ( precisionInt ) ]
+","
+A Unicode String.
+Use two single quotes ('') to create a quote.
+
+The maximum precision is ""Integer.MAX_VALUE"".
+The precision is a size constraint; only the actual data is persisted.
+
+The whole text is loaded into memory when using this data type.
+For large text data CLOB should be used; see there for details.
+
+Mapped to ""java.lang.String"".
+","
+VARCHAR(255)
+"
+
+"Data Types","VARCHAR_IGNORECASE Type","
+VARCHAR_IGNORECASE [ ( precisionInt ) ]
+","
+Same as VARCHAR, but not case sensitive when comparing.
+Stored in mixed case.
+
+The maximum precision is ""Integer.MAX_VALUE"".
+The precision is a size constraint; only the actual data is persisted.
+
+The whole text is loaded into memory when using this data type.
+For large text data CLOB should be used; see there for details.
+
+Mapped to ""java.lang.String"".
+","
+VARCHAR_IGNORECASE
+"
+
+"Data Types","CHAR Type","
+{ CHAR | CHARACTER | NCHAR } [ ( precisionInt ) ]
+","
+A Unicode String.
+This type is supported for compatibility with other databases and older applications.
+The difference to VARCHAR is that trailing spaces are ignored and not persisted.
+
+The maximum precision is ""Integer.MAX_VALUE"".
+The precision is a size constraint; only the actual data is persisted.
+
+The whole text is kept in memory when using this data type.
+For large text data CLOB should be used; see there for details.
+
+Mapped to ""java.lang.String"".
+","
+CHAR(10)
+"
+
+"Data Types","BLOB Type","
+{ BLOB | BINARY LARGE OBJECT
+    | TINYBLOB | MEDIUMBLOB | LONGBLOB | IMAGE | OID }
+[ ( precisionInt [K|M|G|T|P]) ]
+","
+Like BINARY, but intended for very large values such as files or images. Unlike
+when using BINARY, large objects are not kept fully in-memory. Use
+""PreparedStatement.setBinaryStream"" to store values. See also CLOB and
+Advanced / Large Objects.
+
+Mapped to ""java.sql.Blob"" (""java.io.InputStream"" is also supported).
+","
+BLOB
+BLOB(10K)
+"
+
+"Data Types","CLOB Type","
+{ CLOB | CHARACTER LARGE OBJECT
+    | TINYTEXT | TEXT | MEDIUMTEXT | LONGTEXT | NTEXT | NCLOB }
+[ ( precisionInt [K|M|G|T|P] [CHARACTERS|OCTETS]) ]
+","
+CLOB is like VARCHAR, but intended for very large values. Unlike when using
+VARCHAR, large CLOB objects are not kept fully in-memory; instead, they are streamed.
+CLOB should be used for documents and texts with arbitrary size such as XML or
+HTML documents, text files, or memo fields of unlimited size. Use
+""PreparedStatement.setCharacterStream"" to store values. See also Advanced / Large Objects.
+
+VARCHAR should be used for text with relatively short average size (for example
+shorter than 200 characters). Short CLOB values are stored inline, but there is
+an overhead compared to VARCHAR.
+
+Precision, if any, should be specified in characters, CHARACTERS and OCTETS units have no effect in H2.
+
+Mapped to ""java.sql.Clob"" (""java.io.Reader"" is also supported).
+","
+CLOB
+CLOB(10K)
+"
+
+"Data Types","UUID Type","
+UUID
+","
+Universally unique identifier. This is a 128 bit value.
+To store values, use ""PreparedStatement.setBytes"",
+""setString"", or ""setObject(uuid)"" (where ""uuid"" is a ""java.util.UUID"").
+""ResultSet.getObject"" will return a ""java.util.UUID"".
+
+Please note that using an index on randomly generated data will
+result on poor performance once there are millions of rows in a table.
+The reason is that the cache behavior is very bad with randomly distributed data.
+This is a problem for any database system.
+
+For details, see the documentation of ""java.util.UUID"".
+","
+UUID
+"
+
+"Data Types","ARRAY Type","
+ARRAY
+","
+An array of values.
+Mapped to ""java.lang.Object[]"" (arrays of any non-primitive type are also supported).
+
+Use a value list (1, 2) or ""PreparedStatement.setObject(.., new Object[] {..})"" to store values,
+and ""ResultSet.getObject(..)"" or ""ResultSet.getArray(..)"" to retrieve the values.
+","
+ARRAY
+"
+
+"Data Types","ENUM Type","
+{ ENUM (string [, ... ]) }
+","
+A type with enumerated values.
+Mapped to ""java.lang.Integer"".
+
+The first provided value is mapped to 0, the
+second mapped to 1, and so on.
+
+Duplicate and empty values are not permitted.
+","
+
+ENUM('clubs', 'diamonds', 'hearts', 'spades')
+"
+"Data Types","GEOMETRY Type","
+GEOMETRY
+    [({ GEOMETRY |
+    { POINT
+    | LINESTRING
+    | POLYGON
+    | MULTIPOINT
+    | MULTILINESTRING
+    | MULTIPOLYGON
+    | GEOMETRYCOLLECTION } [Z|M|ZM]}
+    [, sridInt] )]
+","
+A spatial geometry type.
+If additional constraints are not specified this type accepts all supported types of geometries.
+A constraint with required geometry type and dimension system can be set by specifying name of the type and
+dimension system. A whitespace between them is optional.
+2D dimension system does not have a name and assumed if only a geometry type name is specified.
+POINT means 2D point, POINT Z or POINTZ means 3D point.
+GEOMETRY constraint means no restrictions on type or dimension system of geometry.
+A constraint with required spatial reference system identifier (SRID) can be set by specifying this identifier.
+
+Mapped to ""org.locationtech.jts.geom.Geometry"" if JTS library is in classpath and to ""java.lang.String"" otherwise.
+May be represented in textual format using the WKT (well-known text) or EWKT (extended well-known text) format.
+Values are stored internally in EWKB (extended well-known binary) format.
+Only a subset of EWKB and EWKT features is supported.
+Supported objects are POINT, LINESTRING, POLYGON, MULTIPOINT, MULTILINESTRING, MULTIPOLYGON, and GEOMETRYCOLLECTION.
+Supported dimension systems are 2D (XY), Z (XYZ), M (XYM), and ZM (XYZM).
+SRID (spatial reference system identifier) is supported.
+
+Use a quoted string containing a WKT/EWKT formatted string or ""PreparedStatement.setObject()"" to store values,
+and ""ResultSet.getObject(..)"" or ""ResultSet.getString(..)"" to retrieve the values.
+","
+GEOMETRY
+GEOMETRY(POINT)
+GEOMETRY(POINT Z)
+GEOMETRY(POINT Z, 4326)
+GEOMETRY(GEOMETRY, 4326)
+"
+
+"Data Types","INTERVAL Type","
+intervalYearType | intervalMonthType | intervalDayType
+    | intervalHourType| intervalMinuteType | intervalSecondType
+    | intervalYearToMonthType | intervalDayToHourType
+    | intervalDayToMinuteType | intervalDayToSecondType
+    | intervalHourToMinuteType | intervalHourToSecondType
+    | intervalMinuteToSecondType
+","
+Interval data type.
+There are two classes of intervals. Year-month intervals can store years and months.
+Day-time intervals can store days, hours, minutes, and seconds.
+Year-month intervals are comparable only with another year-month intervals.
+Day-time intervals are comparable only with another day-time intervals.
+
+Mapped to ""org.h2.api.Interval"".
+","
+INTERVAL DAY TO SECOND
+"
+
+"Interval Data Types","INTERVAL YEAR Type","
+INTERVAL YEAR [ ( precisionInt ) ]
+","
+Interval data type.
+If precision is specified it should be from 1 to 18, 2 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Period"" is also supported on Java 8 and later versions.
+","
+INTERVAL YEAR
+"
+
+"Interval Data Types","INTERVAL MONTH Type","
+INTERVAL MONTH [ ( precisionInt ) ]
+","
+Interval data type.
+If precision is specified it should be from 1 to 18, 2 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Period"" is also supported on Java 8 and later versions.
+","
+INTERVAL MONTH
+"
+
+"Interval Data Types","INTERVAL DAY Type","
+INTERVAL DAY [ ( precisionInt ) ]
+","
+Interval data type.
+If precision is specified it should be from 1 to 18, 2 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Duration"" is also supported on Java 8 and later versions.
+","
+INTERVAL DAY
+"
+
+"Interval Data Types","INTERVAL HOUR Type","
+INTERVAL HOUR [ ( precisionInt ) ]
+","
+Interval data type.
+If precision is specified it should be from 1 to 18, 2 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Duration"" is also supported on Java 8 and later versions.
+","
+INTERVAL HOUR
+"
+
+"Interval Data Types","INTERVAL MINUTE Type","
+INTERVAL MINUTE [ ( precisionInt ) ]
+","
+Interval data type.
+If precision is specified it should be from 1 to 18, 2 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Duration"" is also supported on Java 8 and later versions.
+","
+INTERVAL MINUTE
+"
+
+"Interval Data Types","INTERVAL SECOND Type","
+INTERVAL SECOND [ ( precisionInt [, fractionalPrecisionInt ] ) ]
+","
+Interval data type.
+If precision is specified it should be from 1 to 18, 2 is default.
+If fractional seconds precision is specified it should be from 0 to 9, 6 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Duration"" is also supported on Java 8 and later versions.
+","
+INTERVAL SECOND
+"
+
+"Interval Data Types","INTERVAL YEAR TO MONTH Type","
+INTERVAL YEAR [ ( precisionInt ) ] TO MONTH
+","
+Interval data type.
+If leading field precision is specified it should be from 1 to 18, 2 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Period"" is also supported on Java 8 and later versions.
+","
+INTERVAL YEAR TO MONTH
+"
+
+"Interval Data Types","INTERVAL DAY TO HOUR Type","
+INTERVAL DAY [ ( precisionInt ) ] TO HOUR
+","
+Interval data type.
+If leading field precision is specified it should be from 1 to 18, 2 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Duration"" is also supported on Java 8 and later versions.
+","
+INTERVAL DAY TO HOUR
+"
+
+"Interval Data Types","INTERVAL DAY TO MINUTE Type","
+INTERVAL DAY [ ( precisionInt ) ] TO MINUTE
+","
+Interval data type.
+If leading field precision is specified it should be from 1 to 18, 2 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Duration"" is also supported on Java 8 and later versions.
+","
+INTERVAL DAY TO MINUTE
+"
+
+"Interval Data Types","INTERVAL DAY TO SECOND Type","
+INTERVAL DAY [ ( precisionInt ) ] TO SECOND [ ( fractionalPrecisionInt ) ]
+","
+Interval data type.
+If leading field precision is specified it should be from 1 to 18, 2 is default.
+If fractional seconds precision is specified it should be from 0 to 9, 6 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Duration"" is also supported on Java 8 and later versions.
+","
+INTERVAL DAY TO SECOND
+"
+
+"Interval Data Types","INTERVAL HOUR TO MINUTE Type","
+INTERVAL HOUR [ ( precisionInt ) ] TO MINUTE
+","
+Interval data type.
+If leading field precision is specified it should be from 1 to 18, 2 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Duration"" is also supported on Java 8 and later versions.
+","
+INTERVAL HOUR TO MINUTE
+"
+
+"Interval Data Types","INTERVAL HOUR TO SECOND Type","
+INTERVAL HOUR [ ( precisionInt ) ] TO SECOND [ ( fractionalPrecisionInt ) ]
+","
+Interval data type.
+If leading field precision is specified it should be from 1 to 18, 2 is default.
+If fractional seconds precision is specified it should be from 0 to 9, 6 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Duration"" is also supported on Java 8 and later versions.
+","
+INTERVAL HOUR TO SECOND
+"
+
+"Interval Data Types","INTERVAL MINUTE TO SECOND Type","
+INTERVAL MINUTE [ ( precisionInt ) ] TO SECOND [ ( fractionalPrecisionInt ) ]
+","
+Interval data type.
+If leading field precision is specified it should be from 1 to 18, 2 is default.
+If fractional seconds precision is specified it should be from 0 to 9, 6 is default.
+
+Mapped to ""org.h2.api.Interval"".
+""java.time.Duration"" is also supported on Java 8 and later versions.
+","
+INTERVAL MINUTE TO SECOND
+"
+
+"Functions (Aggregate)","AVG","
+AVG ( [ DISTINCT|ALL ] { numeric } )
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The average (mean) value.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+The returned value is of the same data type as the parameter.
+","
+AVG(X)
+"
+
+"Functions (Aggregate)","BIT_AND","
+BIT_AND(expression)
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The bitwise AND of all non-null values.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+BIT_AND(ID)
+"
+
+"Functions (Aggregate)","BIT_OR","
+BIT_OR(expression)
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The bitwise OR of all non-null values.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+BIT_OR(ID)
+"
+
+"Functions (Aggregate)","EVERY","
+{EVERY|BOOL_AND}(boolean)
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Returns true if all expressions are true.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+EVERY(ID>10)
+"
+
+"Functions (Aggregate)","ANY","
+{ANY|SOME|BOOL_OR}(boolean)
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Returns true if any expression is true.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+
+Note that if ANY or SOME aggregate function is placed on the right side of comparison operation
+and argument of this function is a subquery additional parentheses around aggregate function are required,
+otherwise it will be parsed as quantified comparison predicate.
+","
+ANY(NAME LIKE 'W%')
+A = (ANY((SELECT B FROM T)))
+"
+
+"Functions (Aggregate)","COUNT","
+COUNT( { * | { [ DISTINCT|ALL ] expression } } )
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The count of all row, or of the non-null values.
+This method returns a long.
+If no rows are selected, the result is 0.
+Aggregates are only allowed in select statements.
+","
+COUNT(*)
+"
+
+"Functions (Aggregate)","LISTAGG","
+{ LISTAGG ( [ DISTINCT|ALL ] string [, separatorString] [ ON OVERFLOW ERROR ] )
+    withinGroupSpecification }
+| { GROUP_CONCAT ( [ DISTINCT|ALL ] string
+    [ ORDER BY { expression [ ASC | DESC ] } [,...] ]
+    [ SEPARATOR separatorString ] ) }
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Concatenates strings with a separator.
+Separator must be the same for all rows in the same group.
+The default separator is a ',' (without space).
+This method returns a string.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+LISTAGG(NAME, ', ') WITHIN GROUP (ORDER BY ID)
+LISTAGG(ID, ', ') WITHIN GROUP (ORDER BY ID) OVER (ORDER BY ID)
+"
+
+"Functions (Aggregate)","ARRAY_AGG","
+ARRAY_AGG ( [ DISTINCT|ALL ] string
+[ ORDER BY { expression [ ASC | DESC ] } [,...] ] )
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Aggregate the value into an array.
+This method returns an array.
+If no rows are selected, the result is NULL.
+If ORDER BY is not specified order of values is not determined.
+When this aggregate is used with OVER clause that contains ORDER BY subclause
+it does not enforce exact order of values.
+This aggregate needs additional own ORDER BY clause to make it deterministic.
+Aggregates are only allowed in select statements.
+","
+ARRAY_AGG(NAME ORDER BY ID)
+ARRAY_AGG(ID ORDER BY ID) OVER (ORDER BY ID)
+"
+
+"Functions (Aggregate)","MAX","
+MAX(value)
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The highest value.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+The returned value is of the same data type as the parameter.
+","
+MAX(NAME)
+"
+
+"Functions (Aggregate)","MIN","
+MIN(value)
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The lowest value.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+The returned value is of the same data type as the parameter.
+","
+MIN(NAME)
+"
+
+"Functions (Aggregate)","SUM","
+SUM( [ DISTINCT|ALL ] { numeric } )
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The sum of all values.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+The data type of the returned value depends on the parameter data type like this:
+""BOOLEAN, TINYINT, SMALLINT, INT -> BIGINT, BIGINT -> DECIMAL, REAL -> DOUBLE""
+","
+SUM(X)
+"
+
+"Functions (Aggregate)","SELECTIVITY","
+SELECTIVITY(value)
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Estimates the selectivity (0-100) of a value.
+The value is defined as (100 * distinctCount / rowCount).
+The selectivity of 0 rows is 0 (unknown).
+Up to 10000 values are kept in memory.
+Aggregates are only allowed in select statements.
+","
+SELECT SELECTIVITY(FIRSTNAME), SELECTIVITY(NAME) FROM TEST WHERE ROWNUM()<20000
+"
+
+"Functions (Aggregate)","STDDEV_POP","
+STDDEV_POP( [ DISTINCT|ALL ] numeric )
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The population standard deviation.
+This method returns a double.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+STDDEV_POP(X)
+"
+
+"Functions (Aggregate)","STDDEV_SAMP","
+STDDEV_SAMP( [ DISTINCT|ALL ] numeric )
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The sample standard deviation.
+This method returns a double.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+STDDEV(X)
+"
+
+"Functions (Aggregate)","VAR_POP","
+VAR_POP( [ DISTINCT|ALL ] numeric )
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The population variance (square of the population standard deviation).
+This method returns a double.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+VAR_POP(X)
+"
+
+"Functions (Aggregate)","VAR_SAMP","
+VAR_SAMP( [ DISTINCT|ALL ] numeric )
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The sample variance (square of the sample standard deviation).
+This method returns a double.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+VAR_SAMP(X)
+"
+
+"Functions (Aggregate)","RANK aggregate","
+RANK(value [,...])
+withinGroupSpecification
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Returns the rank of the hypothetical row in specified collection of rows.
+The rank of a row is the number of rows that precede this row plus 1.
+If two or more rows have the same values in ORDER BY columns, these rows get the same rank from the first row with the same values.
+It means that gaps in ranks are possible.
+","
+SELECT RANK(5) WITHIN GROUP (ORDER BY V) FROM TEST;
+"
+
+"Functions (Aggregate)","DENSE_RANK aggregate","
+DENSE_RANK(value [,...])
+withinGroupSpecification
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Returns the dense rank of the hypothetical row in specified collection of rows.
+The rank of a row is the number of groups of rows with the same values in ORDER BY columns that precede group with this row plus 1.
+If two or more rows have the same values in ORDER BY columns, these rows get the same rank.
+Gaps in ranks are not possible.
+","
+SELECT DENSE_RANK(5) WITHIN GROUP (ORDER BY V) FROM TEST;
+"
+
+"Functions (Aggregate)","PERCENT_RANK aggregate","
+PERCENT_RANK(value [,...])
+withinGroupSpecification
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Returns the relative rank of the hypothetical row in specified collection of rows.
+The relative rank is calculated as (RANK - 1) / (NR - 1),
+where RANK is a rank of the row and NR is a total number of rows in the collection including hypothetical row.
+","
+SELECT PERCENT_RANK(5) WITHIN GROUP (ORDER BY V) FROM TEST;
+"
+
+"Functions (Aggregate)","CUME_DIST aggregate","
+CUME_DIST(value [,...])
+withinGroupSpecification
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Returns the relative rank of the hypothetical row in specified collection of rows.
+The relative rank is calculated as NP / NR
+where NP is a number of rows that precede the current row or have the same values in ORDER BY columns
+and NR is a total number of rows in the collection including hypothetical row.
+","
+SELECT CUME_DIST(5) WITHIN GROUP (ORDER BY V) FROM TEST;
+"
+
+"Functions (Aggregate)","PERCENTILE_CONT","
+PERCENTILE_CONT(numeric) WITHIN GROUP (ORDER BY value [ASC|DESC])
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Return percentile of values from the group with interpolation.
+Interpolation is only supported for numeric, date-time, and interval data types.
+Argument must be between 0 and 1 inclusive.
+Argument must be the same for all rows in the same group.
+If argument is NULL, the result is NULL.
+NULL values are ignored in the calculation.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+PERCENTILE_CONT(0.5) WITHIN GROUP (ORDER BY V)
+"
+
+"Functions (Aggregate)","PERCENTILE_DISC","
+PERCENTILE_DISC(numeric) WITHIN GROUP (ORDER BY value [ASC|DESC])
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Return percentile of values from the group.
+Interpolation is not performed.
+Argument must be between 0 and 1 inclusive.
+Argument must be the same for all rows in the same group.
+If argument is NULL, the result is NULL.
+NULL values are ignored in the calculation.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+PERCENTILE_DISC(0.5) WITHIN GROUP (ORDER BY V)
+"
+
+"Functions (Aggregate)","MEDIAN","
+MEDIAN( [ DISTINCT|ALL ] value )
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+The value separating the higher half of a values from the lower half.
+Returns the middle value or an interpolated value between two middle values if number of values is even.
+Interpolation is only supported for numeric, date-time, and interval data types.
+NULL values are ignored in the calculation.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+MEDIAN(X)
+"
+
+"Functions (Aggregate)","MODE","
+{ MODE( value ) [ ORDER BY expression [ ASC | DESC ] ] }
+    | { MODE() WITHIN GROUP (ORDER BY expression [ ASC | DESC ]) }
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Returns the value that occurs with the greatest frequency.
+If there are multiple values with the same frequency only one value will be returned.
+In this situation value will be chosen based on optional ORDER BY clause
+that should specify exactly the same expression as argument of this function.
+Use ascending order to get smallest value or descending order to get largest value
+from multiple values with the same frequency.
+If this clause is not specified the exact chosen value is not determined in this situation.
+NULL values are ignored in the calculation.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+MODE(X)
+MODE(X ORDER BY X)
+MODE() WITHIN GROUP (ORDER BY X)
+"
+
+"Functions (Aggregate)","ENVELOPE","
+ENVELOPE( value )
+[FILTER (WHERE expression)] [OVER windowNameOrSpecification]
+","
+Returns the minimum bounding box that encloses all specified GEOMETRY values.
+Only 2D coordinate plane is supported.
+NULL values are ignored in the calculation.
+If no rows are selected, the result is NULL.
+Aggregates are only allowed in select statements.
+","
+ENVELOPE(X)
+"
+
+"Functions (Numeric)","ABS","
+ABS( { numeric | interval } )
+","
+Returns the absolute value of a specified value.
+The returned value is of the same data type as the parameter.
+
+Note that TINYINT, SMALLINT, INT, and BIGINT data types cannot represent absolute values
+of their minimum negative values, because they have more negative values than positive.
+For example, for INT data type allowed values are from -2147483648 to 2147483647.
+ABS(-2147483648) should be 2147483648, but this value is not allowed for this data type.
+It leads to an exception.
+To avoid it cast argument of this function to a higher data type.
+","
+ABS(VALUE)
+ABS(CAST(VALUE AS BIGINT))
+"
+
+"Functions (Numeric)","ACOS","
+ACOS(numeric)
+","
+Calculate the arc cosine.
+See also Java ""Math.acos"".
+This method returns a double.
+","
+ACOS(D)
+"
+
+"Functions (Numeric)","ASIN","
+ASIN(numeric)
+","
+Calculate the arc sine.
+See also Java ""Math.asin"".
+This method returns a double.
+","
+ASIN(D)
+"
+
+"Functions (Numeric)","ATAN","
+ATAN(numeric)
+","
+Calculate the arc tangent.
+See also Java ""Math.atan"".
+This method returns a double.
+","
+ATAN(D)
+"
+
+"Functions (Numeric)","COS","
+COS(numeric)
+","
+Calculate the trigonometric cosine.
+See also Java ""Math.cos"".
+This method returns a double.
+","
+COS(ANGLE)
+"
+
+"Functions (Numeric)","COSH","
+COSH(numeric)
+","
+Calculate the hyperbolic cosine.
+See also Java ""Math.cosh"".
+This method returns a double.
+","
+COSH(X)
+"
+
+"Functions (Numeric)","COT","
+COT(numeric)
+","
+Calculate the trigonometric cotangent (""1/TAN(ANGLE)"").
+See also Java ""Math.*"" functions.
+This method returns a double.
+","
+COT(ANGLE)
+"
+
+"Functions (Numeric)","SIN","
+SIN(numeric)
+","
+Calculate the trigonometric sine.
+See also Java ""Math.sin"".
+This method returns a double.
+","
+SIN(ANGLE)
+"
+
+"Functions (Numeric)","SINH","
+SINH(numeric)
+","
+Calculate the hyperbolic sine.
+See also Java ""Math.sinh"".
+This method returns a double.
+","
+SINH(ANGLE)
+"
+
+"Functions (Numeric)","TAN","
+TAN(numeric)
+","
+Calculate the trigonometric tangent.
+See also Java ""Math.tan"".
+This method returns a double.
+","
+TAN(ANGLE)
+"
+
+"Functions (Numeric)","TANH","
+TANH(numeric)
+","
+Calculate the hyperbolic tangent.
+See also Java ""Math.tanh"".
+This method returns a double.
+","
+TANH(X)
+"
+
+"Functions (Numeric)","ATAN2","
+ATAN2(numeric, numeric)
+","
+Calculate the angle when converting the rectangular coordinates to polar coordinates.
+See also Java ""Math.atan2"".
+This method returns a double.
+","
+ATAN2(X, Y)
+"
+
+"Functions (Numeric)","BITAND","
+BITAND(long, long)
+","
+The bitwise AND operation.
+This method returns a long.
+See also Java operator &.
+","
+BITAND(A, B)
+"
+
+"Functions (Numeric)","BITGET","
+BITGET(long, int)
+","
+Returns true if and only if the first parameter has a bit set in the
+position specified by the second parameter.
+This method returns a boolean.
+The second parameter is zero-indexed; the least significant bit has position 0.
+","
+BITGET(A, 1)
+"
+
+"Functions (Numeric)","BITOR","
+BITOR(long, long)
+","
+The bitwise OR operation.
+This method returns a long.
+See also Java operator |.
+","
+BITOR(A, B)
+"
+
+"Functions (Numeric)","BITXOR","
+BITXOR(long, long)
+","
+The bitwise XOR operation.
+This method returns a long.
+See also Java operator ^.
+","
+BITXOR(A, B)
+"
+
+"Functions (Numeric)","MOD","
+MOD(long, long)
+","
+The modulo operation.
+This method returns a long.
+See also Java operator %.
+","
+MOD(A, B)
+"
+
+"Functions (Numeric)","CEILING","
+{ CEILING | CEIL } (numeric)
+","
+See also Java ""Math.ceil"".
+This method returns a double.
+","
+CEIL(A)
+"
+
+"Functions (Numeric)","DEGREES","
+DEGREES(numeric)
+","
+See also Java ""Math.toDegrees"".
+This method returns a double.
+","
+DEGREES(A)
+"
+
+"Functions (Numeric)","EXP","
+EXP(numeric)
+","
+See also Java ""Math.exp"".
+This method returns a double.
+","
+EXP(A)
+"
+
+"Functions (Numeric)","FLOOR","
+FLOOR(numeric)
+","
+See also Java ""Math.floor"".
+This method returns a double.
+","
+FLOOR(A)
+"
+
+"Functions (Numeric)","LN","
+{LN|LOG}(numeric)
+","
+Calculates the natural (base e) logarithm as a double value.
+In the PostgreSQL mode, LOG(x) is base 10.
+See also Java ""Math.log"".
+","
+LN(A)
+"
+
+"Functions (Numeric)","LOG10","
+LOG10(numeric)
+","
+Calculates the base 10 logarithm as a double value.
+See also Java ""Math.log10"".
+","
+LOG10(A)
+"
+
+"Functions (Numeric)","ORA_HASH","
+ORA_HASH(expression [, bucketLong [, seedLong]])
+","
+Computes a hash value.
+Optional bucket argument determines the maximum returned value.
+This argument should be between 0 and 4294967295, default is 4294967295.
+Optional seed argument is combined with the given expression to return the different values for the same expression.
+This argument should be between 0 and 4294967295, default is 0.
+This method returns a long value between 0 and the specified or default bucket value inclusive.
+","
+ORA_HASH(A)
+"
+
+"Functions (Numeric)","RADIANS","
+RADIANS(numeric)
+","
+See also Java ""Math.toRadians"".
+This method returns a double.
+","
+RADIANS(A)
+"
+
+"Functions (Numeric)","SQRT","
+SQRT(numeric)
+","
+See also Java ""Math.sqrt"".
+This method returns a double.
+","
+SQRT(A)
+"
+
+"Functions (Numeric)","PI","
+PI()
+","
+See also Java ""Math.PI"".
+This method returns a double.
+","
+PI()
+"
+
+"Functions (Numeric)","POWER","
+POWER(numeric, numeric)
+","
+See also Java ""Math.pow"".
+This method returns a double.
+","
+POWER(A, B)
+"
+
+"Functions (Numeric)","RAND","
+{ RAND | RANDOM } ( [ int ] )
+","
+Calling the function without parameter returns the next a pseudo random number.
+Calling it with an parameter seeds the session's random number generator.
+This method returns a double between 0 (including) and 1 (excluding).
+","
+RAND()
+"
+
+"Functions (Numeric)","RANDOM_UUID","
+{ RANDOM_UUID | UUID } ()
+","
+Returns a new UUID with 122 pseudo random bits.
+
+Please note that using an index on randomly generated data will
+result on poor performance once there are millions of rows in a table.
+The reason is that the cache behavior is very bad with randomly distributed data.
+This is a problem for any database system.
+","
+RANDOM_UUID()
+"
+
+"Functions (Numeric)","ROUND","
+ROUND(numeric [, digitsInt])
+","
+Rounds to a number of digits, or to the nearest long if the number of digits if not set.
+This method returns a numeric (the same type as the input).
+","
+ROUND(VALUE, 2)
+"
+
+"Functions (Numeric)","ROUNDMAGIC","
+ROUNDMAGIC(numeric)
+","
+This function rounds numbers in a good way, but it is slow.
+It has a special handling for numbers around 0.
+Only numbers smaller or equal +/-1000000000000 are supported.
+The value is converted to a String internally, and then the last 4 characters are checked.
+'000x' becomes '0000' and '999x' becomes '999999', which is rounded automatically.
+This method returns a double.
+","
+ROUNDMAGIC(VALUE/3*3)
+"
+
+"Functions (Numeric)","SECURE_RAND","
+SECURE_RAND(int)
+","
+Generates a number of cryptographically secure random numbers.
+This method returns bytes.
+","
+CALL SECURE_RAND(16)
+"
+
+"Functions (Numeric)","SIGN","
+SIGN( { numeric | interval } )
+","
+Returns -1 if the value is smaller than 0, 0 if zero, and otherwise 1.
+","
+SIGN(VALUE)
+"
+
+"Functions (Numeric)","ENCRYPT","
+ENCRYPT(algorithmString, keyBytes, dataBytes)
+","
+Encrypts data using a key.
+The supported algorithm is AES.
+The block size is 16 bytes.
+This method returns bytes.
+","
+CALL ENCRYPT('AES', '00', STRINGTOUTF8('Test'))
+"
+
+"Functions (Numeric)","DECRYPT","
+DECRYPT(algorithmString, keyBytes, dataBytes)
+","
+Decrypts data using a key.
+The supported algorithm is AES.
+The block size is 16 bytes.
+This method returns bytes.
+","
+CALL TRIM(CHAR(0) FROM UTF8TOSTRING(
+    DECRYPT('AES', '00', '3fabb4de8f1ee2e97d7793bab2db1116')))
+"
+
+"Functions (Numeric)","HASH","
+HASH(algorithmString, expression [, iterationInt])
+","
+Calculate the hash value using an algorithm, and repeat this process for a number of iterations.
+Currently, the only algorithm supported is SHA256.
+This method returns bytes.
+","
+CALL HASH('SHA256', STRINGTOUTF8('Password'), 1000)
+"
+
+"Functions (Numeric)","TRUNCATE","
+{ TRUNC | TRUNCATE } ( { {numeric, digitsInt}
+    | timestamp | timestampWithTimeZone | date | timestampString } )
+","
+Truncates to a number of digits (to the next value closer to 0).
+This method returns a double.
+When used with a timestamp, truncates a timestamp to a date (day) value.
+When used with a date, truncates a date to a date (day) value less time part.
+When used with a timestamp as string, truncates a timestamp to a date (day) value.
+","
+TRUNCATE(VALUE, 2)
+"
+
+"Functions (Numeric)","COMPRESS","
+COMPRESS(dataBytes [, algorithmString])
+","
+Compresses the data using the specified compression algorithm.
+Supported algorithms are: LZF (faster but lower compression; default), and DEFLATE (higher compression).
+Compression does not always reduce size. Very small objects and objects with little redundancy may get larger.
+This method returns bytes.
+","
+COMPRESS(STRINGTOUTF8('Test'))
+"
+
+"Functions (Numeric)","EXPAND","
+EXPAND(bytes)
+","
+Expands data that was compressed using the COMPRESS function.
+This method returns bytes.
+","
+UTF8TOSTRING(EXPAND(COMPRESS(STRINGTOUTF8('Test'))))
+"
+
+"Functions (Numeric)","ZERO","
+ZERO()
+","
+Returns the value 0. This function can be used even if numeric literals are disabled.
+","
+ZERO()
+"
+
+"Functions (String)","ASCII","
+ASCII(string)
+","
+Returns the ASCII value of the first character in the string.
+This method returns an int.
+","
+ASCII('Hi')
+"
+"Functions (String)","BIT_LENGTH","
+BIT_LENGTH(string)
+","
+Returns the number of bits in a string.
+This method returns a long.
+For BLOB, CLOB, BYTES and JAVA_OBJECT, the precision is used. Each character needs 16 bits.
+","
+BIT_LENGTH(NAME)
+"
+
+"Functions (String)","LENGTH","
+{ LENGTH | CHAR_LENGTH | CHARACTER_LENGTH } ( string )
+","
+Returns the number of characters in a string.
+This method returns a long.
+For BLOB, CLOB, BYTES and JAVA_OBJECT, the precision is used.
+","
+LENGTH(NAME)
+"
+
+"Functions (String)","OCTET_LENGTH","
+OCTET_LENGTH(string)
+","
+Returns the number of bytes in a string.
+This method returns a long.
+For BLOB, CLOB, BYTES and JAVA_OBJECT, the precision is used.
+Each character needs 2 bytes.
+","
+OCTET_LENGTH(NAME)
+"
+
+"Functions (String)","CHAR","
+{ CHAR | CHR } ( int )
+","
+Returns the character that represents the ASCII value.
+This method returns a string.
+","
+CHAR(65)
+"
+
+"Functions (String)","CONCAT","
+CONCAT(string, string [,...])
+","
+Combines strings.
+Unlike with the operator ""||"", NULL parameters are ignored,
+and do not cause the result to become NULL.
+This method returns a string.
+","
+CONCAT(NAME, '!')
+"
+
+"Functions (String)","CONCAT_WS","
+CONCAT_WS(separatorString, string, string [,...])
+","
+Combines strings with separator.
+Unlike with the operator ""||"", NULL parameters are ignored,
+and do not cause the result to become NULL.
+This method returns a string.
+","
+CONCAT_WS(',', NAME, '!')
+"
+
+"Functions (String)","DIFFERENCE","
+DIFFERENCE(string, string)
+","
+Returns the difference between the sounds of two strings.
+The difference is calculated as a number of matched characters
+in the same positions in SOUNDEX representations of arguments.
+This method returns an int between 0 and 4 inclusive, or null if any of its parameters is null.
+Note that value of 0 means that strings are not similar to each other.
+Value of 4 means that strings are fully similar to each other (have the same SOUNDEX representation).
+","
+DIFFERENCE(T1.NAME, T2.NAME)
+"
+
+"Functions (String)","HEXTORAW","
+HEXTORAW(string)
+","
+Converts a hex representation of a string to a string.
+4 hex characters per string character are used.
+","
+HEXTORAW(DATA)
+"
+
+"Functions (String)","RAWTOHEX","
+RAWTOHEX(string)
+","
+Converts a string to the hex representation.
+4 hex characters per string character are used.
+This method returns a string.
+","
+RAWTOHEX(DATA)
+"
+
+"Functions (String)","INSTR","
+INSTR(string, searchString, [, startInt])
+","
+Returns the location of a search string in a string.
+If a start position is used, the characters before it are ignored.
+If position is negative, the rightmost location is returned.
+0 is returned if the search string is not found.
+Please note this function is case sensitive, even if the parameters are not.
+","
+INSTR(EMAIL,'@')
+"
+
+"Functions (String)","INSERT Function","
+INSERT(originalString, startInt, lengthInt, addString)
+","
+Inserts a additional string into the original string at a specified start position.
+The length specifies the number of characters that are removed at the start position in the original string.
+This method returns a string.
+","
+INSERT(NAME, 1, 1, ' ')
+"
+
+"Functions (String)","LOWER","
+{ LOWER | LCASE } ( string )
+","
+Converts a string to lowercase.
+","
+LOWER(NAME)
+"
+
+"Functions (String)","UPPER","
+{ UPPER | UCASE } ( string )
+","
+Converts a string to uppercase.
+","
+UPPER(NAME)
+"
+
+"Functions (String)","LEFT","
+LEFT(string, int)
+","
+Returns the leftmost number of characters.
+","
+LEFT(NAME, 3)
+"
+
+"Functions (String)","RIGHT","
+RIGHT(string, int)
+","
+Returns the rightmost number of characters.
+","
+RIGHT(NAME, 3)
+"
+
+"Functions (String)","LOCATE","
+LOCATE(searchString, string [, startInt])
+","
+Returns the location of a search string in a string.
+If a start position is used, the characters before it are ignored.
+If position is negative, the rightmost location is returned.
+0 is returned if the search string is not found.
+","
+LOCATE('.', NAME)
+"
+
+"Functions (String)","POSITION","
+POSITION(searchString, string)
+","
+Returns the location of a search string in a string. See also LOCATE.
+","
+POSITION('.', NAME)
+"
+
+"Functions (String)","LPAD","
+LPAD(string, int[, paddingString])
+","
+Left pad the string to the specified length.
+If the length is shorter than the string, it will be truncated at the end.
+If the padding string is not set, spaces will be used.
+","
+LPAD(AMOUNT, 10, '*')
+"
+
+"Functions (String)","RPAD","
+RPAD(string, int[, paddingString])
+","
+Right pad the string to the specified length.
+If the length is shorter than the string, it will be truncated.
+If the padding string is not set, spaces will be used.
+","
+RPAD(TEXT, 10, '-')
+"
+
+"Functions (String)","LTRIM","
+LTRIM(string)
+","
+Removes all leading spaces from a string.
+","
+LTRIM(NAME)
+"
+
+"Functions (String)","RTRIM","
+RTRIM(string)
+","
+Removes all trailing spaces from a string.
+","
+RTRIM(NAME)
+"
+
+"Functions (String)","TRIM","
+TRIM ( [ [ LEADING | TRAILING | BOTH ] [ string ] FROM ] string )
+","
+Removes all leading spaces, trailing spaces, or spaces at both ends, from a string.
+Other characters can be removed as well.
+","
+TRIM(BOTH '_' FROM NAME)
+"
+
+"Functions (String)","REGEXP_REPLACE","
+REGEXP_REPLACE(inputString, regexString, replacementString [, flagsString])
+","
+Replaces each substring that matches a regular expression.
+For details, see the Java ""String.replaceAll()"" method.
+If any parameter is null (except optional flagsString parameter), the result is null.
+
+Flags values limited to 'i', 'c', 'n', 'm'. Other symbols causes exception.
+Multiple symbols could be uses in one flagsString parameter (like 'im').
+Later flags overrides first ones, for example 'ic' equivalent to case sensitive matching 'c'.
+
+'i' enables case insensitive matching (Pattern.CASE_INSENSITIVE)
+
+'c' disables case insensitive matching (Pattern.CASE_INSENSITIVE)
+
+'n' allows the period to match the newline character (Pattern.DOTALL)
+
+'m' enables multiline mode (Pattern.MULTILINE)
+
+","
+REGEXP_REPLACE('Hello    World', ' +', ' ')
+REGEXP_REPLACE('Hello WWWWorld', 'w+', 'W', 'i')
+"
+
+"Functions (String)","REGEXP_LIKE","
+REGEXP_LIKE(inputString, regexString [, flagsString])
+","
+Matches string to a regular expression.
+For details, see the Java ""Matcher.find()"" method.
+If any parameter is null (except optional flagsString parameter), the result is null.
+
+Flags values limited to 'i', 'c', 'n', 'm'. Other symbols causes exception.
+Multiple symbols could be uses in one flagsString parameter (like 'im').
+Later flags overrides first ones, for example 'ic' equivalent to case sensitive matching 'c'.
+
+'i' enables case insensitive matching (Pattern.CASE_INSENSITIVE)
+
+'c' disables case insensitive matching (Pattern.CASE_INSENSITIVE)
+
+'n' allows the period to match the newline character (Pattern.DOTALL)
+
+'m' enables multiline mode (Pattern.MULTILINE)
+
+","
+REGEXP_LIKE('Hello    World', '[A-Z ]*', 'i')
+"
+
+"Functions (String)","REPEAT","
+REPEAT(string, int)
+","
+Returns a string repeated some number of times.
+","
+REPEAT(NAME || ' ', 10)
+"
+
+"Functions (String)","REPLACE","
+REPLACE(string, searchString [, replacementString])
+","
+Replaces all occurrences of a search string in a text with another string.
+If no replacement is specified, the search string is removed from the original string.
+If any parameter is null, the result is null.
+","
+REPLACE(NAME, ' ')
+"
+
+"Functions (String)","SOUNDEX","
+SOUNDEX(string)
+","
+Returns a four character code representing the sound of a string.
+This method returns a string, or null if parameter is null.
+See https://en.wikipedia.org/wiki/Soundex for more information.
+","
+SOUNDEX(NAME)
+"
+
+"Functions (String)","SPACE","
+SPACE(int)
+","
+Returns a string consisting of a number of spaces.
+","
+SPACE(80)
+"
+
+"Functions (String)","STRINGDECODE","
+STRINGDECODE(string)
+","
+Converts a encoded string using the Java string literal encoding format.
+Special characters are \b, \t, \n, \f, \r, \"", \\, \<octal>, \u<unicode>.
+This method returns a string.
+","
+CALL STRINGENCODE(STRINGDECODE('Lines 1\nLine 2'))
+"
+
+"Functions (String)","STRINGENCODE","
+STRINGENCODE(string)
+","
+Encodes special characters in a string using the Java string literal encoding format.
+Special characters are \b, \t, \n, \f, \r, \"", \\, \<octal>, \u<unicode>.
+This method returns a string.
+","
+CALL STRINGENCODE(STRINGDECODE('Lines 1\nLine 2'))
+"
+
+"Functions (String)","STRINGTOUTF8","
+STRINGTOUTF8(string)
+","
+Encodes a string to a byte array using the UTF8 encoding format.
+This method returns bytes.
+","
+CALL UTF8TOSTRING(STRINGTOUTF8('This is a test'))
+"
+
+"Functions (String)","SUBSTRING","
+{ SUBSTRING | SUBSTR } ( string, startInt [, lengthInt ] )
+","
+Returns a substring of a string starting at a position.
+If the start index is negative, then the start index is relative to the end of the string.
+The length is optional.
+Also supported is: ""SUBSTRING(string [FROM start] [FOR length])"".
+","
+CALL SUBSTR('[Hello]', 2, 5);
+CALL SUBSTR('Hello World', -5);
+"
+
+"Functions (String)","UTF8TOSTRING","
+UTF8TOSTRING(bytes)
+","
+Decodes a byte array in the UTF8 format to a string.
+","
+CALL UTF8TOSTRING(STRINGTOUTF8('This is a test'))
+"
+
+"Functions (String)","XMLATTR","
+XMLATTR(nameString, valueString)
+","
+Creates an XML attribute element of the form ""name=value"".
+The value is encoded as XML text.
+This method returns a string.
+","
+CALL XMLNODE('a', XMLATTR('href', 'http://h2database.com'))
+"
+
+"Functions (String)","XMLNODE","
+XMLNODE(elementString [, attributesString [, contentString [, indentBoolean]]])
+","
+Create an XML node element.
+An empty or null attribute string means no attributes are set.
+An empty or null content string means the node is empty.
+The content is indented by default if it contains a newline.
+This method returns a string.
+","
+CALL XMLNODE('a', XMLATTR('href', 'http://h2database.com'), 'H2')
+"
+
+"Functions (String)","XMLCOMMENT","
+XMLCOMMENT(commentString)
+","
+Creates an XML comment.
+Two dashes (""--"") are converted to ""- -"".
+This method returns a string.
+","
+CALL XMLCOMMENT('Test')
+"
+
+"Functions (String)","XMLCDATA","
+XMLCDATA(valueString)
+","
+Creates an XML CDATA element.
+If the value contains ""]]>"", an XML text element is created instead.
+This method returns a string.
+","
+CALL XMLCDATA('data')
+"
+
+"Functions (String)","XMLSTARTDOC","
+XMLSTARTDOC()
+","
+Returns the XML declaration.
+The result is always ""<?xml version=""1.0""?>"".
+","
+CALL XMLSTARTDOC()
+"
+
+"Functions (String)","XMLTEXT","
+XMLTEXT(valueString [, escapeNewlineBoolean])
+","
+Creates an XML text element.
+If enabled, newline and linefeed is converted to an XML entity (&#).
+This method returns a string.
+","
+CALL XMLTEXT('test')
+"
+
+"Functions (String)","TO_CHAR","
+TO_CHAR(value [, formatString[, nlsParamString]])
+","
+Oracle-compatible TO_CHAR function that can format a timestamp, a number, or text.
+","
+CALL TO_CHAR(TIMESTAMP '2010-01-01 00:00:00', 'DD MON, YYYY')
+"
+
+"Functions (String)","TRANSLATE","
+TRANSLATE(value, searchString, replacementString)
+","
+Oracle-compatible TRANSLATE function that replaces a sequence of characters in a string with another set of characters.
+","
+CALL TRANSLATE('Hello world', 'eo', 'EO')
+"
+
+"Functions (Time and Date)","CURRENT_DATE","
+{ CURRENT_DATE | CURDATE() | SYSDATE | TODAY }
+","
+Returns the current date.
+These methods always return the same value within a transaction (default)
+or within a command depending on database mode.
+","
+CURRENT_DATE
+"
+
+"Functions (Time and Date)","CURRENT_TIME","
+CURRENT_TIME [ (int) ]
+","
+Returns the current time.
+The returned value does not have time zone information, because TIME WITH TIME ZONE data type is not supported in H2.
+If fractional seconds precision is specified it should be from 0 to 9, 0 is default.
+The specified value can be used only to limit precision of a result.
+The actual maximum available precision depends on operating system and JVM and can be 3 (milliseconds) or higher.
+Higher precision is not available before Java 9.
+These methods always return the same value within a transaction (default)
+or within a command depending on database mode.
+","
+CURRENT_TIME
+CURRENT_TIME(9)
+"
+
+"Functions (Time and Date)","CURRENT_TIMESTAMP","
+CURRENT_TIMESTAMP [ (int) ]
+","
+Returns the current timestamp with time zone.
+Time zone offset is set to a current time zone offset.
+If fractional seconds precision is specified it should be from 0 to 9, 6 is default.
+The specified value can be used only to limit precision of a result.
+The actual maximum available precision depends on operating system and JVM and can be 3 (milliseconds) or higher.
+Higher precision is not available before Java 9.
+This method always returns the same value within a transaction (default)
+or within a command depending on database mode.
+","
+CURRENT_TIMESTAMP
+CURRENT_TIMESTAMP(9)
+"
+
+"Functions (Time and Date)","LOCALTIME","
+{ LOCALTIME [ (int) ] | CURTIME([ int ]) }
+","
+Returns the current time.
+If fractional seconds precision is specified it should be from 0 to 9, 0 is default.
+The specified value can be used only to limit precision of a result.
+The actual maximum available precision depends on operating system and JVM and can be 3 (milliseconds) or higher.
+Higher precision is not available before Java 9.
+These methods always return the same value within a transaction (default)
+or within a command depending on database mode.
+","
+LOCALTIME
+LOCALTIME(9)
+"
+
+"Functions (Time and Date)","LOCALTIMESTAMP","
+{ LOCALTIMESTAMP [ (int) ] | NOW( [ int ] ) }
+","
+Returns the current timestamp without time zone.
+If fractional seconds precision is specified it should be from 0 to 9, 6 is default.
+The specified value can be used only to limit precision of a result.
+The actual maximum available precision depends on operating system and JVM and can be 3 (milliseconds) or higher.
+Higher precision is not available before Java 9.
+These methods always return the same value within a transaction (default)
+or within a command depending on database mode.
+","
+LOCALTIMESTAMP
+LOCALTIMESTAMP(9)
+"
+
+"Functions (Time and Date)","DATEADD","
+{ DATEADD| TIMESTAMPADD } (datetimeField, addIntLong, dateAndTime)
+","
+Adds units to a date-time value. The datetimeField indicates the unit.
+Use negative values to subtract units.
+addIntLong may be a long value when manipulating milliseconds,
+microseconds, or nanoseconds otherwise its range is restricted to int.
+This method returns a value with the same type as specified value if unit is compatible with this value.
+If specified field is a HOUR, MINUTE, SECOND, MILLISECOND, etc and value is a DATE value DATEADD returns combined TIMESTAMP.
+Fields DAY, MONTH, YEAR, WEEK, etc are not allowed for TIME values.
+Fields TIMEZONE_HOUR and TIMEZONE_MINUTE are only allowed for TIMESTAMP WITH TIME ZONE values.
+","
+DATEADD(MONTH, 1, DATE '2001-01-31')
+"
+
+"Functions (Time and Date)","DATEDIFF","
+{ DATEDIFF | TIMESTAMPDIFF } (datetimeField, aDateAndTime, bDateAndTime)
+","
+Returns the number of crossed unit boundaries between two date/time values.
+This method returns a long.
+The datetimeField indicates the unit.
+Only TIMEZONE_HOUR and TIMEZONE_MINUTE fields use the time zone offset component.
+With all other fields if date/time values have time zone offset component it is ignored.
+","
+DATEDIFF(YEAR, T1.CREATED, T2.CREATED)
+"
+
+"Functions (Time and Date)","DAYNAME","
+DAYNAME(dateAndTime)
+","
+Returns the name of the day (in English).
+","
+DAYNAME(CREATED)
+"
+
+"Functions (Time and Date)","DAY_OF_MONTH","
+DAY_OF_MONTH(dateAndTime|interval)
+","
+Returns the day of the month (1-31).
+","
+DAY_OF_MONTH(CREATED)
+"
+
+"Functions (Time and Date)","DAY_OF_WEEK","
+DAY_OF_WEEK(dateAndTime)
+","
+Returns the day of the week (1 means Sunday).
+","
+DAY_OF_WEEK(CREATED)
+"
+
+"Functions (Time and Date)","ISO_DAY_OF_WEEK","
+ISO_DAY_OF_WEEK(dateAndTime)
+","
+Returns the ISO day of the week (1 means Monday).
+","
+ISO_DAY_OF_WEEK(CREATED)
+"
+
+"Functions (Time and Date)","DAY_OF_YEAR","
+DAY_OF_YEAR(dateAndTime|interval)
+","
+Returns the day of the year (1-366).
+","
+DAY_OF_YEAR(CREATED)
+"
+
+"Functions (Time and Date)","EXTRACT","
+EXTRACT ( datetimeField FROM { dateAndTime | interval })
+","
+Returns a value of the specific time unit from a date/time value.
+This method returns a numeric value with EPOCH field and
+an int for all other fields.
+","
+EXTRACT(SECOND FROM CURRENT_TIMESTAMP)
+"
+
+"Functions (Time and Date)","FORMATDATETIME","
+FORMATDATETIME ( dateAndTime, formatString
+[ , localeString [ , timeZoneString ] ] )
+","
+Formats a date, time or timestamp as a string.
+The most important format characters are:
+y year, M month, d day, H hour, m minute, s second.
+For details of the format, see ""java.text.SimpleDateFormat"".
+timeZoneString may be specified if dateAndTime is a DATE, TIME or TIMESTAMP.
+timeZoneString is ignored if dateAndTime is TIMESTAMP WITH TIME ZONE.
+This method returns a string.
+","
+CALL FORMATDATETIME(TIMESTAMP '2001-02-03 04:05:06',
+    'EEE, d MMM yyyy HH:mm:ss z', 'en', 'GMT')
+"
+
+"Functions (Time and Date)","HOUR","
+HOUR(dateAndTime|interval)
+","
+Returns the hour (0-23) from a date/time value.
+","
+HOUR(CREATED)
+"
+
+"Functions (Time and Date)","MINUTE","
+MINUTE(dateAndTime|interval)
+","
+Returns the minute (0-59) from a date/time value.
+","
+MINUTE(CREATED)
+"
+
+"Functions (Time and Date)","MONTH","
+MONTH(dateAndTime|interval)
+","
+Returns the month (1-12) from a date/time value.
+","
+MONTH(CREATED)
+"
+
+"Functions (Time and Date)","MONTHNAME","
+MONTHNAME(dateAndTime)
+","
+Returns the name of the month (in English).
+","
+MONTHNAME(CREATED)
+"
+
+"Functions (Time and Date)","PARSEDATETIME","
+PARSEDATETIME(string, formatString
+[, localeString [, timeZoneString]])
+","
+Parses a string and returns a timestamp.
+The most important format characters are:
+y year, M month, d day, H hour, m minute, s second.
+For details of the format, see ""java.text.SimpleDateFormat"".
+","
+CALL PARSEDATETIME('Sat, 3 Feb 2001 03:05:06 GMT',
+    'EEE, d MMM yyyy HH:mm:ss z', 'en', 'GMT')
+"
+
+"Functions (Time and Date)","QUARTER","
+QUARTER(dateAndTime)
+","
+Returns the quarter (1-4) from a date/time value.
+","
+QUARTER(CREATED)
+"
+
+"Functions (Time and Date)","SECOND","
+SECOND(dateAndTime)
+","
+Returns the second (0-59) from a date/time value.
+","
+SECOND(CREATED|interval)
+"
+
+"Functions (Time and Date)","WEEK","
+WEEK(dateAndTime)
+","
+Returns the week (1-53) from a date/time value.
+This method uses the current system locale.
+","
+WEEK(CREATED)
+"
+
+"Functions (Time and Date)","ISO_WEEK","
+ISO_WEEK(dateAndTime)
+","
+Returns the ISO week (1-53) from a date/time value.
+This function uses the ISO definition when
+first week of year should have at least four days
+and week is started with Monday.
+","
+ISO_WEEK(CREATED)
+"
+
+"Functions (Time and Date)","YEAR","
+YEAR(dateAndTime|interval)
+","
+Returns the year from a date/time value.
+","
+YEAR(CREATED)
+"
+
+"Functions (Time and Date)","ISO_YEAR","
+ISO_YEAR(dateAndTime)
+","
+Returns the ISO week year from a date/time value.
+","
+ISO_YEAR(CREATED)
+"
+
+"Functions (System)","ARRAY_GET","
+ARRAY_GET(arrayExpression, indexExpression)
+","
+Returns element at the specified 1-based index from an array.
+Returns NULL if there is no such element or array is NULL.
+","
+CALL ARRAY_GET(ARRAY['Hello', 'World'], 2)
+"
+
+"Functions (System)","ARRAY_LENGTH","
+ARRAY_LENGTH(arrayExpression)
+","
+Returns the length of an array.
+Returns NULL if the specified array is NULL.
+","
+CALL ARRAY_LENGTH(ARRAY['Hello', 'World'])
+"
+
+"Functions (System)","ARRAY_CONTAINS","
+ARRAY_CONTAINS(arrayExpression, value)
+","
+Returns a boolean TRUE if the array contains the value or FALSE if it does not contain it.
+Returns NULL if the specified array is NULL.
+","
+CALL ARRAY_CONTAINS(ARRAY['Hello', 'World'], 'Hello')
+"
+
+"Functions (System)","ARRAY_CAT","
+ARRAY_CAT(arrayExpression, arrayExpression)
+","
+Returns the concatenation of two arrays.
+Returns NULL if any parameter is NULL.
+","
+CALL ARRAY_CAT(ARRAY[1, 2], ARRAY[3, 4])
+"
+
+"Functions (System)","ARRAY_APPEND","
+ARRAY_APPEND(arrayExpression, value)
+","
+Append an element to the end of an array.
+Returns NULL if any parameter is NULL.
+","
+CALL ARRAY_APPEND(ARRAY[1, 2], 3)
+"
+
+"Functions (System)","ARRAY_SLICE","
+ARRAY_SLICE(arrayExpression, lowerBoundInt, upperBoundInt)
+","
+Returns elements from the array as specified by the lower and upper bound parameters.
+Both parameters are inclusive and the first element has index 1, i.e. ARRAY_SLICE(a, 2, 2) has only the second element.
+Returns NULL if any parameter is NULL or if an index is out of bounds.
+","
+CALL ARRAY_SLICE(ARRAY[1, 2, 3, 4], 1, 3)
+"
+
+"Functions (System)","AUTOCOMMIT","
+AUTOCOMMIT()
+","
+Returns true if auto commit is switched on for this session.
+","
+AUTOCOMMIT()
+"
+
+"Functions (System)","CANCEL_SESSION","
+CANCEL_SESSION(sessionInt)
+","
+Cancels the currently executing statement of another session.
+The method only works if the multithreaded kernel is enabled (see SET MULTI_THREADED).
+Returns true if the statement was canceled, false if the session is closed or no statement is currently executing.
+
+Admin rights are required to execute this command.
+","
+CANCEL_SESSION(3)
+"
+
+"Functions (System)","CASEWHEN Function","
+CASEWHEN(boolean, aValue, bValue)
+","
+Returns 'a' if the boolean expression is true, otherwise 'b'.
+Returns the same data type as the parameter.
+","
+CASEWHEN(ID=1, 'A', 'B')
+"
+
+"Functions (System)","CAST","
+CAST(value AS dataType)
+","
+Converts a value to another data type. The following conversion rules are used:
+When converting a number to a boolean, 0 is false and every other value is true.
+When converting a boolean to a number, false is 0 and true is 1.
+When converting a number to a number of another type, the value is checked for overflow.
+When converting a number to binary, the number of bytes matches the precision.
+When converting a string to binary, it is hex encoded (every byte two characters);
+a hex string can be converted to a number by first converting it to binary.
+If a direct conversion is not possible, the value is first converted to a string.
+Note that some data types may need explicitly specified precision to avoid overflow or rounding.
+","
+CAST(NAME AS INT);
+CAST(65535 AS BINARY);
+CAST(CAST('FFFF' AS BINARY) AS INT);
+CAST(TIMESTAMP '2010-01-01 10:40:00.123456' AS TIME(6))
+"
+
+"Functions (System)","COALESCE","
+{ COALESCE | NVL } (aValue, bValue [,...])
+","
+Returns the first value that is not null.
+","
+COALESCE(A, B, C)
+"
+
+"Functions (System)","CONVERT","
+CONVERT(value, dataType)
+","
+Converts a value to another data type.
+","
+CONVERT(NAME, INT)
+"
+
+"Functions (System)","CURRVAL","
+CURRVAL( [ schemaName, ] sequenceString )
+","
+Returns the current (last) value of the sequence, independent of the session.
+If the sequence was just created, the method returns (start - interval).
+If the schema name is not set, the current schema is used.
+If the schema name is not set, the sequence name is converted to uppercase (for compatibility).
+This method returns a long.
+","
+CURRVAL('TEST_SEQ')
+"
+
+"Functions (System)","CSVREAD","
+CSVREAD(fileNameString [, columnsString [, csvOptions ] ] )
+","
+Returns the result set of reading the CSV (comma separated values) file.
+For each parameter, NULL means the default value should be used.
+
+If the column names are specified (a list of column names separated with the
+fieldSeparator), those are used, otherwise (or if they are set to NULL) the first line of
+the file is interpreted as the column names.
+In that case, column names that contain no special characters (only letters, '_',
+and digits; similar to the rule for Java identifiers) are considered case insensitive.
+Other column names are case sensitive, that means you need to use quoted identifiers
+(see below).
+
+The default charset is the default value for this system, and the default field separator
+is a comma. Missing unquoted values as well as data that matches nullString is
+parsed as NULL. All columns of type VARCHAR.
+
+The BOM (the byte-order-mark) character 0xfeff at the beginning of the file is ignored.
+
+This function can be used like a table: ""SELECT * FROM CSVREAD(...)"".
+
+Instead of a file, an URL may be used, for example
+""jar:file:///c:/temp/example.zip!/org/example/nested.csv"".
+To read a stream from the classpath, use the prefix ""classpath:"".
+To read from HTTP, use the prefix ""http:"" (as in a browser).
+
+For performance reason, CSVREAD should not be used inside a join.
+Instead, import the data first (possibly into a temporary table) and then use the table.
+
+Admin rights are required to execute this command.
+","
+CALL CSVREAD('test.csv');
+-- Read a file containing the columns ID, NAME with
+CALL CSVREAD('test2.csv', 'ID|NAME', 'charset=UTF-8 fieldSeparator=|');
+SELECT * FROM CSVREAD('data/test.csv', null, 'rowSeparator=;');
+-- Read a tab-separated file
+SELECT * FROM CSVREAD('data/test.tsv', null, 'rowSeparator=' || CHAR(9));
+SELECT ""Last Name"" FROM CSVREAD('address.csv');
+SELECT ""Last Name"" FROM CSVREAD('classpath:/org/acme/data/address.csv');
+"
+
+"Functions (System)","CSVWRITE","
+CSVWRITE ( fileNameString, queryString [, csvOptions [, lineSepString] ] )
+","
+Writes a CSV (comma separated values). The file is overwritten if it exists.
+If only a file name is specified, it will be written to the current working directory.
+For each parameter, NULL means the default value should be used.
+The default charset is the default value for this system, and the default field separator is a comma.
+
+The values are converted to text using the default string representation;
+if another conversion is required you need to change the select statement accordingly.
+The parameter nullString is used when writing NULL (by default nothing is written
+when NULL appears). The default line separator is the default value for this
+system (system property ""line.separator"").
+
+The returned value is the number or rows written.
+Admin rights are required to execute this command.
+","
+CALL CSVWRITE('data/test.csv', 'SELECT * FROM TEST');
+CALL CSVWRITE('data/test2.csv', 'SELECT * FROM TEST', 'charset=UTF-8 fieldSeparator=|');
+-- Write a tab-separated file
+CALL CSVWRITE('data/test.tsv', 'SELECT * FROM TEST', 'charset=UTF-8 fieldSeparator=' || CHAR(9));
+"
+
+"Functions (System)","DATABASE","
+DATABASE()
+","
+Returns the name of the database.
+","
+CALL DATABASE();
+"
+
+"Functions (System)","DATABASE_PATH","
+DATABASE_PATH()
+","
+Returns the directory of the database files and the database name, if it is file based.
+Returns NULL otherwise.
+","
+CALL DATABASE_PATH();
+"
+
+"Functions (System)","DECODE","
+DECODE(value, whenValue, thenValue [,...])
+","
+Returns the first matching value. NULL is considered to match NULL.
+If no match was found, then NULL or the last parameter (if the parameter count is even) is returned.
+This function is provided for Oracle compatibility (see there for details).
+","
+CALL DECODE(RAND()>0.5, 0, 'Red', 1, 'Black');
+"
+
+"Functions (System)","DISK_SPACE_USED","
+DISK_SPACE_USED(tableNameString)
+","
+Returns the approximate amount of space used by the table specified.
+Does not currently take into account indexes or LOB's.
+This function may be expensive since it has to load every page in the table.
+","
+CALL DISK_SPACE_USED('my_table');
+"
+
+"Functions (System)","SIGNAL","
+SIGNAL(sqlStateString, messageString)
+","
+Throw an SQLException with the passed SQLState and reason.
+","
+CALL SIGNAL('23505', 'Duplicate user ID: ' || user_id);
+"
+
+"Functions (System)","ESTIMATED_ENVELOPE","
+ESTIMATED_ENVELOPE(tableNameString, columnNameString)
+","
+Returns the estimated minimum bounding box that encloses all specified GEOMETRY values.
+Only 2D coordinate plane is supported.
+NULL values are ignored.
+This function is only supported by MVStore engine.
+Column must have a spatial index.
+This function is fast, but estimation may include uncommitted data (including data from other transactions),
+may return approximate bounds, or be different with actual value due to other reasons.
+Use with caution.
+If estimation is not available this function returns NULL.
+For accurate and reliable result use ESTIMATE aggregate function instead.
+","
+CALL ESTIMATED_ENVELOPE('MY_TABLE', 'GEOMETRY_COLUMN');
+"
+
+"Functions (System)","FILE_READ","
+FILE_READ(fileNameString [,encodingString])
+","
+Returns the contents of a file. If only one parameter is supplied, the data are
+returned as a BLOB. If two parameters are used, the data is returned as a CLOB
+(text). The second parameter is the character set to use, NULL meaning the
+default character set for this system.
+
+File names and URLs are supported.
+To read a stream from the classpath, use the prefix ""classpath:"".
+
+Admin rights are required to execute this command.
+","
+SELECT LENGTH(FILE_READ('~/.h2.server.properties')) LEN;
+SELECT FILE_READ('http://localhost:8182/stylesheet.css', NULL) CSS;
+"
+
+"Functions (System)","FILE_WRITE","
+FILE_WRITE(blobValue, fileNameString)
+","
+Write the supplied parameter into a file. Return the number of bytes written.
+
+Write access to folder, and admin rights are required to execute this command.
+","
+SELECT FILE_WRITE('Hello world', '/tmp/hello.txt')) LEN;
+"
+
+"Functions (System)","GREATEST","
+GREATEST(aValue, bValue [,...])
+","
+Returns the largest value that is not NULL, or NULL if all values are NULL.
+","
+CALL GREATEST(1, 2, 3);
+"
+
+"Functions (System)","IDENTITY","
+IDENTITY()
+","
+Returns the last inserted identity value for this session.
+This value changes whenever a new sequence number was generated,
+even within a trigger or Java function. See also SCOPE_IDENTITY.
+This method returns a long.
+","
+CALL IDENTITY();
+"
+
+"Functions (System)","IFNULL","
+IFNULL(aValue, bValue)
+","
+Returns the value of 'a' if it is not null, otherwise 'b'.
+","
+CALL IFNULL(NULL, '');
+"
+
+"Functions (System)","LEAST","
+LEAST(aValue, bValue [,...])
+","
+Returns the smallest value that is not NULL, or NULL if all values are NULL.
+","
+CALL LEAST(1, 2, 3);
+"
+
+"Functions (System)","LOCK_MODE","
+LOCK_MODE()
+","
+Returns the current lock mode. See SET LOCK_MODE.
+This method returns an int.
+","
+CALL LOCK_MODE();
+"
+
+"Functions (System)","LOCK_TIMEOUT","
+LOCK_TIMEOUT()
+","
+Returns the lock timeout of the current session (in milliseconds).
+","
+LOCK_TIMEOUT()
+"
+
+"Functions (System)","LINK_SCHEMA","
+LINK_SCHEMA(targetSchemaString, driverString, urlString,
+userString, passwordString, sourceSchemaString)
+","
+Creates table links for all tables in a schema.
+If tables with the same name already exist, they are dropped first.
+The target schema is created automatically if it does not yet exist.
+The driver name may be empty if the driver is already loaded.
+The list of tables linked is returned in the form of a result set.
+Admin rights are required to execute this command.
+","
+CALL LINK_SCHEMA('TEST2', '', 'jdbc:h2:test2', 'sa', 'sa', 'PUBLIC');
+"
+
+"Functions (System)","MEMORY_FREE","
+MEMORY_FREE()
+","
+Returns the free memory in KB (where 1024 bytes is a KB).
+This method returns an int.
+The garbage is run before returning the value.
+Admin rights are required to execute this command.
+","
+MEMORY_FREE()
+"
+
+"Functions (System)","MEMORY_USED","
+MEMORY_USED()
+","
+Returns the used memory in KB (where 1024 bytes is a KB).
+This method returns an int.
+The garbage is run before returning the value.
+Admin rights are required to execute this command.
+","
+MEMORY_USED()
+"
+
+"Functions (System)","NEXTVAL","
+NEXTVAL ( [ schemaName, ] sequenceString )
+","
+Returns the next value of the sequence.
+Used values are never re-used, even when the transaction is rolled back.
+If the schema name is not set, the current schema is used, and the sequence name is converted to uppercase (for compatibility).
+This method returns a long.
+","
+NEXTVAL('TEST_SEQ')
+"
+
+"Functions (System)","NULLIF","
+NULLIF(aValue, bValue)
+","
+Returns NULL if 'a' is equals to 'b', otherwise 'a'.
+","
+NULLIF(A, B)
+"
+
+"Functions (System)","NVL2","
+NVL2(testValue, aValue, bValue)
+","
+If the test value is null, then 'b' is returned. Otherwise, 'a' is returned.
+The data type of the returned value is the data type of 'a' if this is a text type.
+","
+NVL2(X, 'not null', 'null')
+"
+
+"Functions (System)","READONLY","
+READONLY()
+","
+Returns true if the database is read-only.
+","
+READONLY()
+"
+
+"Functions (System)","ROWNUM","
+ROWNUM()
+","
+Returns the number of the current row.
+This method returns a long value.
+It is supported for SELECT statements, as well as for DELETE and UPDATE.
+The first row has the row number 1, and is calculated before ordering and grouping the result set,
+but after evaluating index conditions (even when the index conditions are specified in an outer query).
+Use the ROW_NUMBER() OVER () function to get row numbers after grouping or in specified order.
+","
+SELECT ROWNUM(), * FROM TEST;
+SELECT ROWNUM(), * FROM (SELECT * FROM TEST ORDER BY NAME);
+SELECT ID FROM (SELECT T.*, ROWNUM AS R FROM TEST T) WHERE R BETWEEN 2 AND 3;
+"
+
+"Functions (System)","SCHEMA","
+SCHEMA()
+","
+Returns the name of the default schema for this session.
+","
+CALL SCHEMA()
+"
+
+"Functions (System)","SCOPE_IDENTITY","
+SCOPE_IDENTITY()
+","
+Returns the last inserted identity value for this session for the current scope
+(the current statement).
+Changes within triggers and Java functions are ignored. See also IDENTITY().
+This method returns a long.
+","
+CALL SCOPE_IDENTITY();
+"
+
+"Functions (System)","SESSION_ID","
+SESSION_ID()
+","
+Returns the unique session id number for the current database connection.
+This id stays the same while the connection is open.
+This method returns an int.
+The database engine may re-use a session id after the connection is closed.
+","
+CALL SESSION_ID()
+"
+
+"Functions (System)","SET","
+SET(@variableName, value)
+","
+Updates a variable with the given value.
+The new value is returned.
+When used in a query, the value is updated in the order the rows are read.
+When used in a subquery, not all rows might be read depending on the query plan.
+This can be used to implement running totals / cumulative sums.
+","
+SELECT X, SET(@I, IFNULL(@I, 0)+X) RUNNING_TOTAL FROM SYSTEM_RANGE(1, 10)
+"
+
+"Functions (System)","TABLE","
+{ TABLE | TABLE_DISTINCT }
+( { name dataType = array|rowValueExpression } [,...] )
+","
+Returns the result set. TABLE_DISTINCT removes duplicate rows.
+","
+SELECT * FROM TABLE(VALUE INT = ARRAY[1, 2]);
+SELECT * FROM TABLE(ID INT=(1, 2), NAME VARCHAR=('Hello', 'World'));
+"
+
+"Functions (System)","TRANSACTION_ID","
+TRANSACTION_ID()
+","
+Returns the current transaction id for this session.
+This method returns NULL if there is no uncommitted change, or if the database is not persisted.
+Otherwise a value of the following form is returned:
+""logFileId-position-sessionId"".
+This method returns a string.
+The value is unique across database restarts (values are not re-used).
+","
+CALL TRANSACTION_ID()
+"
+
+"Functions (System)","TRUNCATE_VALUE","
+TRUNCATE_VALUE(value, precisionInt, forceBoolean)
+","
+Truncate a value to the required precision.
+The precision of the returned value may be a bit larger than requested,
+because fixed precision values are not truncated (unlike the numeric TRUNCATE method).
+Unlike CAST, the truncating a decimal value may lose precision if the force flag is set to true.
+The method returns a value with the same data type as the first parameter.
+","
+CALL TRUNCATE_VALUE(X, 10, TRUE);
+"
+
+"Functions (System)","UNNEST","
+UNNEST(array, [,...]) [WITH ORDINALITY]
+","
+Returns the result set.
+Number of columns is equal to number of arguments,
+plus one additional column with row number if WITH ORDINALITY is specified.
+Number of rows is equal to length of longest specified array.
+If multiple arguments are specified and they have different length, cells with missing values will contain null values.
+","
+SELECT * FROM UNNEST(ARRAY['a', 'b', 'c']);
+"
+
+"Functions (System)","USER","
+{ USER | CURRENT_USER } ()
+","
+Returns the name of the current user of this session.
+","
+CURRENT_USER()
+"
+
+"Functions (System)","H2VERSION","
+H2VERSION()
+","
+Returns the H2 version as a String.
+","
+H2VERSION()
+"
+
+"Functions (Window)","ROW_NUMBER","
+ROW_NUMBER() OVER windowNameOrSpecification
+","
+Returns the number of the current row starting with 1.
+Window frame clause is not allowed for this function.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT ROW_NUMBER() OVER (), * FROM TEST;
+SELECT ROW_NUMBER() OVER (ORDER BY ID), * FROM TEST;
+SELECT ROW_NUMBER() OVER (PARTITION BY CATEGORY ORDER BY ID), * FROM TEST;
+"
+
+"Functions (Window)","RANK","
+RANK() OVER windowNameOrSpecification
+","
+Returns the rank of the current row.
+The rank of a row is the number of rows that precede this row plus 1.
+If two or more rows have the same values in ORDER BY columns, these rows get the same rank from the first row with the same values.
+It means that gaps in ranks are possible.
+This function requires window order clause.
+Window frame clause is not allowed for this function.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT RANK() OVER (ORDER BY ID), * FROM TEST;
+SELECT RANK() OVER (PARTITION BY CATEGORY ORDER BY ID), * FROM TEST;
+"
+
+"Functions (Window)","DENSE_RANK","
+DENSE_RANK() OVER windowNameOrSpecification
+","
+Returns the dense rank of the current row.
+The rank of a row is the number of groups of rows with the same values in ORDER BY columns that precede group with this row plus 1.
+If two or more rows have the same values in ORDER BY columns, these rows get the same rank.
+Gaps in ranks are not possible.
+This function requires window order clause.
+Window frame clause is not allowed for this function.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT DENSE_RANK() OVER (ORDER BY ID), * FROM TEST;
+SELECT DENSE_RANK() OVER (PARTITION BY CATEGORY ORDER BY ID), * FROM TEST;
+"
+
+"Functions (Window)","PERCENT_RANK","
+PERCENT_RANK() OVER windowNameOrSpecification
+","
+Returns the relative rank of the current row.
+The relative rank is calculated as (RANK - 1) / (NR - 1),
+where RANK is a rank of the row and NR is a number of rows in window partition with this row.
+Note that result is always 0 if window order clause is not specified.
+Window frame clause is not allowed for this function.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT PERCENT_RANK() OVER (ORDER BY ID), * FROM TEST;
+SELECT PERCENT_RANK() OVER (PARTITION BY CATEGORY ORDER BY ID), * FROM TEST;
+"
+
+"Functions (Window)","CUME_DIST","
+CUME_DIST() OVER windowNameOrSpecification
+","
+Returns the relative rank of the current row.
+The relative rank is calculated as NP / NR
+where NP is a number of rows that precede the current row or have the same values in ORDER BY columns
+and NR is a number of rows in window partition with this row.
+Note that result is always 1 if window order clause is not specified.
+Window frame clause is not allowed for this function.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT CUME_DIST() OVER (ORDER BY ID), * FROM TEST;
+SELECT CUME_DIST() OVER (PARTITION BY CATEGORY ORDER BY ID), * FROM TEST;
+"
+
+"Functions (Window)","NTILE","
+NTILE(long) OVER windowNameOrSpecification
+","
+Distributes the rows into a specified number of groups.
+Number of groups should be a positive long value.
+NTILE returns the 1-based number of the group to which the current row belongs.
+First groups will have more rows if number of rows is not divisible by number of groups.
+For example, if 5 rows are distributed into 2 groups this function returns 1 for the first 3 row and 2 for the last 2 rows.
+This function requires window order clause.
+Window frame clause is not allowed for this function.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT NTILE(10) OVER (ORDER BY ID), * FROM TEST;
+SELECT NTILE(5) OVER (PARTITION BY CATEGORY ORDER BY ID), * FROM TEST;
+"
+
+"Functions (Window)","LEAD","
+LEAD(value [, offsetInt [, defaultValue]]) [{RESPECT|IGNORE} NULLS]
+OVER windowNameOrSpecification
+","
+Returns the value in a next row with specified offset relative to the current row.
+Offset must be non-negative.
+If IGNORE NULLS is specified rows with null values in selected expression are skipped.
+If number of considered rows is less than specified relative number this function returns NULL
+or the specified default value, if any.
+If offset is 0 the value from the current row is returned unconditionally.
+This function requires window order clause.
+Window frame clause is not allowed for this function.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT LEAD(X) OVER (ORDER BY ID), * FROM TEST;
+SELECT LEAD(X, 2, 0) IGNORE NULLS OVER (
+    PARTITION BY CATEGORY ORDER BY ID
+), * FROM TEST;
+"
+
+"Functions (Window)","LAG","
+LAG(value [, offsetInt [, defaultValue]]) [{RESPECT|IGNORE} NULLS]
+OVER windowNameOrSpecification
+","
+Returns the value in a previous row with specified offset relative to the current row.
+Offset must be non-negative.
+If IGNORE NULLS is specified rows with null values in selected expression are skipped.
+If number of considered rows is less than specified relative number this function returns NULL
+or the specified default value, if any.
+If offset is 0 the value from the current row is returned unconditionally.
+This function requires window order clause.
+Window frame clause is not allowed for this function.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT LAG(X) OVER (ORDER BY ID), * FROM TEST;
+SELECT LAG(X, 2, 0) IGNORE NULLS OVER (
+    PARTITION BY CATEGORY ORDER BY ID
+), * FROM TEST;
+"
+
+"Functions (Window)","FIRST_VALUE","
+FIRST_VALUE(value) [{RESPECT|IGNORE} NULLS]
+OVER windowNameOrSpecification
+","
+Returns the first value in a window.
+If IGNORE NULLS is specified null values are skipped and the function returns first non-null value, if any.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT FIRST_VALUE(X) OVER (ORDER BY ID), * FROM TEST;
+SELECT FIRST_VALUE(X) IGNORE NULLS OVER (PARTITION BY CATEGORY ORDER BY ID), * FROM TEST;
+"
+
+"Functions (Window)","LAST_VALUE","
+LAST_VALUE(value) [{RESPECT|IGNORE} NULLS]
+OVER windowNameOrSpecification
+","
+Returns the last value in a window.
+If IGNORE NULLS is specified null values are skipped and the function returns last non-null value before them, if any;
+if there is no non-null value it returns NULL.
+Note that the last value is actually a value in the current group of rows
+if window order clause is specified and window frame clause is not specified.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT LAST_VALUE(X) OVER (ORDER BY ID), * FROM TEST;
+SELECT LAST_VALUE(X) IGNORE NULLS OVER (
+    PARTITION BY CATEGORY ORDER BY ID
+    RANGE BETWEEN CURRENT ROW AND UNBOUNDED FOLLOWING
+), * FROM TEST;
+"
+
+"Functions (Window)","NTH_VALUE","
+NTH_VALUE(value, nInt) [FROM {FIRST|LAST}] [{RESPECT|IGNORE} NULLS]
+OVER windowNameOrSpecification
+","
+Returns the value in a row with a specified relative number in a window.
+Relative row number must be positive.
+If FROM LAST is specified rows a counted backwards from the last row.
+If IGNORE NULLS is specified rows with null values in selected expression are skipped.
+If number of considered rows is less than specified relative number this function returns NULL.
+Note that the last row is actually a last row in the current group of rows
+if window order clause is specified and window frame clause is not specified.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT NTH_VALUE(X) OVER (ORDER BY ID), * FROM TEST;
+SELECT NTH_VALUE(X) IGNORE NULLS OVER (
+    PARTITION BY CATEGORY ORDER BY ID
+    RANGE BETWEEN UNBOUNDED PRECEDING AND UNBOUNDED FOLLOWING
+), * FROM TEST;
+"
+
+"Functions (Window)","RATIO_TO_REPORT","
+RATIO_TO_REPORT(value)
+OVER windowNameOrSpecification
+","
+Returns the ratio of a value to the sum of all values.
+If argument is NULL or sum of all values is 0, then the value of function is NULL.
+Window ordering and window frame clauses are not allowed for this function.
+
+Window functions in H2 may require a lot of memory for large queries.
+","
+SELECT X, RATIO_TO_REPORT(X) OVER (PARTITION BY CATEGORY), CATEGORY FROM TEST;
+"
+
+"System Tables","Information Schema","
+INFORMATION_SCHEMA
+","
+To get the list of system tables, execute the statement SELECT * FROM
+INFORMATION_SCHEMA.TABLES WHERE TABLE_SCHEMA = 'INFORMATION_SCHEMA'
+","
+
+"
+"System Tables","Range Table","
+SYSTEM_RANGE(start, end)
+","
+Contains all values from start to end (this is a dynamic table).
+","
+SYSTEM_RANGE(0, 100)
+"
diff --git a/modules/h2/src/docsrc/html/advanced.html b/modules/h2/src/docsrc/html/advanced.html
new file mode 100644
index 0000000..c1d0501
--- /dev/null
+++ b/modules/h2/src/docsrc/html/advanced.html
@@ -0,0 +1,1968 @@
+<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
+<!--
+Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
+and the EPL 1.0 (http://h2database.com/html/license.html).
+Initial Developer: H2 Group
+-->
+<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
+<head>
+<meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
+<meta name="viewport" content="width=device-width, initial-scale=1" />
+<title>
+Advanced
+</title>
+<link rel="stylesheet" type="text/css" href="stylesheet.css" />
+<!-- [search] { -->
+<script type="text/javascript" src="navigation.js"></script>
+</head><body onload="frameMe();">
+<table class="content"><tr class="content"><td class="content"><div class="contentDiv">
+<!-- } -->
+
+<h1>Advanced</h1>
+<a href="#result_sets">
+    Result Sets</a><br />
+<a href="#large_objects">
+    Large Objects</a><br />
+<a href="#linked_tables">
+    Linked Tables</a><br />
+<a href="#spatial_features">
+    Spatial Features</a><br />
+<a href="#recursive_queries">
+    Recursive Queries</a><br />
+<a href="#updatable_views">
+    Updatable Views</a><br />
+<a href="#transaction_isolation">
+    Transaction Isolation</a><br />
+<a href="#mvcc">
+    Multi-Version Concurrency Control (MVCC)</a><br />
+<a href="#clustering">
+    Clustering / High Availability</a><br />
+<a href="#two_phase_commit">
+    Two Phase Commit</a><br />
+<a href="#compatibility">
+    Compatibility</a><br />
+<a href="#keywords">
+    Keywords / Reserved Words</a><br />
+<a href="#standards_compliance">
+    Standards Compliance</a><br />
+<a href="#windows_service">
+    Run as Windows Service</a><br />
+<a href="#odbc_driver">
+    ODBC Driver</a><br />
+<a href="#microsoft_dot_net">
+    Using H2 in Microsoft .NET</a><br />
+<a href="#acid">
+    ACID</a><br />
+<a href="#durability_problems">
+    Durability Problems</a><br />
+<a href="#using_recover_tool">
+    Using the Recover Tool</a><br />
+<a href="#file_locking_protocols">
+    File Locking Protocols</a><br />
+<a href="#passwords">
+    Using Passwords</a><br />
+<a href="#password_hash">
+    Password Hash</a><br />
+<a href="#sql_injection">
+    Protection against SQL Injection</a><br />
+<a href="#remote_access">
+    Protection against Remote Access</a><br />
+<a href="#restricting_classes">
+    Restricting Class Loading and Usage</a><br />
+<a href="#security_protocols">
+    Security Protocols</a><br />
+<a href="#tls_connections">
+    TLS Connections</a><br />
+<a href="#uuid">
+    Universally Unique Identifiers (UUID)</a><br />
+<a href="#system_properties">
+    Settings Read from System Properties</a><br />
+<a href="#server_bind_address">
+    Setting the Server Bind Address</a><br />
+<a href="#file_system">
+    Pluggable File System</a><br />
+<a href="#file_system_split">
+    Split File System</a><br />
+<a href="#database_upgrade">
+    Database Upgrade</a><br />
+<a href="#java_objects_serialization">
+    Java Objects Serialization</a><br />
+<a href="#custom_data_types_handler_api">
+    Custom Data Types Handler API</a><br />
+<a href="#limits_limitations">
+    Limits and Limitations</a><br />
+<a href="#glossary_links">
+    Glossary and Links</a><br />
+
+<h2 id="result_sets">Result Sets</h2>
+
+<h3>Statements that Return a Result Set</h3>
+<p>
+The following statements return a result set: <code>SELECT, EXPLAIN, CALL, SCRIPT, SHOW, HELP</code>.
+All other statements return an update count.
+</p>
+
+<h3>Limiting the Number of Rows</h3>
+<p>
+Before the result is returned to the application, all rows are read by the database.
+Server side cursors are not supported currently.
+If only the first few rows are interesting for the application, then the
+result set size should be limited to improve the performance.
+This can be done using <code>FETCH</code> in a query
+(example: <code>SELECT * FROM TEST FETCH FIRST 100 ROWS ONLY</code>),
+or by using <code>Statement.setMaxRows(max)</code>.
+</p>
+
+<h3>Large Result Sets and External Sorting</h3>
+<p>
+For large result set, the result is buffered to disk. The threshold can be defined using the statement
+<code>SET MAX_MEMORY_ROWS</code>.
+If <code>ORDER BY</code> is used, the sorting is done using an
+external sort algorithm.
+In this case, each block of rows is sorted using quick sort, then written to disk;
+when reading the data, the blocks are merged together.
+</p>
+
+<h2 id="large_objects">Large Objects</h2>
+
+<h3>Storing and Reading Large Objects</h3>
+<p>
+If it is possible that the objects don't fit into memory, then the data type
+CLOB (for textual data) or BLOB (for binary data) should be used.
+For these data types, the objects are not fully read into memory, by using streams.
+To store a BLOB, use <code>PreparedStatement.setBinaryStream</code>. To store a CLOB, use
+<code>PreparedStatement.setCharacterStream</code>. To read a BLOB, use <code>ResultSet.getBinaryStream</code>,
+and to read a CLOB, use <code>ResultSet.getCharacterStream</code>.
+When using the client/server mode, large BLOB and CLOB data is stored in a temporary file
+on the client side.
+</p>
+
+<h3>When to use CLOB/BLOB</h3>
+<p>
+By default, this database stores large LOB (CLOB and BLOB) objects separate from the main table data.
+Small LOB objects are stored in-place, the threshold can be set using
+<a href="commands.html#set_max_length_inplace_lob" class="notranslate" >MAX_LENGTH_INPLACE_LOB</a>,
+but there is still an overhead to use CLOB/BLOB. Because of this, BLOB and CLOB
+should never be used for columns with a maximum size below about 200 bytes.
+The best threshold depends on the use case; reading in-place objects is faster
+than reading from separate files, but slows down the performance of operations
+that don't involve this column.
+</p>
+
+<h3>Large Object Compression</h3>
+<p>
+The following feature is only available for the PageStore storage engine.
+For the MVStore engine (the default for H2 version 1.4.x),
+append <code>;COMPRESS=TRUE</code> to the database URL instead.
+CLOB and BLOB values can be compressed by using
+<a href="commands.html#set_compress_lob" class="notranslate" >SET COMPRESS_LOB</a>.
+The LZF algorithm is faster but needs more disk space. By default compression is disabled, which usually speeds up write
+operations. If you store many large compressible values such as XML, HTML, text, and uncompressed binary files,
+then compressing can save a lot of disk space (sometimes more than 50%), and read operations may even be faster.
+</p>
+
+<h2 id="linked_tables">Linked Tables</h2>
+<p>
+This database supports linked tables, which means tables that don't exist in the current database but
+are just links to another database. To create such a link, use the
+<code>CREATE LINKED TABLE</code> statement:
+</p>
+<pre>
+CREATE LINKED TABLE LINK('org.postgresql.Driver', 'jdbc:postgresql:test', 'sa', 'sa', 'TEST');
+</pre>
+<p>
+You can then access the table in the usual way.
+Whenever the linked table is accessed, the database issues specific queries over JDBC.
+Using the example above, if you issue the query <code>SELECT * FROM LINK WHERE ID=1</code>,
+then the following query is run against the PostgreSQL database: <code>SELECT * FROM TEST WHERE ID=?</code>.
+The same happens for insert and update statements.
+Only simple statements are executed against the target database, that means no joins
+(queries that contain joins are converted to simple queries).
+Prepared statements are used where possible.
+</p>
+<p>
+To view the statements that are executed against the target table, set the trace level to 3.
+</p>
+<p>
+If multiple linked tables point to the same database (using the same database URL), the connection
+is shared. To disable this, set the system property <code>h2.shareLinkedConnections=false</code>.
+</p>
+<p>
+The statement <a href="commands.html#create_linked_table" class="notranslate" >CREATE LINKED TABLE</a>
+supports an optional schema name parameter.
+</p>
+<p>
+The following are not supported because they may result in a deadlock:
+creating a linked table to the same database,
+and creating a linked table to another database using the server mode if the other database is open in the same server
+(use the embedded mode instead).
+</p>
+<p>
+Data types that are not supported in H2 are also not supported for linked tables,
+for example unsigned data types if the value is outside the range of the signed type.
+In such cases, the columns needs to be cast to a supported type.
+</p>
+
+<h2 id="updatable_views">Updatable Views</h2>
+<p>
+By default, views are not updatable.
+To make a view updatable, use an "instead of" trigger as follows:
+</p>
+<pre>
+CREATE TRIGGER TRIGGER_NAME
+INSTEAD OF INSERT, UPDATE, DELETE
+ON VIEW_NAME
+FOR EACH ROW CALL "com.acme.TriggerClassName";
+</pre>
+<p>
+Update the base table(s) within the trigger as required.
+For details, see the sample application <code>org.h2.samples.UpdatableView</code>.
+</p>
+
+<h2 id="transaction_isolation">Transaction Isolation</h2>
+<p>
+Please note that most data definition language (DDL) statements,
+such as "create table", commit the current transaction.
+See the <a href="commands.html">Commands</a> for details.
+</p>
+<p>
+Transaction isolation is provided for all data manipulation language (DML) statements.
+</p>
+<p>
+Please note that with default MVStore storage engine table level locking is not used.
+Instead, rows are locked for update, and read committed is used in all cases
+except for explicitly selected read uncommitted transaction isolation level.
+</p>
+<p>
+This database supports the following transaction isolation levels:
+</p>
+<ul>
+<li><b>Read Committed</b><br />
+    This is the default level.
+    Read locks are released immediately after executing the statement, but write locks are kept until the transaction commits.
+    Higher concurrency is possible when using this level.<br />
+    To enable, execute the SQL statement <code>SET LOCK_MODE 3</code><br />
+    or append <code>;LOCK_MODE=3</code> to the database URL: <code>jdbc:h2:~/test;LOCK_MODE=3</code>
+</li><li>
+<b>Serializable</b><br />
+    Both read locks and write locks are kept until the transaction commits.
+    To enable, execute the SQL statement <code>SET LOCK_MODE 1</code><br />
+    or append <code>;LOCK_MODE=1</code> to the database URL: <code>jdbc:h2:~/test;LOCK_MODE=1</code>
+</li><li><b>Read Uncommitted</b><br />
+    This level means that transaction isolation is disabled.
+    This level is not supported by PageStore engine if multi-threaded mode is enabled.
+    <br />
+    To enable, execute the SQL statement <code>SET LOCK_MODE 0</code><br />
+    or append <code>;LOCK_MODE=0</code> to the database URL: <code>jdbc:h2:~/test;LOCK_MODE=0</code>
+</li>
+</ul>
+<p>
+When using the isolation level 'serializable', dirty reads, non-repeatable reads, and phantom reads are prohibited.
+</p>
+<ul>
+<li><b>Dirty Reads</b><br />
+    Means a connection can read uncommitted changes made by another connection.<br />
+    Possible with: read uncommitted
+</li><li><b>Non-Repeatable Reads</b><br />
+    A connection reads a row, another connection changes a row and commits,
+    and the first connection re-reads the same row and gets the new result.<br />
+    Possible with: read uncommitted, read committed
+</li><li><b>Phantom Reads</b><br />
+    A connection reads a set of rows using a condition, another connection
+    inserts a row that falls in this condition and commits, then the first connection
+    re-reads using the same condition and gets the new row.<br />
+    Possible with: read uncommitted, read committed
+</li>
+</ul>
+
+<h3 id="mvcc">Multi-Version Concurrency Control (MVCC)</h3>
+<p>
+With default MVStore engine delete, insert and update operations only issue a shared lock on the table.
+An exclusive lock is still used when adding or removing columns or when dropping the table.
+Connections only 'see' committed data, and own changes. That means, if connection A updates
+a row but doesn't commit this change yet, connection B will see the old value.
+Only when the change is committed, the new value is visible by other connections
+(read committed). If multiple connections concurrently try to lock or update the same row, the
+database waits until it can apply the change, but at most until the lock timeout expires.
+</p>
+
+<h3>Table Level Locking (PageStore engine)</h3>
+<p>
+With PageStore engine to make sure all connections only see consistent data, table level locking is used.
+This mechanism does not allow high concurrency, but is very fast.
+Shared locks and exclusive locks are supported.
+Before reading from a table, the database tries to add a shared lock to the table
+(this is only possible if there is no exclusive lock on the object by another connection).
+If the shared lock is added successfully, the table can be read. It is allowed that
+other connections also have a shared lock on the same object. If a connection wants
+to write to a table (update or delete a row), an exclusive lock is required. To get the
+exclusive lock, other connection must not have any locks on the object. After the
+connection commits, all locks are released.
+This database keeps all locks in memory.
+When a lock is released, and multiple connections are waiting for it, one of them is picked at random.
+</p>
+
+<h3>Lock Timeout</h3>
+<p>
+If a connection cannot get a lock on an object, the connection waits for some amount
+of time (the lock timeout). During this time, hopefully the connection holding the
+lock commits and it is then possible to get the lock. If this is not possible because
+the other connection does not release the lock for some time, the unsuccessful
+connection will get a lock timeout exception. The lock timeout can be set individually
+for each connection.
+</p>
+
+<h2 id="clustering">Clustering / High Availability</h2>
+<p>
+This database supports a simple clustering / high availability mechanism. The architecture is:
+two database servers run on two different computers, and on both computers is a copy of the
+same database. If both servers run, each database operation is executed on both computers.
+If one server fails (power, hardware or network failure), the other server can still continue to work.
+From this point on, the operations will be executed only on one server until the other server
+is back up.
+</p><p>
+Clustering can only be used in the server mode (the embedded mode does not support clustering).
+The cluster can be re-created using the <code>CreateCluster</code> tool without stopping
+the remaining server. Applications that are still connected are automatically disconnected,
+however when appending <code>;AUTO_RECONNECT=TRUE</code>, they will recover from that.
+</p><p>
+To initialize the cluster, use the following steps:
+</p>
+<ul>
+<li>Create a database
+</li><li>Use the <code>CreateCluster</code> tool to copy the database to
+    another location and initialize the clustering.
+    Afterwards, you have two databases containing the same data.
+</li><li>Start two servers (one for each copy of the database)
+</li><li>You are now ready to connect to the databases with the client application(s)
+</li></ul>
+
+<h3>Using the CreateCluster Tool</h3>
+<p>
+To understand how clustering works, please try out the following example.
+In this example, the two databases reside on the same computer, but usually, the
+databases will be on different servers.
+</p>
+<ul>
+<li>Create two directories: <code>server1, server2</code>.
+    Each directory will simulate a directory on a computer.
+</li><li>Start a TCP server pointing to the first directory.
+    You can do this using the command line:
+<pre>
+java org.h2.tools.Server
+    -tcp -tcpPort 9101
+    -baseDir server1
+</pre>
+</li><li>Start a second TCP server pointing to the second directory.
+    This will simulate a server running on a second (redundant) computer.
+    You can do this using the command line:
+<pre>
+java org.h2.tools.Server
+    -tcp -tcpPort 9102
+    -baseDir server2
+</pre>
+</li><li>Use the <code>CreateCluster</code> tool to initialize clustering.
+    This will automatically create a new, empty database if it does not exist.
+    Run the tool on the command line:
+<pre>
+java org.h2.tools.CreateCluster
+    -urlSource jdbc:h2:tcp://localhost:9101/~/test
+    -urlTarget jdbc:h2:tcp://localhost:9102/~/test
+    -user sa
+    -serverList localhost:9101,localhost:9102
+</pre>
+</li><li>You can now connect to the databases using
+an application or the H2 Console using the JDBC URL
+<code>jdbc:h2:tcp://localhost:9101,localhost:9102/~/test</code>
+</li><li>If you stop a server (by killing the process),
+you will notice that the other machine continues to work,
+and therefore the database is still accessible.
+</li><li>To restore the cluster, you first need to delete the
+database that failed, then restart the server that was stopped,
+and re-run the <code>CreateCluster</code> tool.
+</li></ul>
+
+<h3>Detect Which Cluster Instances are Running</h3>
+<p>
+To find out which cluster nodes are currently running, execute the following SQL statement:
+</p>
+<pre>
+SELECT VALUE FROM INFORMATION_SCHEMA.SETTINGS WHERE NAME='CLUSTER'
+</pre>
+<p>
+If the result is <code>''</code> (two single quotes), then the cluster mode is disabled. Otherwise, the list of
+servers is returned, enclosed in single quote. Example: <code>'server1:9191,server2:9191'</code>.
+</p>
+
+<p>
+It is also possible to get the list of servers by using Connection.getClientInfo().
+</p>
+
+<p>
+The property list returned from <code>getClientInfo()</code> contains a <code>numServers</code> property that returns the
+number of servers that are in the connection list. To get the actual servers, <code>getClientInfo()</code> also has
+properties <code>server0</code>..<code>serverX</code>, where serverX is the number of servers minus 1.
+</p>
+
+<p>
+Example: To get the 2nd server in the connection list one uses <code>getClientInfo('server1')</code>.
+<b>Note:</b> The <code>serverX</code> property only returns IP addresses and ports and not hostnames.
+</p>
+
+<h3>Clustering Algorithm and Limitations</h3>
+<p>
+Read-only queries are only executed against the first cluster node, but all other statements are
+executed against all nodes. There is currently no load balancing made to avoid problems with
+transactions. The following functions may yield different results on different cluster nodes and must be
+executed with care: <code>UUID(), RANDOM_UUID(), SECURE_RAND(), SESSION_ID(),
+MEMORY_FREE(), MEMORY_USED(), CSVREAD(), CSVWRITE(), RAND()</code> [when not using a seed].
+Those functions should not be used directly in modifying statements
+(for example <code>INSERT, UPDATE, MERGE</code>). However, they can be used
+in read-only statements and the result can then be used for modifying statements.
+Using auto-increment and identity columns is currently not supported.
+Instead, sequence values need to be manually requested and then used to insert data (using two statements).
+</p>
+<p>
+When using the cluster modes, result sets are read fully in memory by the client, so that
+there is no problem if the server dies that executed the query. Result sets must fit in memory
+on the client side.
+</p>
+<p>
+The SQL statement <code>SET AUTOCOMMIT FALSE</code> is not supported in the cluster mode.
+To disable autocommit, the method <code>Connection.setAutoCommit(false)</code> needs to be called.
+</p>
+<p>
+It is possible that a transaction from one connection overtakes a transaction from a different connection.
+Depending on the operations, this might result in different results, for example when
+conditionally incrementing a value in a row.
+</p>
+
+<h2 id="two_phase_commit">Two Phase Commit</h2>
+<p>
+The two phase commit protocol is supported. 2-phase-commit works as follows:
+</p>
+<ul>
+<li>Autocommit needs to be switched off
+</li><li>A transaction is started, for example by inserting a row
+</li><li>The transaction is marked 'prepared' by executing the SQL statement
+    <code>PREPARE COMMIT transactionName</code>
+</li><li>The transaction can now be committed or rolled back
+</li><li>If a problem occurs before the transaction was successfully committed or rolled back
+    (for example because a network problem occurred), the transaction is in the state 'in-doubt'
+</li><li>When re-connecting to the database, the in-doubt transactions can be listed
+    with <code>SELECT * FROM INFORMATION_SCHEMA.IN_DOUBT</code>
+</li><li>Each transaction in this list must now be committed or rolled back by executing
+    <code>COMMIT TRANSACTION transactionName</code> or
+    <code>ROLLBACK TRANSACTION transactionName</code>
+</li><li>The database needs to be closed and re-opened to apply the changes
+</li></ul>
+
+<h2 id="compatibility">Compatibility</h2>
+<p>
+This database is (up to a certain point) compatible to other databases such as HSQLDB, MySQL and PostgreSQL.
+There are certain areas where H2 is incompatible.
+</p>
+
+<h3>Transaction Commit when Autocommit is On</h3>
+<p>
+At this time, this database engine commits a transaction (if autocommit is switched on) just before returning the result.
+For a query, this means the transaction is committed even before the application scans through the result set, and before the result set is closed.
+Other database engines may commit the transaction in this case when the result set is closed.
+</p>
+
+<h2 id="keywords">Keywords / Reserved Words</h2>
+<p>
+There is a list of keywords that can't be used as identifiers (table names, column names and so on),
+unless they are quoted (surrounded with double quotes).
+The following tokens are keywords in H2:
+</p>
+<table class="main">
+<thead>
+<tr>
+<th>Keyword</th>
+<th>H2</th>
+<th>SQL:&#8203;2011</th>
+<th>SQL:&#8203;2008</th>
+<th>SQL:&#8203;2003</th>
+<th>SQL:&#8203;1999</th>
+<th>SQL-92</th>
+</tr>
+</thead>
+<tbody>
+<tr><td>ALL</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>AND</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>ARRAY</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td></td></tr>
+<tr><td>AS</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>BETWEEN</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>NR</td><td>+</td></tr>
+<tr><td>BOTH</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>CASE</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>CHECK</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>CONSTRAINT</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>CROSS</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>CURRENT_DATE</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>CURRENT_TIME</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>CURRENT_TIMESTAMP</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>CURRENT_USER</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>DISTINCT</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>EXCEPT</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>EXISTS</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>NR</td><td>+</td></tr>
+<tr><td>FALSE</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>FETCH</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>FILTER</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td></td><td></td></tr>
+<tr><td>FOR</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>FOREIGN</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>FROM</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>FULL</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>GROUP</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>GROUPS</td>
+<td>CS</td><td>+</td><td></td><td></td><td></td><td></td></tr>
+<tr><td>HAVING</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>IF</td>
+<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>ILIKE</td>
+<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>IN</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>INNER</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>INTERSECT</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>INTERSECTS</td>
+<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>INTERVAL</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>IS</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>JOIN</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>LEADING</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>LEFT</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>LIKE</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>LIMIT</td>
+<td>+</td><td></td><td></td><td></td><td>+</td><td></td></tr>
+<tr><td>LOCALTIME</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td></td></tr>
+<tr><td>LOCALTIMESTAMP</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td></td></tr>
+<tr><td>MINUS</td>
+<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>NATURAL</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>NOT</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>NULL</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>OFFSET</td>
+<td>+</td><td>+</td><td>+</td><td></td><td></td><td></td></tr>
+<tr><td>ON</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>OR</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>ORDER</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>OVER</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td></td><td></td></tr>
+<tr><td>PARTITION</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td></td><td></td></tr>
+<tr><td>PRIMARY</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>QUALIFY</td>
+<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>RANGE</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td></td><td></td></tr>
+<tr><td>REGEXP</td>
+<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>RIGHT</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>ROW</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td></td></tr>
+<tr><td>_ROWID_</td>
+<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>ROWNUM</td>
+<td>+</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>ROWS</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>SELECT</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>SYSDATE</td>
+<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>SYSTIME</td>
+<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>SYSTIMESTAMP</td>
+<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>TABLE</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>TODAY</td>
+<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>TOP</td>
+<td>CS</td><td></td><td></td><td></td><td></td><td></td></tr>
+<tr><td>TRAILING</td>
+<td>CS</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>TRUE</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>UNION</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>UNIQUE</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>VALUES</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>WHERE</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+<tr><td>WINDOW</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td></td><td></td></tr>
+<tr><td>WITH</td>
+<td>+</td><td>+</td><td>+</td><td>+</td><td>+</td><td>+</td></tr>
+</tbody>
+</table>
+<p>
+Some keywords in H2 are context-sensitive (CS), such keywords may be used as identifiers in some places,
+but cannot be used as identifiers in others.
+Most keywords in H2 are also reserved (+) or non-reserved (NR) words in the SQL Standard.
+Newer versions of H2 may have more keywords than older ones.
+</p>
+
+<h2 id="standards_compliance">Standards Compliance</h2>
+<p>
+This database tries to be as much standard compliant as possible. For the SQL language, ANSI/ISO is the main
+standard. There are several versions that refer to the release date: SQL-92, SQL:1999, and SQL:2003.
+Unfortunately, the standard documentation is not freely available. Another problem is that important features
+are not standardized. Whenever this is the case, this database tries to be compatible to other databases.
+</p>
+
+<h3>Supported Character Sets, Character Encoding, and Unicode</h3>
+<p>
+H2 internally uses Unicode, and supports all character encoding systems and character sets supported by the virtual machine you use.
+</p>
+
+<h2 id="windows_service">Run as Windows Service</h2>
+<p>
+Using a native wrapper / adapter, Java applications can be run as a Windows Service.
+There are various tools available to do that. The Java Service Wrapper from
+<a href="https://wrapper.tanukisoftware.org">Tanuki Software, Inc.</a>
+is included in the installation. Batch files are provided to install, start, stop and uninstall the
+H2 Database Engine Service. This service contains the TCP Server and the H2 Console web application.
+The batch files are located in the directory <code>h2/service</code>.
+</p>
+<p>
+The service wrapper bundled with H2 is a 32-bit version.
+To use a 64-bit version of Windows (x64), you need to use a 64-bit version of the wrapper,
+for example the one from
+<a href="https://www.krenger.ch/blog/java-service-wrapper-3-5-14-for-windows-x64/">
+Simon Krenger</a>.
+</p>
+<p>
+When running the database as a service, absolute path should be used.
+Using <code>~</code> in the database URL is problematic in this case,
+because it means to use the home directory of the current user.
+The service might run without or with the wrong user, so that
+the database files might end up in an unexpected place.
+</p>
+
+<h3>Install the Service</h3>
+<p>
+The service needs to be registered as a Windows Service first.
+To do that, double click on <code>1_install_service.bat</code>.
+If successful, a command prompt window will pop up and disappear immediately. If not, a message will appear.
+</p>
+
+<h3>Start the Service</h3>
+<p>
+You can start the H2 Database Engine Service using the service manager of Windows,
+or by double clicking on <code>2_start_service.bat</code>.
+Please note that the batch file does not print an error message if the service is not installed.
+</p>
+
+<h3>Connect to the H2 Console</h3>
+<p>
+After installing and starting the service, you can connect to the H2 Console application using a browser.
+Double clicking on <code>3_start_browser.bat</code> to do that. The
+default port (8082) is hard coded in the batch file.
+</p>
+
+<h3>Stop the Service</h3>
+<p>
+To stop the service, double click on <code>4_stop_service.bat</code>.
+Please note that the batch file does not print an error message if the service is not installed or started.
+</p>
+
+<h3>Uninstall the Service</h3>
+<p>
+To uninstall the service, double click on <code>5_uninstall_service.bat</code>.
+If successful, a command prompt window will pop up and disappear immediately. If not, a message will appear.
+</p>
+
+<h3>Additional JDBC drivers</h3>
+<p>
+To use other databases (for example MySQL), the location of the JDBC drivers of those databases need to be
+added to the environment variables <code>H2DRIVERS</code>  or <code>CLASSPATH</code> before
+installing the service. Multiple drivers can be set; each entry needs to be separated with a <code>;</code>
+(Windows) or <code>:</code>  (other operating systems). Spaces in the path names are supported.
+The settings must not be quoted.
+</p>
+
+<h2 id="odbc_driver">ODBC Driver</h2>
+<p>
+This database does not come with its own ODBC driver at this time,
+but it supports the PostgreSQL network protocol.
+Therefore, the PostgreSQL ODBC driver can be used.
+Support for the PostgreSQL network protocol is quite new and should be viewed
+as experimental. It should not be used for production applications.
+</p>
+<p>
+To use the PostgreSQL ODBC driver on 64 bit versions of Windows,
+first run <code>c:/windows/syswow64/odbcad32.exe</code>.
+At this point you set up your DSN just like you would on any other system.
+See also:
+<a href="https://www.postgresql.org/message-id/dg76q0$khn$1@sea.gmane.org">Re: ODBC Driver on Windows 64 bit</a>
+</p>
+
+<h3>ODBC Installation</h3>
+<p>
+First, the ODBC driver must be installed.
+Any recent PostgreSQL ODBC driver should work, however version 8.2 (<code>psqlodbc-08_02*</code>) or newer is recommended.
+The Windows version of the PostgreSQL ODBC driver is available at
+<a href="https://www.postgresql.org/ftp/odbc/versions/msi/">https://www.postgresql.org/ftp/odbc/versions/msi/</a>.
+</p>
+
+<h3>Starting the Server</h3>
+<p>
+After installing the ODBC driver, start the H2 Server using the command line:
+</p>
+<pre>
+java -cp h2*.jar org.h2.tools.Server
+</pre>
+<p>
+The PG Server (PG for PostgreSQL protocol) is started as well.
+By default, databases are stored in the current working directory where the server is started.
+Use <code>-baseDir</code> to save databases in another directory, for example the user home directory:
+</p>
+<pre>
+java -cp h2*.jar org.h2.tools.Server -baseDir ~
+</pre>
+<p>
+The PG server can be started and stopped from within a Java application as follows:
+</p>
+<pre>
+Server server = Server.createPgServer("-baseDir", "~");
+server.start();
+...
+server.stop();
+</pre>
+<p>
+By default, only connections from localhost are allowed. To allow remote connections, use
+<code>-pgAllowOthers</code> when starting the server.
+</p>
+<p>
+To map an ODBC database name to a different JDBC database name,
+use the option <code>-key</code> when starting the server.
+Please note only one mapping is allowed. The following will map the ODBC database named
+<code>TEST</code> to the database URL <code>jdbc:h2:~/data/test;cipher=aes</code>:
+</p>
+<pre>
+java org.h2.tools.Server -pg -key TEST "~/data/test;cipher=aes"
+</pre>
+
+<h3>ODBC Configuration</h3>
+<p>
+After installing the driver, a new Data Source must be added. In Windows,
+run <code>odbcad32.exe</code> to open the Data Source Administrator. Then click on 'Add...'
+and select the PostgreSQL Unicode driver. Then click 'Finish'.
+You will be able to change the connection properties.
+The property column represents the property key in the <code>odbc.ini</code> file
+(which may be different from the GUI).
+</p>
+<table class="main">
+<tr><th>Property</th><th>Example</th><th>Remarks</th></tr>
+<tr><td>Data Source</td><td>H2 Test</td><td>The name of the ODBC Data Source</td></tr>
+<tr><td>Database</td><td>~/test;ifexists=true</td>
+    <td>
+        The database name. This can include connections settings.
+        By default, the database is stored in the current working directory
+        where the Server is started except when the -baseDir setting is used.
+        The name must be at least 3 characters.
+    </td></tr>
+<tr><td>Servername</td><td>localhost</td><td>The server name or IP address.<br />By default, only remote connections are allowed</td></tr>
+<tr><td>Username</td><td>sa</td><td>The database user name.</td></tr>
+<tr><td>SSL</td><td>false (disabled)</td><td>At this time, SSL is not supported.</td></tr>
+<tr><td>Port</td><td>5435</td><td>The port where the PG Server is listening.</td></tr>
+<tr><td>Password</td><td>sa</td><td>The database password.</td></tr>
+</table>
+<p>
+To improve performance, please enable 'server side prepare' under Options / Datasource / Page 2 / Server side prepare.
+</p>
+<p>
+Afterwards, you may use this data source.
+</p>
+
+<h3>PG Protocol Support Limitations</h3>
+<p>
+At this time, only a subset of the PostgreSQL network protocol is implemented.
+Also, there may be compatibility problems on the SQL level, with the catalog, or with text encoding.
+Problems are fixed as they are found.
+Currently, statements can not be canceled when using the PG protocol.
+Also, H2 does not provide index meta over ODBC.
+</p>
+<p>
+PostgreSQL ODBC Driver Setup requires a database password; that means it
+is not possible to connect to H2 databases without password. This is a limitation
+of the ODBC driver.
+</p>
+
+<h3>Security Considerations</h3>
+<p>
+Currently, the PG Server does not support challenge response or encrypt passwords.
+This may be a problem if an attacker can listen to the data transferred between the ODBC driver
+and the server, because the password is readable to the attacker.
+Also, it is currently not possible to use encrypted SSL connections.
+Therefore the ODBC driver should not be used where security is important.
+</p>
+<p>
+The first connection that opens a database using the PostgreSQL server needs to be an administrator user.
+Subsequent connections don't need to be opened by an administrator.
+</p>
+
+<h3>Using Microsoft Access</h3>
+<p>
+When using Microsoft Access to edit data in a linked H2 table, you may need to enable the following option:
+Tools - Options - Edit/Find - ODBC fields.
+</p>
+
+<h2 id="microsoft_dot_net">Using H2 in Microsoft .NET</h2>
+<p>
+The database can be used from Microsoft .NET even without using Java, by using IKVM.NET.
+You can access a H2 database on .NET using the JDBC API, or using the ADO.NET interface.
+</p>
+
+<h3>Using the ADO.NET API on .NET</h3>
+<p>
+An implementation of the ADO.NET interface is available in the open source project
+<a href="https://code.google.com/archive/p/h2sharp/">H2Sharp</a>.
+</p>
+
+<h3>Using the JDBC API on .NET</h3>
+<ul><li>Install the .NET Framework from <a href="https://www.microsoft.com">Microsoft</a>.
+    Mono has not yet been tested.
+</li><li>Install <a href="http://www.ikvm.net">IKVM.NET</a>.
+</li><li>Copy the <code>h2*.jar</code> file to <code>ikvm/bin</code>
+</li><li>Run the H2 Console using:
+    <code>ikvm -jar h2*.jar</code>
+</li><li>Convert the H2 Console to an <code>.exe</code> file using:
+    <code>ikvmc -target:winexe h2*.jar</code>.
+    You may ignore the warnings.
+</li><li>Create a <code>.dll</code> file using (change the version accordingly):
+    <code>ikvmc.exe -target:library -version:1.0.69.0 h2*.jar</code>
+</li></ul>
+<p>
+If you want your C# application use H2, you need to add the <code>h2.dll</code> and the
+<code>IKVM.OpenJDK.ClassLibrary.dll</code> to your C# solution. Here some sample code:
+</p>
+<pre>
+using System;
+using java.sql;
+
+class Test
+{
+    static public void Main()
+    {
+        org.h2.Driver.load();
+        Connection conn = DriverManager.getConnection("jdbc:h2:~/test", "sa", "sa");
+        Statement stat = conn.createStatement();
+        ResultSet rs = stat.executeQuery("SELECT 'Hello World'");
+        while (rs.next())
+        {
+            Console.WriteLine(rs.getString(1));
+        }
+    }
+}
+</pre>
+
+<h2 id="acid">ACID</h2>
+<p>
+In the database world, ACID stands for:
+</p>
+<ul>
+<li>Atomicity: transactions must be atomic, meaning either all tasks are performed or none.
+</li><li>Consistency: all operations must comply with the defined constraints.
+</li><li>Isolation: transactions must be isolated from each other.
+</li><li>Durability: committed transaction will not be lost.
+</li></ul>
+
+<h3>Atomicity</h3>
+<p>
+Transactions in this database are always atomic.
+</p>
+
+<h3>Consistency</h3>
+<p>
+By default, this database is always in a consistent state.
+Referential integrity rules are enforced except when
+explicitly disabled.
+</p>
+
+<h3>Isolation</h3>
+<p>
+For H2, as with most other database systems, the default isolation level is 'read committed'.
+This provides better performance, but also means that transactions are not completely isolated.
+H2 supports the transaction isolation levels 'serializable', 'read committed', and 'read uncommitted'.
+</p>
+
+<h3>Durability</h3>
+<p>
+This database does not guarantee that all committed transactions survive a power failure.
+Tests show that all databases sometimes lose transactions on power failure (for details, see below).
+Where losing transactions is not acceptable, a laptop or UPS (uninterruptible power supply) should be used.
+If durability is required for all possible cases of hardware failure, clustering should be used,
+such as the H2 clustering mode.
+</p>
+
+<h2 id="durability_problems">Durability Problems</h2>
+<p>
+Complete durability means all committed transaction survive a power failure.
+Some databases claim they can guarantee durability, but such claims are wrong.
+A durability test was run against H2, HSQLDB, PostgreSQL, and Derby.
+All of those databases sometimes lose committed transactions.
+The test is included in the H2 download, see <code>org.h2.test.poweroff.Test</code>.
+</p>
+
+<h3>Ways to (Not) Achieve Durability</h3>
+<p>
+Making sure that committed transactions are not lost is more complicated than it seems first.
+To guarantee complete durability, a database must ensure that the log record is on the hard drive
+before the commit call returns. To do that, databases use different methods. One
+is to use the 'synchronous write' file access mode. In Java, <code>RandomAccessFile</code>
+supports the modes <code>rws</code> and <code>rwd</code>:
+</p>
+<ul>
+<li><code>rwd</code>: every update to the file's content is written synchronously to the underlying storage device.
+</li><li><code>rws</code>: in addition to <code>rwd</code>, every update to the metadata is written synchronously.</li>
+</ul>
+<p>
+A test (<code>org.h2.test.poweroff.TestWrite</code>) with one of those modes achieves
+around 50 thousand write operations per second.
+Even when the operating system write buffer is disabled, the write rate is around 50 thousand operations per second.
+This feature does not force changes to disk because it does not flush all buffers.
+The test updates the same byte in the file again and again. If the hard drive was able to write at this rate,
+then the disk would need to make at least 50 thousand revolutions per second, or 3 million RPM
+(revolutions per minute). There are no such hard drives. The hard drive used for the test is about 7200 RPM,
+or about 120 revolutions per second. There is an overhead, so the maximum write rate must be lower than that.
+</p>
+<p>
+Calling <code>fsync</code> flushes the buffers. There are two ways to do that in Java:
+</p>
+<ul>
+<li><code>FileDescriptor.sync()</code>. The documentation says that this forces all system
+buffers to synchronize with the underlying device.
+This method is supposed to return after all in-memory modified copies of buffers associated with this file descriptor
+have been written to the physical medium.
+</li><li><code>FileChannel.force()</code>. This method is supposed
+to force any updates to this channel's file to be written to the storage device that contains it.
+</li></ul>
+<p>
+By default, MySQL calls <code>fsync</code> for each commit. When using one of those methods, only around 60 write operations
+per second can be achieved, which is consistent with the RPM rate of the hard drive used.
+Unfortunately, even when calling <code>FileDescriptor.sync()</code> or
+<code>FileChannel.force()</code>,
+data is not always persisted to the hard drive, because most hard drives do not obey
+<code>fsync()</code>: see
+<a href="https://hardware.slashdot.org/story/05/05/13/0529252/your-hard-drive-lies-to-you">Your Hard Drive Lies to You</a>.
+In Mac OS X, <code>fsync</code> does not flush hard drive buffers. See
+<a href="https://lists.apple.com/archives/darwin-dev/2005/Feb/msg00072.html">Bad fsync?</a>.
+So the situation is confusing, and tests prove there is a problem.
+</p>
+<p>
+Trying to flush hard drive buffers is hard, and if you do the performance is very bad.
+First you need to make sure that the hard drive actually flushes all buffers.
+Tests show that this can not be done in a reliable way.
+Then the maximum number of transactions is around 60 per second.
+Because of those reasons, the default behavior of H2 is to delay writing committed transactions.
+</p>
+<p>
+In H2, after a power failure, a bit more than one second of committed transactions may be lost.
+To change the behavior, use <code>SET WRITE_DELAY</code> and
+<code>CHECKPOINT SYNC</code>.
+Most other databases support commit delay as well.
+In the performance comparison, commit delay was used for all databases that support it.
+</p>
+
+<h3>Running the Durability Test</h3>
+<p>
+To test the durability / non-durability of this and other databases, you can use the test application
+in the package <code>org.h2.test.poweroff</code>.
+Two computers with network connection are required to run this test.
+One computer just listens, while the test application is run (and power is cut) on the other computer.
+The computer with the listener application opens a TCP/IP port and listens for an incoming connection.
+The second computer first connects to the listener, and then created the databases and starts inserting
+records. The connection is set to 'autocommit', which means after each inserted record a commit is performed
+automatically. Afterwards, the test computer notifies the listener that this record was inserted successfully.
+The listener computer displays the last inserted record number every 10 seconds. Now, switch off the power
+manually, then restart the computer, and run the application again. You will find out that in most cases,
+none of the databases contains all the records that the listener computer knows about. For details, please
+consult the source code of the listener and test application.
+</p>
+
+<h2 id="using_recover_tool">Using the Recover Tool</h2>
+<p>
+The <code>Recover</code> tool can be used to extract the contents of a database file, even if the database is corrupted.
+It also extracts the content of the transaction log and large objects (CLOB or BLOB).
+To run the tool, type on the command line:
+</p>
+<pre>
+java -cp h2*.jar org.h2.tools.Recover
+</pre>
+<p>
+For each database in the current directory, a text file will be created.
+This file contains raw insert statements (for the data) and data definition (DDL) statements to recreate
+the schema of the database. This file can be executed using the <code>RunScript</code> tool or a
+<code>RUNSCRIPT FROM</code> SQL statement. The script includes at least one
+<code>CREATE USER</code> statement. If you run the script against a database that was created with the same
+user, or if there are conflicting users, running the script will fail. Consider running the script
+against a database that was created with a user name that is not in the script.
+</p>
+<p>
+The <code>Recover</code> tool creates a SQL script from database file. It also processes the transaction log.
+</p>
+<p>
+To verify the database can recover at any time, append <code>;RECOVER_TEST=64</code>
+to the database URL in your test environment. This will simulate an application crash after each 64 writes to the database file.
+A log file named <code>databaseName.h2.db.log</code> is created that lists the operations.
+The recovery is tested using an in-memory file system, that means it may require a larger heap setting.
+</p>
+
+<h2 id="file_locking_protocols">File Locking Protocols</h2>
+<p>
+Multiple concurrent connections to the same database are supported, however a database file
+can only be open for reading and writing (in embedded mode) by one process at the same time.
+Otherwise, the processes would overwrite each others data and corrupt the database file.
+To protect against this problem, whenever a database is opened, a lock file is created
+to signal other processes that the database is in use. If the database is closed, or if the process that opened
+the database stops normally, this lock file is deleted.
+</p><p>
+In special cases (if the process did not terminate normally, for example because
+there was a power failure), the lock file is not deleted by the process that created it.
+That means the existence of the lock file is not a safe protocol for file locking.
+However, this software uses a challenge-response protocol to protect the database
+files. There are two methods (algorithms) implemented to provide both security
+(that is, the same database files cannot be opened by two processes at the same time)
+and simplicity (that is, the lock file does not need to be deleted manually by the user).
+The two methods are 'file method' and 'socket methods'.
+</p>
+<p>
+The file locking protocols (except the file locking method 'FS')
+have the following limitation: if a shared file system is used,
+and the machine with the lock owner is sent to sleep (standby or hibernate),
+another machine may take over. If the machine that originally held the lock
+wakes up, the database may become corrupt. If this situation can occur,
+the application must ensure the database is closed when the application
+is put to sleep.
+</p>
+
+<h3>File Locking Method 'File'</h3>
+<p>
+The default method for database file locking for version 1.3 and older is the 'File Method'.
+The algorithm is:
+</p>
+<ul>
+<li>If the lock file does not exist, it is created (using the atomic operation
+<code>File.createNewFile</code>).
+Then, the process waits a little bit (20 ms) and checks the file again. If the file was changed
+during this time, the operation is aborted. This protects against a race condition
+when one process deletes the lock file just after another one create it, and a third process creates
+the file again. It does not occur if there are only two writers.
+</li><li>
+If the file can be created, a random number is inserted together with the locking method
+('file'). Afterwards, a watchdog thread is started that
+checks regularly (every second once by default) if the file was deleted or modified by
+another (challenger) thread / process. Whenever that occurs, the file is overwritten with the
+old data. The watchdog thread runs with high priority so that a change to the lock file does
+not get through undetected even if the system is very busy. However, the watchdog thread
+does use very little resources (CPU time), because it waits most of the time. Also, the watchdog only reads from the hard disk
+and does not write to it.
+</li><li>
+If the lock file exists and was recently modified, the process waits for some time (up to two seconds).
+If it was still changed, an exception is thrown (database is locked). This is done to eliminate race conditions with many concurrent
+writers. Afterwards, the file is overwritten with a new version (challenge).
+After that, the thread waits for 2 seconds.
+If there is a watchdog thread protecting the file, he will overwrite the change
+and this process will fail to lock the database.
+However, if there is no watchdog thread, the lock file will still be as written by
+this thread. In this case, the file is deleted and atomically created again.
+The watchdog thread is started in this case and the file is locked.
+</li></ul>
+<p>
+This algorithm is tested with over 100 concurrent threads. In some cases, when there are
+many concurrent threads trying to lock the database, they block each other (meaning
+the file cannot be locked by any of them) for some time. However, the file never gets
+locked by two threads at the same time. However using that many concurrent threads
+/ processes is not the common use case. Generally, an application should throw an error
+to the user if it cannot open a database, and not try again in a (fast) loop.
+</p>
+
+<h3>File Locking Method 'Socket'</h3>
+<p>
+There is a second locking mechanism implemented, but disabled by default.
+To use it, append <code>;FILE_LOCK=SOCKET</code> to the database URL.
+The algorithm is:
+</p>
+<ul>
+<li>If the lock file does not exist, it is created.
+Then a server socket is opened on a defined port, and kept open.
+The port and IP address of the process that opened the database is written
+into the lock file.
+</li><li>If the lock file exists, and the lock method is 'file', then the software switches
+to the 'file' method.
+</li><li>If the lock file exists, and the lock method is 'socket', then the process
+checks if the port is in use. If the original process is still running, the port is in use
+and this process throws an exception (database is in use). If the original process
+died (for example due to a power failure, or abnormal termination of the virtual machine),
+then the port was released. The new process deletes the lock file and starts again.
+</li></ul>
+<p>
+This method does not require a watchdog thread actively polling (reading) the same
+file every second. The problem with this method is, if the file is stored on a network
+share, two processes (running on different computers) could still open the same
+database files, if they do not have a direct TCP/IP connection.
+</p>
+
+<h3>File Locking Method 'FS'</h3>
+<p>
+This is the default mode for version 1.4 and newer.
+This database file locking mechanism uses native file system lock on the database file.
+No *.lock.db file is created in this case, and no background thread is started.
+This mechanism may not work on all systems as expected.
+Some systems allow to lock the same file multiple times within the same virtual machine,
+and on some system native file locking is not supported or files are not unlocked after a power failure.
+</p>
+<p>
+To enable this feature, append <code>;FILE_LOCK=FS</code> to the database URL.
+</p>
+<p>
+This feature is relatively new. When using it for production, please ensure
+your system does in fact lock files as expected.
+</p>
+
+<h2 id="passwords">Using Passwords</h2>
+
+<h3>Using Secure Passwords</h3>
+<p>
+Remember that weak passwords can be broken regardless of the encryption and security protocols.
+Don't use passwords that can be found in a dictionary. Appending numbers does not make passwords
+secure. A way to create good passwords that can be remembered is: take the first
+letters of a sentence, use upper and lower case characters, and creatively include special characters
+(but it's more important to use a long password than to use special characters).
+Example:
+</p><p>
+<code>i'sE2rtPiUKtT</code> from the sentence <code>it's easy to remember this password if you know the trick</code>.
+</p>
+
+<h3>Passwords: Using Char Arrays instead of Strings</h3>
+<p>
+Java strings are immutable objects and cannot be safely 'destroyed' by the application.
+After creating a string, it will remain in the main memory of the computer at least
+until it is garbage collected. The garbage collection cannot be controlled by the application,
+and even if it is garbage collected the data may still remain in memory.
+It might also be possible that the part of memory containing the password
+is swapped to disk (if not enough main memory is available), which is
+a problem if the attacker has access to the swap file of the operating system.
+</p><p>
+It is a good idea to use char arrays instead of strings for passwords.
+Char arrays can be cleared (filled with zeros) after use, and therefore the
+password will not be stored in the swap file.
+</p><p>
+This database supports using char arrays instead of string to pass user and file passwords.
+The following code can be used to do that:
+</p>
+<pre>
+import java.sql.*;
+import java.util.*;
+public class Test {
+    public static void main(String[] args) throws Exception {
+        String url = "jdbc:h2:~/test";
+        Properties prop = new Properties();
+        prop.setProperty("user", "sa");
+        System.out.print("Password?");
+        char[] password = System.console().readPassword();
+        prop.put("password", password);
+        Connection conn = null;
+        try {
+            conn = DriverManager.getConnection(url, prop);
+        } finally {
+            Arrays.fill(password, (char) 0);
+        }
+        conn.close();
+    }
+}
+</pre>
+<p>
+When using Swing, use <code>javax.swing.JPasswordField</code>.
+</p>
+
+<h3>Passing the User Name and/or Password in the URL</h3>
+<p>
+Instead of passing the user name as a separate parameter as in
+<code>
+Connection conn = DriverManager.
+    getConnection("jdbc:h2:~/test", "sa", "123");
+</code>
+the user name (and/or password) can be supplied in the URL itself:
+<code>
+Connection conn = DriverManager.
+    getConnection("jdbc:h2:~/test;USER=sa;PASSWORD=123");
+</code>
+The settings in the URL override the settings passed as a separate parameter.
+</p>
+
+<h2 id="password_hash">Password Hash</h2>
+<p>
+Sometimes the database password needs to be stored in a configuration file
+(for example in the <code>web.xml</code> file).
+In addition to connecting with the plain text password,
+this database supports connecting with the password hash.
+This means that only the hash of the password (and not the plain text password)
+needs to be stored in the configuration file.
+This will only protect others from reading or re-constructing the plain text password
+(even if they have access to the configuration file);
+it does not protect others from accessing the database using the password hash.
+</p>
+<p>
+To connect using the password hash instead of plain text password, append
+<code>;PASSWORD_HASH=TRUE</code> to the database URL, and replace
+the password with the password hash. To calculate the password hash from a plain text password,
+run the following command within the H2 Console tool:
+<code>@password_hash &lt;upperCaseUserName&gt; &lt;password&gt;</code>.
+As an example, if the user name is <code>sa</code> and the password is
+<code>test</code>, run the command
+<code>@password_hash SA test</code>.
+Then use the resulting password hash as you would use the plain text password.
+When using an encrypted database, then the user password and file password
+need to be hashed separately. To calculate the hash of the file password, run:
+<code>@password_hash file &lt;filePassword&gt;</code>.
+</p>
+
+<h2 id="sql_injection">Protection against SQL Injection</h2>
+<h3>What is SQL Injection</h3>
+<p>
+This database engine provides a solution for the security vulnerability known as 'SQL Injection'.
+Here is a short description of what SQL injection means.
+Some applications build SQL statements with embedded user input such as:
+</p>
+<pre>
+String sql = "SELECT * FROM USERS WHERE PASSWORD='"+pwd+"'";
+ResultSet rs = conn.createStatement().executeQuery(sql);
+</pre>
+<p>
+If this mechanism is used anywhere in the application, and user input is not correctly filtered or encoded,
+it is possible for a user to inject SQL functionality or statements by using specially built input
+such as (in this example) this password: <code>' OR ''='</code>.
+In this case the statement becomes:
+</p>
+<pre>
+SELECT * FROM USERS WHERE PASSWORD='' OR ''='';
+</pre>
+<p>
+Which is always true no matter what the password stored in the database is.
+For more information about SQL Injection, see <a href="#glossary_links">Glossary and Links</a>.
+</p>
+
+<h3>Disabling Literals</h3>
+<p>
+SQL Injection is not possible if user input is not directly embedded in SQL statements.
+A simple solution for the problem above is to use a prepared statement:
+</p>
+<pre>
+String sql = "SELECT * FROM USERS WHERE PASSWORD=?";
+PreparedStatement prep = conn.prepareStatement(sql);
+prep.setString(1, pwd);
+ResultSet rs = prep.executeQuery();
+</pre>
+<p>
+This database provides a way to enforce usage of parameters when passing user input
+to the database. This is done by disabling embedded literals in SQL statements.
+To do this, execute the statement:
+</p>
+<pre>
+SET ALLOW_LITERALS NONE;
+</pre>
+<p>
+Afterwards, SQL statements with text and number literals are not allowed any more.
+That means, SQL statement of the form <code>WHERE NAME='abc'</code>
+or <code>WHERE CustomerId=10</code> will fail.
+It is still possible to use prepared statements and parameters as described above. Also, it is still possible to generate
+SQL statements dynamically, and use the Statement API, as long as the SQL statements
+do not include literals.
+There is also a second mode where number literals are allowed:
+<code>SET ALLOW_LITERALS NUMBERS</code>.
+To allow all literals, execute <code>SET ALLOW_LITERALS ALL</code>
+(this is the default setting). Literals can only be enabled or disabled by an administrator.
+</p>
+
+<h3>Using Constants</h3>
+<p>
+Disabling literals also means disabling hard-coded 'constant' literals. This database supports
+defining constants using the <code>CREATE CONSTANT</code> command.
+Constants can be defined only
+when literals are enabled, but used even when literals are disabled. To avoid name clashes
+with column names, constants can be defined in other schemas:
+</p>
+<pre>
+CREATE SCHEMA CONST AUTHORIZATION SA;
+CREATE CONSTANT CONST.ACTIVE VALUE 'Active';
+CREATE CONSTANT CONST.INACTIVE VALUE 'Inactive';
+SELECT * FROM USERS WHERE TYPE=CONST.ACTIVE;
+</pre>
+<p>
+Even when literals are enabled, it is better to use constants instead
+of hard-coded number or text literals in queries or views. With constants, typos are found at compile
+time, the source code is easier to understand and change.
+</p>
+
+<h3>Using the ZERO() Function</h3>
+<p>
+It is not required to create a constant for the number 0 as there is already a built-in function <code>ZERO()</code>:
+</p>
+<pre>
+SELECT * FROM USERS WHERE LENGTH(PASSWORD)=ZERO();
+</pre>
+
+<h2 id="remote_access">Protection against Remote Access</h2>
+<p>
+By default this database does not allow connections from other machines when starting the H2 Console,
+the TCP server, or the PG server. Remote access can be enabled using the command line
+options <code>-webAllowOthers, -tcpAllowOthers, -pgAllowOthers</code>.
+</p>
+<p>
+If you enable remote access using
+<code>-tcpAllowOthers</code> or <code>-pgAllowOthers</code>,
+please also consider using the options <code>-baseDir</code>,
+so that remote users can not create new databases
+or access existing databases with weak passwords.
+When using the option <code>-baseDir</code>, only databases within that directory may be accessed.
+Ensure the existing accessible databases are protected using strong passwords.
+</p>
+<p>
+If you enable remote access using <code>-webAllowOthers</code>,
+please ensure the web server can only be accessed from trusted networks.
+The options <code>-baseDir</code> don't protect
+access to the tools section, prevent remote shutdown of the web server,
+changes to the preferences, the saved connection settings,
+or access to other databases accessible from the system.
+</p>
+
+<h2 id="restricting_classes">Restricting Class Loading and Usage</h2>
+<p>
+By default there is no restriction on loading classes and executing Java code for admins.
+That means an admin may call system functions such as
+<code>System.setProperty</code> by executing:
+</p>
+<pre>
+CREATE ALIAS SET_PROPERTY FOR "java.lang.System.setProperty";
+CALL SET_PROPERTY('abc', '1');
+CREATE ALIAS GET_PROPERTY FOR "java.lang.System.getProperty";
+CALL GET_PROPERTY('abc');
+</pre>
+<p>
+To restrict users (including admins) from loading classes and executing code,
+the list of allowed classes can be set in the system property
+<code>h2.allowedClasses</code>
+in the form of a comma separated list of classes or patterns (items ending with <code>*</code>).
+By default all classes are allowed. Example:
+</p>
+<pre>
+java -Dh2.allowedClasses=java.lang.Math,com.acme.*
+</pre>
+<p>
+This mechanism is used for all user classes, including database event listeners,
+trigger classes, user-defined functions, user-defined aggregate functions, and JDBC
+driver classes (with the exception of the H2 driver) when using the H2 Console.
+</p>
+
+<h2 id="security_protocols">Security Protocols</h2>
+<p>
+The following paragraphs document the security protocols used in this database.
+These descriptions are very technical and only intended for security experts that already know
+the underlying security primitives.
+</p>
+
+<h3>User Password Encryption</h3>
+<p>
+When a user tries to connect to a database, the combination of
+user name, @, and password are hashed using SHA-256, and this hash value
+is transmitted to the database.
+This step does not protect against an attacker that re-uses the value if he is able to listen to the
+(unencrypted) transmission between the client and the server.
+But, the passwords are never transmitted as plain text,
+even when using an unencrypted connection between client and server.
+That means if a user reuses the same password for different things,
+this password is still protected up to some point. See also
+'RFC 2617 - HTTP Authentication: Basic and Digest Access Authentication'
+for more information.
+</p><p>
+When a new database or user is created, a new random salt value is generated.
+The size of the salt is 64 bits. Using the random salt reduces the risk of an
+attacker pre-calculating hash values for many different (commonly used) passwords.
+</p><p>
+The combination of user-password hash value (see above) and salt is hashed
+using SHA-256. The resulting value is stored in the database.
+When a user tries to connect to the database, the database combines
+user-password hash value with the stored salt value and calculates the
+hash value. Other products use multiple iterations (hash the hash value again and again),
+but this is not done in this product to reduce the risk of denial of service attacks
+(where the attacker tries to connect with bogus passwords, and the server
+spends a lot of time calculating the hash value for each password).
+The reasoning is: if the attacker has access to the hashed passwords, he also has
+access to the data in plain text, and therefore does not need the password any more.
+If the data is protected by storing it on another computer and only accessible remotely,
+then the iteration count is not required at all.
+</p>
+
+<h3>File Encryption</h3>
+<p>
+The database files can be encrypted using the AES-128 algorithm.
+</p><p>
+When a user tries to connect to an encrypted database, the combination of
+<code>file@</code> and the file password is hashed using SHA-256. This hash value is
+transmitted to the server.
+</p><p>
+When a new database file is created, a new cryptographically secure
+random salt value is generated. The size of the salt is 64 bits.
+The combination of the file password hash and the salt value is hashed 1024 times
+using SHA-256. The reason for the iteration is to make it harder for an attacker to
+calculate hash values for common passwords.
+</p><p>
+The resulting hash value is used as the key for the block cipher algorithm.
+Then, an initialization vector (IV) key
+is calculated by hashing the key again using SHA-256.
+This is to make sure the IV is unknown to the attacker.
+The reason for using a secret IV is to protect against watermark attacks.
+</p><p>
+Before saving a block of data (each block is 8 bytes long), the following operations are executed:
+first, the IV is calculated by encrypting the block number with the IV key (using the same
+block cipher algorithm). This IV is combined with the plain text using XOR. The resulting data is
+encrypted using the AES-128 algorithm.
+</p><p>
+When decrypting, the operation is done in reverse. First, the block is decrypted using the key,
+and then the IV is calculated combined with the decrypted text using XOR.
+</p><p>
+Therefore, the block cipher mode of operation is CBC (cipher-block chaining), but each chain
+is only one block long. The advantage over the ECB (electronic codebook) mode is that patterns
+in the data are not revealed, and the advantage over multi block CBC is that flipped cipher text bits
+are not propagated to flipped plaintext bits in the next block.
+</p><p>
+Database encryption is meant for securing the database while it is not in use (stolen laptop and so on).
+It is not meant for cases where the attacker has access to files while the database is in use.
+When he has write access, he can for example replace pieces of files with pieces of older versions
+and manipulate data like this.
+</p><p>
+File encryption slows down the performance of the database engine. Compared to unencrypted mode,
+database operations take about 2.5 times longer using AES (embedded mode).
+</p>
+
+<h3>Wrong Password / User Name Delay</h3>
+<p>
+To protect against remote brute force password attacks, the delay after each unsuccessful
+login gets double as long. Use the system properties <code>h2.delayWrongPasswordMin</code>
+and <code>h2.delayWrongPasswordMax</code> to change the minimum (the default is 250 milliseconds)
+or maximum delay (the default is 4000 milliseconds, or 4 seconds). The delay only
+applies for those using the wrong password. Normally there is no delay for a user that knows the correct
+password, with one exception: after using the wrong password, there is a delay of up to (randomly distributed)
+the same delay as for a wrong password. This is to protect against parallel brute force attacks,
+so that an attacker needs to wait for the whole delay. Delays are synchronized. This is also required
+to protect against parallel attacks.
+</p>
+<p>
+There is only one exception message for both wrong user and for wrong password,
+to make it harder to get the list of user names. It is not possible from the stack trace to see
+if the user name was wrong or the password.
+</p>
+
+<h3>HTTPS Connections</h3>
+<p>
+The web server supports HTTP and HTTPS connections using <code>SSLServerSocket</code>.
+There is a default self-certified certificate to support an easy starting point, but
+custom certificates are supported as well.
+</p>
+
+<h2 id="tls_connections">TLS Connections</h2>
+<p>
+Remote TLS connections are supported using the Java Secure Socket Extension
+(<code>SSLServerSocket, SSLSocket</code>). By default, anonymous TLS is enabled.
+</p>
+<p>
+To use your own keystore, set the system properties <code>javax.net.ssl.keyStore</code> and
+<code>javax.net.ssl.keyStorePassword</code> before starting the H2 server and client.
+See also <a href="https://docs.oracle.com/javase/7/docs/technotes/guides/security/jsse/JSSERefGuide.html#CustomizingStores">
+Customizing the Default Key and Trust Stores, Store Types, and Store Passwords</a>
+for more information.
+</p>
+<p>
+To disable anonymous TLS, set the system property <code>h2.enableAnonymousTLS</code> to false.
+</p>
+
+<h2 id="uuid">Universally Unique Identifiers (UUID)</h2>
+<p>
+This database supports UUIDs. Also supported is a function to create new UUIDs using
+a cryptographically strong pseudo random number generator.
+With random UUIDs, the chance of two having the same value can be calculated
+using the probability theory. See also 'Birthday Paradox'.
+Standardized randomly generated UUIDs have 122 random bits.
+4 bits are used for the version (Randomly generated UUID), and 2 bits for the variant (Leach-Salz).
+This database supports generating such UUIDs using the built-in function
+<code>RANDOM_UUID()</code> or <code>UUID()</code>.
+Here is a small program to estimate the probability of having two identical UUIDs
+after generating a number of values:
+</p>
+<pre>
+public class Test {
+    public static void main(String[] args) throws Exception {
+        double x = Math.pow(2, 122);
+        for (int i = 35; i &lt; 62; i++) {
+            double n = Math.pow(2, i);
+            double p = 1 - Math.exp(-(n * n) / 2 / x);
+            System.out.println("2^" + i + "=" + (1L &lt;&lt; i) +
+                    " probability: 0" +
+                    String.valueOf(1 + p).substring(1));
+        }
+    }
+}
+</pre>
+<p>
+Some values are:
+</p>
+<table class="main">
+<tr><th>Number of UUIs</th><th>Probability of Duplicates</th></tr>
+<tr><td>2^36=68'719'476'736</td><td>0.000'000'000'000'000'4</td></tr>
+<tr><td>2^41=2'199'023'255'552</td><td>0.000'000'000'000'4</td></tr>
+<tr><td>2^46=70'368'744'177'664</td><td>0.000'000'000'4</td></tr>
+</table>
+<p>
+To help non-mathematicians understand what those numbers mean, here a comparison:
+one's annual risk of being hit by a meteorite is estimated to be one chance in 17 billion,
+that means the probability is about 0.000'000'000'06.
+</p>
+
+<h2 id="spatial_features">Spatial Features</h2>
+<p>
+H2 supports the geometry data type and spatial indexes.
+Here is an example SQL script to create a table with a spatial column and index:
+</p>
+<pre>
+CREATE TABLE GEO_TABLE(GID SERIAL, THE_GEOM GEOMETRY);
+INSERT INTO GEO_TABLE(THE_GEOM) VALUES
+    ('POINT(500 505)'),
+    ('LINESTRING(550 551, 525 512, 565 566)'),
+    ('POLYGON ((550 521, 580 540, 570 564, 512 566, 550 521))');
+CREATE SPATIAL INDEX GEO_TABLE_SPATIAL_INDEX
+    ON GEO_TABLE(THE_GEOM);
+</pre>
+<p>
+To query the table using geometry envelope intersection,
+use the operation <code>&amp;&amp;</code>, as in PostGIS:
+</p>
+<pre>
+SELECT * FROM GEO_TABLE
+    WHERE THE_GEOM &amp;&amp;
+    'POLYGON ((490 490, 536 490, 536 515, 490 515, 490 490))';
+</pre>
+<p>
+You can verify that the spatial index is used using the "explain plan" feature:
+</p>
+<pre>
+EXPLAIN SELECT * FROM GEO_TABLE
+    WHERE THE_GEOM &amp;&amp;
+    'POLYGON ((490 490, 536 490, 536 515, 490 515, 490 490))';
+-- Result
+SELECT
+    "GEO_TABLE"."GID",
+    "GEO_TABLE"."THE_GEOM"
+FROM "PUBLIC"."GEO_TABLE"
+    /* PUBLIC.GEO_TABLE_SPATIAL_INDEX:
+    THE_GEOM &amp;&amp;
+    'POLYGON ((490 490, 536 490, 536 515, 490 515, 490 490))'::Geometry */
+WHERE INTERSECTS("THE_GEOM",
+    'POLYGON ((490 490, 536 490, 536 515, 490 515, 490 490))'::Geometry)
+</pre>
+<p>
+For persistent databases, the spatial index is stored on disk;
+for in-memory databases, the index is kept in memory.
+</p>
+
+<h2 id="recursive_queries">Recursive Queries</h2>
+<p>
+H2 has experimental support for recursive queries using so called "common table expressions" (CTE).
+Examples:
+</p>
+<pre>
+WITH RECURSIVE T(N) AS (
+    SELECT 1
+    UNION ALL
+    SELECT N+1 FROM T WHERE N&lt;10
+)
+SELECT * FROM T;
+-- returns the values 1 .. 10
+
+WITH RECURSIVE T(N) AS (
+    SELECT 1
+    UNION ALL
+    SELECT N*2 FROM T WHERE N&lt;10
+)
+SELECT * FROM T;
+-- returns the values 1, 2, 4, 8, 16
+
+CREATE TABLE FOLDER(ID INT PRIMARY KEY, NAME VARCHAR(255), PARENT INT);
+
+INSERT INTO FOLDER VALUES(1, null, null), (2, 'src', 1),
+(3, 'main', 2), (4, 'org', 3), (5, 'test', 2);
+
+WITH LINK(ID, NAME, LEVEL) AS (
+    SELECT ID, NAME, 0 FROM FOLDER WHERE PARENT IS NULL
+    UNION ALL
+    SELECT FOLDER.ID, IFNULL(LINK.NAME || '/', '') || FOLDER.NAME, LEVEL + 1
+    FROM LINK INNER JOIN FOLDER ON LINK.ID = FOLDER.PARENT
+)
+SELECT NAME FROM LINK WHERE NAME IS NOT NULL ORDER BY ID;
+-- src
+-- src/main
+-- src/main/org
+-- src/test
+</pre>
+<p>
+Limitations: Recursive queries need to be of the type <code>UNION ALL</code>,
+and the recursion needs to be on the second part of the query.
+No tables or views with the name of the table expression may exist.
+Different table expression names need to be used when using multiple distinct table
+expressions within the same transaction and for the same session.
+All columns of the table expression are of type <code>VARCHAR</code>,
+and may need to be cast to the required data type.
+Views with recursive queries are not supported.
+Subqueries and <code>INSERT INTO ... FROM</code> with recursive queries are not supported.
+Parameters are only supported within the last <code>SELECT</code> statement
+(a workaround is to use session variables like <code>@start</code>
+within the table expression).
+The syntax is:
+</p>
+<pre>
+WITH RECURSIVE recursiveQueryName(columnName, ...) AS (
+    nonRecursiveSelect
+    UNION ALL
+    recursiveSelect
+)
+select
+</pre>
+
+<h2 id="system_properties">Settings Read from System Properties</h2>
+<p>
+Some settings of the database can be set on the command line using
+<code>-DpropertyName=value</code>. It is usually not required to change those settings manually.
+The settings are case sensitive.
+Example:
+</p>
+<pre>
+java -Dh2.serverCachedObjects=256 org.h2.tools.Server
+</pre>
+<p>
+The current value of the settings can be read in the table
+<code>INFORMATION_SCHEMA.SETTINGS</code>.
+</p>
+<p>
+For a complete list of settings, see
+<a href="http://www.h2database.com/javadoc/org/h2/engine/SysProperties.html">SysProperties</a>.
+</p>
+
+<h2 id="server_bind_address">Setting the Server Bind Address</h2>
+<p>
+Usually server sockets accept connections on any/all local addresses.
+This may be a problem on multi-homed hosts.
+To bind only to one address, use the system property <code>h2.bindAddress</code>.
+This setting is used for both regular server sockets and for TLS server sockets.
+IPv4 and IPv6 address formats are supported.
+</p>
+
+<h2 id="file_system">Pluggable File System</h2>
+<p>
+This database supports a pluggable file system API.
+The file system implementation is selected using a file name prefix.
+Internally, the interfaces are very similar to the Java 7 NIO2 API, but do not (yet) use or require Java 7.
+The following file systems are included:
+</p>
+<ul><li><code>zip:</code>  read-only zip-file based file system. Format: <code>zip:/zipFileName!/fileName</code>.
+</li><li><code>split:</code> file system that splits files in 1 GB files (stackable with other file systems).
+</li><li><code>nio:</code> file system that uses <code>FileChannel</code> instead of <code>RandomAccessFile</code> (faster in some operating systems).
+</li><li><code>nioMapped:</code> file system that uses memory mapped files (faster in some operating systems).
+    Please note that there currently is a file size limitation of 2 GB when using this file system.
+    To work around this limitation, combine it with the split file system: <code>split:nioMapped:test</code>.
+</li><li><code>async:</code> experimental file system that uses <code>AsynchronousFileChannel</code> instead of <code>RandomAccessFile</code> (faster in some operating systems).
+</li><li><code>memFS:</code> in-memory file system (slower than mem; experimental; mainly used for testing the database engine itself).
+</li><li><code>memLZF:</code> compressing in-memory file system (slower than memFS but uses less memory; experimental; mainly used for testing the database engine itself).
+</li><li><code>nioMemFS:</code> stores data outside of the VM's heap - useful for large memory DBs without incurring GC costs.
+</li>
+<li>
+    <code>nioMemLZF:</code> stores compressed data outside of the VM's heap -
+    useful for large memory DBs without incurring GC costs.
+    Use "nioMemLZF:12:" to tweak the % of blocks that are stored uncompressed.
+    If you size this to your working set correctly,
+    compressed storage is roughly the same performance as uncompressed.
+    The default value is 1%.
+</li></ul>
+<p>
+As an example, to use the <code>nio</code> file system with PageStore storage engine,
+use the following database URL: <code>jdbc:h2:nio:~/test;MV_STORE=FALSE</code>.
+With MVStore storage engine nio file system is used by default.
+</p>
+<p>
+To register a new file system, extend the classes <code>org.h2.store.fs.FilePath, FileBase</code>,
+and call the method <code>FilePath.register</code> before using it.
+</p>
+<p>
+For input streams (but not for random access files), URLs may be used in addition to the registered file systems.
+Example: <code>jar:file:///c:/temp/example.zip!/org/example/nested.csv</code>.
+To read a stream from the classpath, use the prefix <code>classpath:</code>, as in
+<code>classpath:/org/h2/samples/newsfeed.sql</code>.
+</p>
+
+<h2 id="file_system_split">Split File System</h2>
+<p>
+The file system prefix <code>split:</code> is used to split logical files into multiple physical files,
+for example so that a database can get larger than the maximum file system size of the operating system.
+If the logical file is larger than the maximum file size, then the file is split as follows:
+</p>
+<ul><li><code>&lt;fileName&gt;</code> (first block, is always created)
+</li><li><code>&lt;fileName&gt;.1.part</code> (second block)
+</li></ul>
+<p>
+More physical files (<code>*.2.part, *.3.part</code>) are automatically created / deleted if needed.
+The maximum physical file size of a block is 2^30 bytes, which is also called 1 GiB or 1 GB.
+However this can be changed if required, by specifying the block size in the file name.
+The file name format is: <code>split:&lt;x&gt;:&lt;fileName&gt;</code> where the file size per block is 2^x.
+For 1 MiB block sizes, use x = 20 (because 2^20 is 1 MiB).
+The following file name means the logical file is split into 1 MiB blocks: <code>split:20:test.h2.db</code>.
+An example database URL for this case is <code>jdbc:h2:split:20:~/test</code>.
+</p>
+
+<h2 id="database_upgrade">Database Upgrade</h2>
+<p>
+In version 1.2, H2 introduced a new file store implementation which is incompatible to the one used in versions &lt; 1.2.
+To automatically convert databases to the new file store, it is necessary to include an additional jar file.
+The file can be found at <a href="http://h2database.com/h2mig_pagestore_addon.jar">http://h2database.com/h2mig_pagestore_addon.jar</a> .
+If this file is in the classpath, every connect to an older database will result in a conversion process.
+</p>
+<p>
+The conversion itself is done internally via <code>'script to'</code> and <code>'runscript from'</code>. After the conversion process, the files will be
+renamed from
... 422167 lines suppressed ...


[ignite] 15/17: GG-17480 Implement WAL page snapshot records compression * fixed groupId causing compilation errors

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 77c839de4dac99929bd9d50551684844a1e9f1c0
Author: Peter Ivanov <mr...@gmail.com>
AuthorDate: Mon Apr 29 19:00:02 2019 +0300

    GG-17480 Implement WAL page snapshot records compression
     * fixed groupId causing compilation errors
---
 modules/compress/pom.xml | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)

diff --git a/modules/compress/pom.xml b/modules/compress/pom.xml
index bdcd924..11b3558 100644
--- a/modules/compress/pom.xml
+++ b/modules/compress/pom.xml
@@ -42,7 +42,7 @@
         </dependency>
 
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-indexing</artifactId>
             <type>test-jar</type>
             <scope>test</scope>
@@ -50,7 +50,7 @@
         </dependency>
 
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-indexing</artifactId>
             <scope>test</scope>
             <version>${project.version}</version>


[ignite] 09/17: GG-17424 Disable by default bash pipefail/errexit/nounset options from Ignite startup scripts

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit e66ff5dfef3c59b44a897c3051090f13b0a686d7
Author: mcherkasov <mc...@gridgain.com>
AuthorDate: Fri Apr 26 18:37:54 2019 +0300

    GG-17424 Disable by default bash pipefail/errexit/nounset options from Ignite startup scripts
    
    (cherry picked from commit f871f10)
---
 bin/control.sh                 | 14 +++++++++-----
 bin/ignite-tf.sh               | 14 +++++++++-----
 bin/ignite.sh                  | 13 ++++++++-----
 bin/ignitevisorcmd.sh          | 14 +++++++++-----
 bin/include/functions.sh       | 14 +++++++++-----
 bin/include/parseargs.sh       | 14 +++++++++-----
 bin/include/setenv.sh          | 14 +++++++++-----
 modules/sqlline/bin/sqlline.sh | 14 +++++++++-----
 packaging/package.sh           | 13 ++++++++-----
 9 files changed, 79 insertions(+), 45 deletions(-)

diff --git a/bin/control.sh b/bin/control.sh
index 1411f15..155df4d 100755
--- a/bin/control.sh
+++ b/bin/control.sh
@@ -1,9 +1,13 @@
 #!/usr/bin/env bash
-set -o nounset
-set -o errexit
-set -o pipefail
-set -o errtrace
-set -o functrace
+if [ ! -z "${IGNITE_SCRIPT_STRICT_MODE:-}" ]
+then
+    set -o nounset
+    set -o errexit
+    set -o pipefail
+    set -o errtrace
+    set -o functrace
+fi
+
 #
 # Copyright 2019 GridGain Systems, Inc. and Contributors.
 #
diff --git a/bin/ignite-tf.sh b/bin/ignite-tf.sh
index 64808cd..177222d 100755
--- a/bin/ignite-tf.sh
+++ b/bin/ignite-tf.sh
@@ -1,9 +1,13 @@
 #!/usr/bin/env bash
-set -o nounset
-set -o errexit
-set -o pipefail
-set -o errtrace
-set -o functrace
+if [ ! -z "${IGNITE_SCRIPT_STRICT_MODE:-}" ]
+then
+    set -o nounset
+    set -o errexit
+    set -o pipefail
+    set -o errtrace
+    set -o functrace
+fi
+
 #
 # Copyright 2019 GridGain Systems, Inc. and Contributors.
 #
diff --git a/bin/ignite.sh b/bin/ignite.sh
index 81f6f4c..e986f6f 100755
--- a/bin/ignite.sh
+++ b/bin/ignite.sh
@@ -1,9 +1,12 @@
 #!/usr/bin/env bash
-set -o nounset
-set -o errexit
-set -o pipefail
-set -o errtrace
-set -o functrace
+if [ ! -z "${IGNITE_SCRIPT_STRICT_MODE:-}" ]
+then
+    set -o nounset
+    set -o errexit
+    set -o pipefail
+    set -o errtrace
+    set -o functrace
+fi
 
 #
 # Copyright 2019 GridGain Systems, Inc. and Contributors.
diff --git a/bin/ignitevisorcmd.sh b/bin/ignitevisorcmd.sh
index d9212c6..b40e312 100755
--- a/bin/ignitevisorcmd.sh
+++ b/bin/ignitevisorcmd.sh
@@ -1,9 +1,13 @@
 #!/usr/bin/env bash
-set -o nounset
-set -o errexit
-set -o pipefail
-set -o errtrace
-set -o functrace
+if [ ! -z "${IGNITE_SCRIPT_STRICT_MODE:-}" ]
+then
+    set -o nounset
+    set -o errexit
+    set -o pipefail
+    set -o errtrace
+    set -o functrace
+fi
+
 #
 # Copyright 2019 GridGain Systems, Inc. and Contributors.
 #
diff --git a/bin/include/functions.sh b/bin/include/functions.sh
index 2f903ea..779f2b9 100755
--- a/bin/include/functions.sh
+++ b/bin/include/functions.sh
@@ -1,9 +1,13 @@
 #!/usr/bin/env bash
-set -o nounset
-set -o errexit
-set -o pipefail
-set -o errtrace
-set -o functrace
+if [ ! -z "${IGNITE_SCRIPT_STRICT_MODE:-}" ]
+then
+    set -o nounset
+    set -o errexit
+    set -o pipefail
+    set -o errtrace
+    set -o functrace
+fi
+
 #
 # Copyright 2019 GridGain Systems, Inc. and Contributors.
 #
diff --git a/bin/include/parseargs.sh b/bin/include/parseargs.sh
index 26be961..8acb462 100755
--- a/bin/include/parseargs.sh
+++ b/bin/include/parseargs.sh
@@ -1,9 +1,13 @@
 #!/usr/bin/env bash
-set -o nounset
-set -o errexit
-set -o pipefail
-set -o errtrace
-set -o functrace
+if [ ! -z "${IGNITE_SCRIPT_STRICT_MODE:-}" ]
+then
+    set -o nounset
+    set -o errexit
+    set -o pipefail
+    set -o errtrace
+    set -o functrace
+fi
+
 #
 # Copyright 2019 GridGain Systems, Inc. and Contributors.
 #
diff --git a/bin/include/setenv.sh b/bin/include/setenv.sh
index b652077..3829bcb 100755
--- a/bin/include/setenv.sh
+++ b/bin/include/setenv.sh
@@ -1,9 +1,13 @@
 #!/usr/bin/env bash
-set -o nounset
-set -o errexit
-set -o pipefail
-set -o errtrace
-set -o functrace
+if [ ! -z "${IGNITE_SCRIPT_STRICT_MODE:-}" ]
+then
+    set -o nounset
+    set -o errexit
+    set -o pipefail
+    set -o errtrace
+    set -o functrace
+fi
+
 #
 # Copyright 2019 GridGain Systems, Inc. and Contributors.
 #
diff --git a/modules/sqlline/bin/sqlline.sh b/modules/sqlline/bin/sqlline.sh
index c70bea6..4b13b13 100644
--- a/modules/sqlline/bin/sqlline.sh
+++ b/modules/sqlline/bin/sqlline.sh
@@ -1,9 +1,13 @@
 #!/usr/bin/env bash
-set -o nounset
-set -o errexit
-set -o pipefail
-set -o errtrace
-set -o functrace
+if [ ! -z "${IGNITE_SCRIPT_STRICT_MODE:-}" ]
+then
+    set -o nounset
+    set -o errexit
+    set -o pipefail
+    set -o errtrace
+    set -o functrace
+fi
+
 #
 # Copyright 2019 GridGain Systems, Inc. and Contributors.
 #
diff --git a/packaging/package.sh b/packaging/package.sh
index d409052..223e314 100755
--- a/packaging/package.sh
+++ b/packaging/package.sh
@@ -1,9 +1,12 @@
 #!/usr/bin/env bash
-set -o nounset
-set -o errexit
-set -o pipefail
-set -o errtrace
-set -o functrace
+if [ ! -z "${IGNITE_SCRIPT_STRICT_MODE:-}" ]
+then
+    set -o nounset
+    set -o errexit
+    set -o pipefail
+    set -o errtrace
+    set -o functrace
+fi
 
 cd "$(dirname "${BASH_SOURCE[0]}")"    # Run from the script's root
 


[ignite] 04/17: GG-17405 Web Console: Fixed missing e-mail templates in "Direct install" packages.

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit f4f20f7948f828ed8111b98131a1c62183d895a7
Author: Andrey Novikov <an...@gridgain.com>
AuthorDate: Fri Apr 26 18:31:40 2019 +0700

    GG-17405 Web Console: Fixed missing e-mail templates in "Direct install" packages.
---
 modules/web-console/assembly/direct-install.xml |    8 +
 modules/web-console/backend/package.json        |    2 +-
 modules/web-console/frontend/package-lock.json  | 3370 ++++++++++++-----------
 modules/web-console/pom.xml                     |    2 +-
 pom.xml                                         |    6 +-
 5 files changed, 1710 insertions(+), 1678 deletions(-)

diff --git a/modules/web-console/assembly/direct-install.xml b/modules/web-console/assembly/direct-install.xml
index 413dbfa..a695fdd 100644
--- a/modules/web-console/assembly/direct-install.xml
+++ b/modules/web-console/assembly/direct-install.xml
@@ -59,6 +59,14 @@
         </fileSet>
 
         <fileSet>
+            <directory>${project.basedir}/backend/templates</directory>
+            <outputDirectory>/templates</outputDirectory>
+            <includes>
+                <include>*.html</include>
+            </includes>
+        </fileSet>
+
+        <fileSet>
             <directory>${basedir}/backend/build</directory>
             <outputDirectory>/</outputDirectory>
             <includes>
diff --git a/modules/web-console/backend/package.json b/modules/web-console/backend/package.json
index 45a538d..5f15a55 100644
--- a/modules/web-console/backend/package.json
+++ b/modules/web-console/backend/package.json
@@ -69,7 +69,7 @@
     "passport-local": "1.0.0",
     "passport-local-mongoose": "4.0.0",
     "passport.socketio": "3.7.0",
-    "pkg": "4.3.1",
+    "pkg": "4.3.7",
     "socket.io": "2.1.1",
     "uuid": "3.1.0"
   },
diff --git a/modules/web-console/frontend/package-lock.json b/modules/web-console/frontend/package-lock.json
index 4e4f928..ab14044 100644
--- a/modules/web-console/frontend/package-lock.json
+++ b/modules/web-console/frontend/package-lock.json
@@ -5,71 +5,71 @@
   "requires": true,
   "dependencies": {
     "@angular/common": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@angular/common/-/common-7.2.2.tgz",
-      "integrity": "sha512-43EcR3mbM+dKH4VE1EYS1HxSuEToxxv5XPktKqdzY95g8PBOxe11ifcXoYHgImd7YOWzcKoy0k6yQbX3o0cZ8g==",
+      "version": "7.2.14",
+      "resolved": "https://registry.npmjs.org/@angular/common/-/common-7.2.14.tgz",
+      "integrity": "sha512-c2QBhVpbQhg1FDhOQkyVdFvU11mfvYHW5ZaXzxdCpq2rZXCureYiCSnlv++EsIAKqi22+2a6GACHF9Gh8kBmSg==",
       "requires": {
         "tslib": "^1.9.0"
       }
     },
     "@angular/compiler": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@angular/compiler/-/compiler-7.2.2.tgz",
-      "integrity": "sha512-vjPreOVPca6HSuDmj7N1w5u8hwXdm98gEPo2wqQMVuJd6qvGEyLYE9FsHc0XCchyQEKSybAYl1dwsjZq2nNSvQ==",
+      "version": "7.2.14",
+      "resolved": "https://registry.npmjs.org/@angular/compiler/-/compiler-7.2.14.tgz",
+      "integrity": "sha512-Idhs+5HIzx+1+hrXIDaRpSqobMB7UvSvPlvCvtb3EDYjmltTNG68TtwMzGM8W2jdayliYuFOjFrnw1wCTkK3Ag==",
       "requires": {
         "tslib": "^1.9.0"
       }
     },
     "@angular/core": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@angular/core/-/core-7.2.2.tgz",
-      "integrity": "sha512-kQ0HxUYAPvly8b3aibTGbiodFnBBgo3asXAQuPgFjYYEqcKR1zZII7PQdaEF9kb9sfm/IKLKj4nd9fZ0gcgqZg==",
+      "version": "7.2.14",
+      "resolved": "https://registry.npmjs.org/@angular/core/-/core-7.2.14.tgz",
+      "integrity": "sha512-XeZZJCyBKSKo0E/7Ef0SfJejmn+E7uBXa5cR1QapafS0Hnrq/hZu/NI039IDU/51NoycMDH2vTV19SmKu9Mkow==",
       "requires": {
         "tslib": "^1.9.0"
       }
     },
     "@angular/forms": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@angular/forms/-/forms-7.2.2.tgz",
-      "integrity": "sha512-IsvVuUnzIA2ryRmh7l42AANPZFSyNcwqZNtxbmRq2wm3Lfed64U0rsRWWNqipjz7QTxZ2SRdAlP+XDgzg8hvMQ==",
+      "version": "7.2.14",
+      "resolved": "https://registry.npmjs.org/@angular/forms/-/forms-7.2.14.tgz",
+      "integrity": "sha512-jL5YbTk7VZmz4l0++iFVUNa1vGM+nnALjHKi1Ub8VWioRDRboYUsHyxzlgWW9gZRbHpnLEXFiUz1td+v7TouJw==",
       "requires": {
         "tslib": "^1.9.0"
       }
     },
     "@angular/language-service": {
-      "version": "7.2.4",
-      "resolved": "https://registry.npmjs.org/@angular/language-service/-/language-service-7.2.4.tgz",
-      "integrity": "sha512-A9Rud/27hHMSUUjpgn57nVeLsoYgdvFwJhtlZA/oCuSpmlD+LqqBsEpPhivwn++u44+DSrFXsic29jlFnsBotw==",
+      "version": "7.2.14",
+      "resolved": "https://registry.npmjs.org/@angular/language-service/-/language-service-7.2.14.tgz",
+      "integrity": "sha512-YTU4ePAKikbIxNae9Qta8qaDArPgek7nhLEW9QfvrUAnpF7BkVboEI+7yLX5+NTfGf9cQ9cUfQ0TEreV+tMs7A==",
       "dev": true
     },
     "@angular/platform-browser": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@angular/platform-browser/-/platform-browser-7.2.2.tgz",
-      "integrity": "sha512-eiaqHq26PVASx1kTngBDkFkXhaJzEjoGtc5I+wQUef8CUjq6ZViWz8tUgiiDPOWdqUKUacRZG4q6VR/6uwQj0A==",
+      "version": "7.2.14",
+      "resolved": "https://registry.npmjs.org/@angular/platform-browser/-/platform-browser-7.2.14.tgz",
+      "integrity": "sha512-yAq2+3W4J4B48HEmZYQucdEb9AHwRnv72q9CC/SxU7g59vaLhl1nv7cAWGJ4XFaJTbB7aB4Y4rLffuR+Gxkn7A==",
       "requires": {
         "tslib": "^1.9.0"
       }
     },
     "@angular/platform-browser-dynamic": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@angular/platform-browser-dynamic/-/platform-browser-dynamic-7.2.2.tgz",
-      "integrity": "sha512-bw5PuzMzjKMecB4slG/btmvxgn4qFWhNmJVpf2pbtZW7NtZz3HlrqipYzMk9XrCUDGjtwy7O2Z71C3ujI748iw==",
+      "version": "7.2.14",
+      "resolved": "https://registry.npmjs.org/@angular/platform-browser-dynamic/-/platform-browser-dynamic-7.2.14.tgz",
+      "integrity": "sha512-lmTCBiDRbOPtniIqBjm1n5jl1TdyQM0qWQdBcoCsKpMNS/6/RacRcQsJZApAMdWm6gIVuLgmRQzaCLkSoekfYA==",
       "requires": {
         "tslib": "^1.9.0"
       }
     },
     "@angular/router": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@angular/router/-/router-7.2.2.tgz",
-      "integrity": "sha512-+cBC+JxbPdjk+Nyqq27PKkjfIdnc+H+xjMGrkO6dlAKhVMGxyNaYt5NUNugb8XJPsQ1XNXyzwTfZK6jcAGLw6w==",
+      "version": "7.2.14",
+      "resolved": "https://registry.npmjs.org/@angular/router/-/router-7.2.14.tgz",
+      "integrity": "sha512-uqg0SKy79voEOIOvzVbCzFDD9XOAfZWkYt01ca2qLFXMx+6jWeVQIDuXc8Dmz5udIXNK5Ae//9R+nt5UZUZrSA==",
       "requires": {
         "tslib": "^1.9.0"
       }
     },
     "@angular/upgrade": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@angular/upgrade/-/upgrade-7.2.2.tgz",
-      "integrity": "sha512-eKqJuAgu3vce0oHB7BxF4imprvWfLmJbEB2sXtR1ZjeCR/c4WP7CwDaLA5GBKadsJ7oWrS+N7U3Ay+CFJ64pUQ==",
+      "version": "7.2.14",
+      "resolved": "https://registry.npmjs.org/@angular/upgrade/-/upgrade-7.2.14.tgz",
+      "integrity": "sha512-KWgIxrkUYNi67Na/Ue0Gzi4r+kSi7LVsaoYxHebiKZmcrnclIMpEEk9v9/YN1jyZCxdxXBK+LCne7VMhmgAZSw==",
       "requires": {
         "tslib": "^1.9.0"
       }
@@ -116,13 +116,13 @@
       }
     },
     "@babel/generator": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@babel/generator/-/generator-7.2.2.tgz",
-      "integrity": "sha512-I4o675J/iS8k+P38dvJ3IBGqObLXyQLTxtrR4u9cSUJOURvafeEWb/pFMOTwtNrmq73mJzyF6ueTbO1BtN0Zeg==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/generator/-/generator-7.4.0.tgz",
+      "integrity": "sha512-/v5I+a1jhGSKLgZDcmAUZ4K/VePi43eRkUs3yePW1HB1iANOD5tqJXwGSG4BZhSksP8J9ejSlwGeTiiOFZOrXQ==",
       "requires": {
-        "@babel/types": "^7.2.2",
+        "@babel/types": "^7.4.0",
         "jsesc": "^2.5.1",
-        "lodash": "^4.17.10",
+        "lodash": "^4.17.11",
         "source-map": "^0.5.0",
         "trim-right": "^1.0.1"
       }
@@ -147,37 +147,38 @@
       }
     },
     "@babel/helper-call-delegate": {
-      "version": "7.1.0",
-      "resolved": "https://registry.npmjs.org/@babel/helper-call-delegate/-/helper-call-delegate-7.1.0.tgz",
-      "integrity": "sha512-YEtYZrw3GUK6emQHKthltKNZwszBcHK58Ygcis+gVUrF4/FmTVr5CCqQNSfmvg2y+YDEANyYoaLz/SHsnusCwQ==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/helper-call-delegate/-/helper-call-delegate-7.4.0.tgz",
+      "integrity": "sha512-SdqDfbVdNQCBp3WhK2mNdDvHd3BD6qbmIc43CAyjnsfCmgHMeqgDcM3BzY2lchi7HBJGJ2CVdynLWbezaE4mmQ==",
       "requires": {
-        "@babel/helper-hoist-variables": "^7.0.0",
-        "@babel/traverse": "^7.1.0",
-        "@babel/types": "^7.0.0"
+        "@babel/helper-hoist-variables": "^7.4.0",
+        "@babel/traverse": "^7.4.0",
+        "@babel/types": "^7.4.0"
       }
     },
     "@babel/helper-create-class-features-plugin": {
-      "version": "7.3.0",
-      "resolved": "https://registry.npmjs.org/@babel/helper-create-class-features-plugin/-/helper-create-class-features-plugin-7.3.0.tgz",
-      "integrity": "sha512-DUsQNS2CGLZZ7I3W3fvh0YpPDd6BuWJlDl+qmZZpABZHza2ErE3LxtEzLJFHFC1ZwtlAXvHhbFYbtM5o5B0WBw==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/helper-create-class-features-plugin/-/helper-create-class-features-plugin-7.4.3.tgz",
+      "integrity": "sha512-UMl3TSpX11PuODYdWGrUeW6zFkdYhDn7wRLrOuNVM6f9L+S9CzmDXYyrp3MTHcwWjnzur1f/Op8A7iYZWya2Yg==",
       "dev": true,
       "requires": {
         "@babel/helper-function-name": "^7.1.0",
         "@babel/helper-member-expression-to-functions": "^7.0.0",
         "@babel/helper-optimise-call-expression": "^7.0.0",
         "@babel/helper-plugin-utils": "^7.0.0",
-        "@babel/helper-replace-supers": "^7.2.3"
+        "@babel/helper-replace-supers": "^7.4.0",
+        "@babel/helper-split-export-declaration": "^7.4.0"
       }
     },
     "@babel/helper-define-map": {
-      "version": "7.1.0",
-      "resolved": "https://registry.npmjs.org/@babel/helper-define-map/-/helper-define-map-7.1.0.tgz",
-      "integrity": "sha512-yPPcW8dc3gZLN+U1mhYV91QU3n5uTbx7DUdf8NnPbjS0RMwBuHi9Xt2MUgppmNz7CJxTBWsGczTiEp1CSOTPRg==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/helper-define-map/-/helper-define-map-7.4.0.tgz",
+      "integrity": "sha512-wAhQ9HdnLIywERVcSvX40CEJwKdAa1ID4neI9NXQPDOHwwA+57DqwLiPEVy2AIyWzAk0CQ8qx4awO0VUURwLtA==",
       "dev": true,
       "requires": {
         "@babel/helper-function-name": "^7.1.0",
-        "@babel/types": "^7.0.0",
-        "lodash": "^4.17.10"
+        "@babel/types": "^7.4.0",
+        "lodash": "^4.17.11"
       }
     },
     "@babel/helper-explode-assignable-expression": {
@@ -209,11 +210,11 @@
       }
     },
     "@babel/helper-hoist-variables": {
-      "version": "7.0.0",
-      "resolved": "https://registry.npmjs.org/@babel/helper-hoist-variables/-/helper-hoist-variables-7.0.0.tgz",
-      "integrity": "sha512-Ggv5sldXUeSKsuzLkddtyhyHe2YantsxWKNi7A+7LeD12ExRDWTRk29JCXpaHPAbMaIPZSil7n+lq78WY2VY7w==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/helper-hoist-variables/-/helper-hoist-variables-7.4.0.tgz",
+      "integrity": "sha512-/NErCuoe/et17IlAQFKWM24qtyYYie7sFIrW/tIQXpck6vAu2hhtYYsKLBWQV+BQZMbcIYPU/QMYuTufrY4aQw==",
       "requires": {
-        "@babel/types": "^7.0.0"
+        "@babel/types": "^7.4.0"
       }
     },
     "@babel/helper-member-expression-to-functions": {
@@ -235,9 +236,9 @@
       }
     },
     "@babel/helper-module-transforms": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@babel/helper-module-transforms/-/helper-module-transforms-7.2.2.tgz",
-      "integrity": "sha512-YRD7I6Wsv+IHuTPkAmAS4HhY0dkPobgLftHp0cRGZSdrRvmZY8rFvae/GVu3bD00qscuvK3WPHB3YdNpBXUqrA==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/helper-module-transforms/-/helper-module-transforms-7.4.3.tgz",
+      "integrity": "sha512-H88T9IySZW25anu5uqyaC1DaQre7ofM+joZtAaO2F8NBdFfupH0SZ4gKjgSFVcvtx/aAirqA9L9Clio2heYbZA==",
       "dev": true,
       "requires": {
         "@babel/helper-module-imports": "^7.0.0",
@@ -245,7 +246,7 @@
         "@babel/helper-split-export-declaration": "^7.0.0",
         "@babel/template": "^7.2.2",
         "@babel/types": "^7.2.2",
-        "lodash": "^4.17.10"
+        "lodash": "^4.17.11"
       }
     },
     "@babel/helper-optimise-call-expression": {
@@ -263,12 +264,12 @@
       "integrity": "sha512-CYAOUCARwExnEixLdB6sDm2dIJ/YgEAKDM1MOeMeZu9Ld/bDgVo8aiWrXwcY7OBh+1Ea2uUcVRcxKk0GJvW7QA=="
     },
     "@babel/helper-regex": {
-      "version": "7.0.0",
-      "resolved": "https://registry.npmjs.org/@babel/helper-regex/-/helper-regex-7.0.0.tgz",
-      "integrity": "sha512-TR0/N0NDCcUIUEbqV6dCO+LptmmSQFQ7q70lfcEB4URsjD0E1HzicrwUH+ap6BAQ2jhCX9Q4UqZy4wilujWlkg==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/helper-regex/-/helper-regex-7.4.3.tgz",
+      "integrity": "sha512-hnoq5u96pLCfgjXuj8ZLX3QQ+6nAulS+zSgi6HulUwFbEruRAKwbGLU5OvXkE14L8XW6XsQEKsIDfgthKLRAyA==",
       "dev": true,
       "requires": {
-        "lodash": "^4.17.10"
+        "lodash": "^4.17.11"
       }
     },
     "@babel/helper-remap-async-to-generator": {
@@ -285,15 +286,15 @@
       }
     },
     "@babel/helper-replace-supers": {
-      "version": "7.2.3",
-      "resolved": "https://registry.npmjs.org/@babel/helper-replace-supers/-/helper-replace-supers-7.2.3.tgz",
-      "integrity": "sha512-GyieIznGUfPXPWu0yLS6U55Mz67AZD9cUk0BfirOWlPrXlBcan9Gz+vHGz+cPfuoweZSnPzPIm67VtQM0OWZbA==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/helper-replace-supers/-/helper-replace-supers-7.4.0.tgz",
+      "integrity": "sha512-PVwCVnWWAgnal+kJ+ZSAphzyl58XrFeSKSAJRiqg5QToTsjL+Xu1f9+RJ+d+Q0aPhPfBGaYfkox66k86thxNSg==",
       "dev": true,
       "requires": {
         "@babel/helper-member-expression-to-functions": "^7.0.0",
         "@babel/helper-optimise-call-expression": "^7.0.0",
-        "@babel/traverse": "^7.2.3",
-        "@babel/types": "^7.0.0"
+        "@babel/traverse": "^7.4.0",
+        "@babel/types": "^7.4.0"
       }
     },
     "@babel/helper-simple-access": {
@@ -307,11 +308,11 @@
       }
     },
     "@babel/helper-split-export-declaration": {
-      "version": "7.0.0",
-      "resolved": "https://registry.npmjs.org/@babel/helper-split-export-declaration/-/helper-split-export-declaration-7.0.0.tgz",
-      "integrity": "sha512-MXkOJqva62dfC0w85mEf/LucPPS/1+04nmmRMPEBUB++hiiThQ2zPtX/mEWQ3mtzCEjIJvPY8nuwxXtQeQwUag==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/helper-split-export-declaration/-/helper-split-export-declaration-7.4.0.tgz",
+      "integrity": "sha512-7Cuc6JZiYShaZnybDmfwhY4UYHzI6rlqhWjaIqbsJGsIqPimEYy5uh3akSRLMg65LSdSEnJ8a8/bWQN6u2oMGw==",
       "requires": {
-        "@babel/types": "^7.0.0"
+        "@babel/types": "^7.4.0"
       }
     },
     "@babel/helper-wrap-function": {
@@ -327,14 +328,14 @@
       }
     },
     "@babel/helpers": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/helpers/-/helpers-7.2.0.tgz",
-      "integrity": "sha512-Fr07N+ea0dMcMN8nFpuK6dUIT7/ivt9yKQdEEnjVS83tG2pHwPi03gYmk/tyuwONnZ+sY+GFFPlWGgCtW1hF9A==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/helpers/-/helpers-7.4.3.tgz",
+      "integrity": "sha512-BMh7X0oZqb36CfyhvtbSmcWc3GXocfxv3yNsAEuM0l+fAqSO22rQrUpijr3oE/10jCTrB6/0b9kzmG4VetCj8Q==",
       "dev": true,
       "requires": {
-        "@babel/template": "^7.1.2",
-        "@babel/traverse": "^7.1.5",
-        "@babel/types": "^7.2.0"
+        "@babel/template": "^7.4.0",
+        "@babel/traverse": "^7.4.3",
+        "@babel/types": "^7.4.0"
       }
     },
     "@babel/highlight": {
@@ -345,12 +346,24 @@
         "chalk": "^2.0.0",
         "esutils": "^2.0.2",
         "js-tokens": "^4.0.0"
+      },
+      "dependencies": {
+        "chalk": {
+          "version": "2.4.2",
+          "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.4.2.tgz",
+          "integrity": "sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==",
+          "requires": {
+            "ansi-styles": "^3.2.1",
+            "escape-string-regexp": "^1.0.5",
+            "supports-color": "^5.3.0"
+          }
+        }
       }
     },
     "@babel/parser": {
-      "version": "7.2.3",
-      "resolved": "https://registry.npmjs.org/@babel/parser/-/parser-7.2.3.tgz",
-      "integrity": "sha512-0LyEcVlfCoFmci8mXx8A5oIkpkOgyo8dRHtxBnK9RRBwxO2+JZPNsqtVEZQ7mJFPxnXF9lfmU24mHOPI0qnlkA=="
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/parser/-/parser-7.4.3.tgz",
+      "integrity": "sha512-gxpEUhTS1sGA63EGQGuA+WESPR/6tz6ng7tSHFCmaTJK/cGK8y37cBTspX+U2xCAue2IQVvF6Z0oigmjwD8YGQ=="
     },
     "@babel/plugin-proposal-async-generator-functions": {
       "version": "7.2.0",
@@ -378,12 +391,12 @@
       }
     },
     "@babel/plugin-proposal-decorators": {
-      "version": "7.3.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-proposal-decorators/-/plugin-proposal-decorators-7.3.0.tgz",
-      "integrity": "sha512-3W/oCUmsO43FmZIqermmq6TKaRSYhmh/vybPfVFwQWdSb8xwki38uAIvknCRzuyHRuYfCYmJzL9or1v0AffPjg==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-proposal-decorators/-/plugin-proposal-decorators-7.4.0.tgz",
+      "integrity": "sha512-d08TLmXeK/XbgCo7ZeZ+JaeZDtDai/2ctapTRsWWkkmy7G/cqz8DQN/HlWG7RR4YmfXxmExsbU3SuCjlM7AtUg==",
       "dev": true,
       "requires": {
-        "@babel/helper-create-class-features-plugin": "^7.3.0",
+        "@babel/helper-create-class-features-plugin": "^7.4.0",
         "@babel/helper-plugin-utils": "^7.0.0",
         "@babel/plugin-syntax-decorators": "^7.2.0"
       }
@@ -419,14 +432,14 @@
       }
     },
     "@babel/plugin-proposal-unicode-property-regex": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-proposal-unicode-property-regex/-/plugin-proposal-unicode-property-regex-7.2.0.tgz",
-      "integrity": "sha512-LvRVYb7kikuOtIoUeWTkOxQEV1kYvL5B6U3iWEGCzPNRus1MzJweFqORTj+0jkxozkTSYNJozPOddxmqdqsRpw==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-proposal-unicode-property-regex/-/plugin-proposal-unicode-property-regex-7.4.0.tgz",
+      "integrity": "sha512-h/KjEZ3nK9wv1P1FSNb9G079jXrNYR0Ko+7XkOx85+gM24iZbPn0rh4vCftk+5QKY7y1uByFataBTmX7irEF1w==",
       "dev": true,
       "requires": {
         "@babel/helper-plugin-utils": "^7.0.0",
         "@babel/helper-regex": "^7.0.0",
-        "regexpu-core": "^4.2.0"
+        "regexpu-core": "^4.5.4"
       }
     },
     "@babel/plugin-syntax-async-generators": {
@@ -493,9 +506,9 @@
       }
     },
     "@babel/plugin-syntax-typescript": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-syntax-typescript/-/plugin-syntax-typescript-7.2.0.tgz",
-      "integrity": "sha512-WhKr6yu6yGpGcNMVgIBuI9MkredpVc7Y3YR4UzEZmDztHoL6wV56YBHLhWnjO1EvId1B32HrD3DRFc+zSoKI1g==",
+      "version": "7.3.3",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-syntax-typescript/-/plugin-syntax-typescript-7.3.3.tgz",
+      "integrity": "sha512-dGwbSMA1YhVS8+31CnPR7LB4pcbrzcV99wQzby4uAfrkZPYZlQ7ImwdpzLqi6Z6IL02b8IAL379CaMwo0x5Lag==",
       "dev": true,
       "requires": {
         "@babel/helper-plugin-utils": "^7.0.0"
@@ -511,9 +524,9 @@
       }
     },
     "@babel/plugin-transform-async-to-generator": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-async-to-generator/-/plugin-transform-async-to-generator-7.2.0.tgz",
-      "integrity": "sha512-CEHzg4g5UraReozI9D4fblBYABs7IM6UerAVG7EJVrTLC5keh00aEuLUT+O40+mJCEzaXkYfTCUKIyeDfMOFFQ==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-async-to-generator/-/plugin-transform-async-to-generator-7.4.0.tgz",
+      "integrity": "sha512-EeaFdCeUULM+GPFEsf7pFcNSxM7hYjoj5fiYbyuiXobW4JhFnjAv9OWzNwHyHcKoPNpAfeRDuW6VyaXEDUBa7g==",
       "dev": true,
       "requires": {
         "@babel/helper-module-imports": "^7.0.0",
@@ -531,28 +544,28 @@
       }
     },
     "@babel/plugin-transform-block-scoping": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-block-scoping/-/plugin-transform-block-scoping-7.2.0.tgz",
-      "integrity": "sha512-vDTgf19ZEV6mx35yiPJe4fS02mPQUUcBNwWQSZFXSzTSbsJFQvHt7DqyS3LK8oOWALFOsJ+8bbqBgkirZteD5Q==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-block-scoping/-/plugin-transform-block-scoping-7.4.0.tgz",
+      "integrity": "sha512-AWyt3k+fBXQqt2qb9r97tn3iBwFpiv9xdAiG+Gr2HpAZpuayvbL55yWrsV3MyHvXk/4vmSiedhDRl1YI2Iy5nQ==",
       "dev": true,
       "requires": {
         "@babel/helper-plugin-utils": "^7.0.0",
-        "lodash": "^4.17.10"
+        "lodash": "^4.17.11"
       }
     },
     "@babel/plugin-transform-classes": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-classes/-/plugin-transform-classes-7.2.2.tgz",
-      "integrity": "sha512-gEZvgTy1VtcDOaQty1l10T3jQmJKlNVxLDCs+3rCVPr6nMkODLELxViq5X9l+rfxbie3XrfrMCYYY6eX3aOcOQ==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-classes/-/plugin-transform-classes-7.4.3.tgz",
+      "integrity": "sha512-PUaIKyFUDtG6jF5DUJOfkBdwAS/kFFV3XFk7Nn0a6vR7ZT8jYw5cGtIlat77wcnd0C6ViGqo/wyNf4ZHytF/nQ==",
       "dev": true,
       "requires": {
         "@babel/helper-annotate-as-pure": "^7.0.0",
-        "@babel/helper-define-map": "^7.1.0",
+        "@babel/helper-define-map": "^7.4.0",
         "@babel/helper-function-name": "^7.1.0",
         "@babel/helper-optimise-call-expression": "^7.0.0",
         "@babel/helper-plugin-utils": "^7.0.0",
-        "@babel/helper-replace-supers": "^7.1.0",
-        "@babel/helper-split-export-declaration": "^7.0.0",
+        "@babel/helper-replace-supers": "^7.4.0",
+        "@babel/helper-split-export-declaration": "^7.4.0",
         "globals": "^11.1.0"
       }
     },
@@ -566,23 +579,23 @@
       }
     },
     "@babel/plugin-transform-destructuring": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-destructuring/-/plugin-transform-destructuring-7.2.0.tgz",
-      "integrity": "sha512-coVO2Ayv7g0qdDbrNiadE4bU7lvCd9H539m2gMknyVjjMdwF/iCOM7R+E8PkntoqLkltO0rk+3axhpp/0v68VQ==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-destructuring/-/plugin-transform-destructuring-7.4.3.tgz",
+      "integrity": "sha512-rVTLLZpydDFDyN4qnXdzwoVpk1oaXHIvPEOkOLyr88o7oHxVc/LyrnDx+amuBWGOwUb7D1s/uLsKBNTx08htZg==",
       "dev": true,
       "requires": {
         "@babel/helper-plugin-utils": "^7.0.0"
       }
     },
     "@babel/plugin-transform-dotall-regex": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-dotall-regex/-/plugin-transform-dotall-regex-7.2.0.tgz",
-      "integrity": "sha512-sKxnyHfizweTgKZf7XsXu/CNupKhzijptfTM+bozonIuyVrLWVUvYjE2bhuSBML8VQeMxq4Mm63Q9qvcvUcciQ==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-dotall-regex/-/plugin-transform-dotall-regex-7.4.3.tgz",
+      "integrity": "sha512-9Arc2I0AGynzXRR/oPdSALv3k0rM38IMFyto7kOCwb5F9sLUt2Ykdo3V9yUPR+Bgr4kb6bVEyLkPEiBhzcTeoA==",
       "dev": true,
       "requires": {
         "@babel/helper-plugin-utils": "^7.0.0",
-        "@babel/helper-regex": "^7.0.0",
-        "regexpu-core": "^4.1.3"
+        "@babel/helper-regex": "^7.4.3",
+        "regexpu-core": "^4.5.4"
       }
     },
     "@babel/plugin-transform-duplicate-keys": {
@@ -605,18 +618,18 @@
       }
     },
     "@babel/plugin-transform-for-of": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-for-of/-/plugin-transform-for-of-7.2.0.tgz",
-      "integrity": "sha512-Kz7Mt0SsV2tQk6jG5bBv5phVbkd0gd27SgYD4hH1aLMJRchM0dzHaXvrWhVZ+WxAlDoAKZ7Uy3jVTW2mKXQ1WQ==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-for-of/-/plugin-transform-for-of-7.4.3.tgz",
+      "integrity": "sha512-UselcZPwVWNSURnqcfpnxtMehrb8wjXYOimlYQPBnup/Zld426YzIhNEvuRsEWVHfESIECGrxoI6L5QqzuLH5Q==",
       "dev": true,
       "requires": {
         "@babel/helper-plugin-utils": "^7.0.0"
       }
     },
     "@babel/plugin-transform-function-name": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-function-name/-/plugin-transform-function-name-7.2.0.tgz",
-      "integrity": "sha512-kWgksow9lHdvBC2Z4mxTsvc7YdY7w/V6B2vy9cTIPtLEE9NhwoWivaxdNM/S37elu5bqlLP/qOY906LukO9lkQ==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-function-name/-/plugin-transform-function-name-7.4.3.tgz",
+      "integrity": "sha512-uT5J/3qI/8vACBR9I1GlAuU/JqBtWdfCrynuOkrWG6nCDieZd5przB1vfP59FRHBZQ9DC2IUfqr/xKqzOD5x0A==",
       "dev": true,
       "requires": {
         "@babel/helper-function-name": "^7.1.0",
@@ -643,23 +656,23 @@
       }
     },
     "@babel/plugin-transform-modules-commonjs": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-modules-commonjs/-/plugin-transform-modules-commonjs-7.2.0.tgz",
-      "integrity": "sha512-V6y0uaUQrQPXUrmj+hgnks8va2L0zcZymeU7TtWEgdRLNkceafKXEduv7QzgQAE4lT+suwooG9dC7LFhdRAbVQ==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-modules-commonjs/-/plugin-transform-modules-commonjs-7.4.3.tgz",
+      "integrity": "sha512-sMP4JqOTbMJMimqsSZwYWsMjppD+KRyDIUVW91pd7td0dZKAvPmhCaxhOzkzLParKwgQc7bdL9UNv+rpJB0HfA==",
       "dev": true,
       "requires": {
-        "@babel/helper-module-transforms": "^7.1.0",
+        "@babel/helper-module-transforms": "^7.4.3",
         "@babel/helper-plugin-utils": "^7.0.0",
         "@babel/helper-simple-access": "^7.1.0"
       }
     },
     "@babel/plugin-transform-modules-systemjs": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-modules-systemjs/-/plugin-transform-modules-systemjs-7.2.0.tgz",
-      "integrity": "sha512-aYJwpAhoK9a+1+O625WIjvMY11wkB/ok0WClVwmeo3mCjcNRjt+/8gHWrB5i+00mUju0gWsBkQnPpdvQ7PImmQ==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-modules-systemjs/-/plugin-transform-modules-systemjs-7.4.0.tgz",
+      "integrity": "sha512-gjPdHmqiNhVoBqus5qK60mWPp1CmYWp/tkh11mvb0rrys01HycEGD7NvvSoKXlWEfSM9TcL36CpsK8ElsADptQ==",
       "dev": true,
       "requires": {
-        "@babel/helper-hoist-variables": "^7.0.0",
+        "@babel/helper-hoist-variables": "^7.4.0",
         "@babel/helper-plugin-utils": "^7.0.0"
       }
     },
@@ -674,9 +687,9 @@
       }
     },
     "@babel/plugin-transform-new-target": {
-      "version": "7.0.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-new-target/-/plugin-transform-new-target-7.0.0.tgz",
-      "integrity": "sha512-yin069FYjah+LbqfGeTfzIBODex/e++Yfa0rH0fpfam9uTbuEeEOx5GLGr210ggOV77mVRNoeqSYqeuaqSzVSw==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-new-target/-/plugin-transform-new-target-7.4.0.tgz",
+      "integrity": "sha512-6ZKNgMQmQmrEX/ncuCwnnw1yVGoaOW5KpxNhoWI7pCQdA0uZ0HqHGqenCUIENAnxRjy2WwNQ30gfGdIgqJXXqw==",
       "dev": true,
       "requires": {
         "@babel/helper-plugin-utils": "^7.0.0"
@@ -703,12 +716,12 @@
       }
     },
     "@babel/plugin-transform-regenerator": {
-      "version": "7.0.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-regenerator/-/plugin-transform-regenerator-7.0.0.tgz",
-      "integrity": "sha512-sj2qzsEx8KDVv1QuJc/dEfilkg3RRPvPYx/VnKLtItVQRWt1Wqf5eVCOLZm29CiGFfYYsA3VPjfizTCV0S0Dlw==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-regenerator/-/plugin-transform-regenerator-7.4.3.tgz",
+      "integrity": "sha512-kEzotPuOpv6/iSlHroCDydPkKYw7tiJGKlmYp6iJn4a6C/+b2FdttlJsLKYxolYHgotTJ5G5UY5h0qey5ka3+A==",
       "dev": true,
       "requires": {
-        "regenerator-transform": "^0.13.3"
+        "regenerator-transform": "^0.13.4"
       }
     },
     "@babel/plugin-transform-shorthand-properties": {
@@ -759,9 +772,9 @@
       }
     },
     "@babel/plugin-transform-typescript": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-typescript/-/plugin-transform-typescript-7.2.0.tgz",
-      "integrity": "sha512-EnI7i2/gJ7ZNr2MuyvN2Hu+BHJENlxWte5XygPvfj/MbvtOkWor9zcnHpMMQL2YYaaCcqtIvJUyJ7QVfoGs7ew==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-typescript/-/plugin-transform-typescript-7.4.0.tgz",
+      "integrity": "sha512-U7/+zKnRZg04ggM/Bm+xmu2B/PrwyDQTT/V89FXWYWNMxBDwSx56u6jtk9SEbfLFbZaEI72L+5LPvQjeZgFCrQ==",
       "dev": true,
       "requires": {
         "@babel/helper-plugin-utils": "^7.0.0",
@@ -769,14 +782,14 @@
       }
     },
     "@babel/plugin-transform-unicode-regex": {
-      "version": "7.2.0",
-      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-unicode-regex/-/plugin-transform-unicode-regex-7.2.0.tgz",
-      "integrity": "sha512-m48Y0lMhrbXEJnVUaYly29jRXbQ3ksxPrS1Tg8t+MHqzXhtBYAvI51euOBaoAlZLPHsieY9XPVMf80a5x0cPcA==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-transform-unicode-regex/-/plugin-transform-unicode-regex-7.4.3.tgz",
+      "integrity": "sha512-lnSNgkVjL8EMtnE8eSS7t2ku8qvKH3eqNf/IwIfnSPUqzgqYmRwzdsQWv4mNQAN9Nuo6Gz1Y0a4CSmdpu1Pp6g==",
       "dev": true,
       "requires": {
         "@babel/helper-plugin-utils": "^7.0.0",
-        "@babel/helper-regex": "^7.0.0",
-        "regexpu-core": "^4.1.3"
+        "@babel/helper-regex": "^7.4.3",
+        "regexpu-core": "^4.5.4"
       }
     },
     "@babel/preset-env": {
@@ -839,38 +852,38 @@
       }
     },
     "@babel/template": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@babel/template/-/template-7.2.2.tgz",
-      "integrity": "sha512-zRL0IMM02AUDwghf5LMSSDEz7sBCO2YnNmpg3uWTZj/v1rcG2BmQUvaGU8GhU8BvfMh1k2KIAYZ7Ji9KXPUg7g==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/template/-/template-7.4.0.tgz",
+      "integrity": "sha512-SOWwxxClTTh5NdbbYZ0BmaBVzxzTh2tO/TeLTbF6MO6EzVhHTnff8CdBXx3mEtazFBoysmEM6GU/wF+SuSx4Fw==",
       "requires": {
         "@babel/code-frame": "^7.0.0",
-        "@babel/parser": "^7.2.2",
-        "@babel/types": "^7.2.2"
+        "@babel/parser": "^7.4.0",
+        "@babel/types": "^7.4.0"
       }
     },
     "@babel/traverse": {
-      "version": "7.2.3",
-      "resolved": "https://registry.npmjs.org/@babel/traverse/-/traverse-7.2.3.tgz",
-      "integrity": "sha512-Z31oUD/fJvEWVR0lNZtfgvVt512ForCTNKYcJBGbPb1QZfve4WGH8Wsy7+Mev33/45fhP/hwQtvgusNdcCMgSw==",
+      "version": "7.4.3",
+      "resolved": "https://registry.npmjs.org/@babel/traverse/-/traverse-7.4.3.tgz",
+      "integrity": "sha512-HmA01qrtaCwwJWpSKpA948cBvU5BrmviAief/b3AVw936DtcdsTexlbyzNuDnthwhOQ37xshn7hvQaEQk7ISYQ==",
       "requires": {
         "@babel/code-frame": "^7.0.0",
-        "@babel/generator": "^7.2.2",
+        "@babel/generator": "^7.4.0",
         "@babel/helper-function-name": "^7.1.0",
-        "@babel/helper-split-export-declaration": "^7.0.0",
-        "@babel/parser": "^7.2.3",
-        "@babel/types": "^7.2.2",
+        "@babel/helper-split-export-declaration": "^7.4.0",
+        "@babel/parser": "^7.4.3",
+        "@babel/types": "^7.4.0",
         "debug": "^4.1.0",
         "globals": "^11.1.0",
-        "lodash": "^4.17.10"
+        "lodash": "^4.17.11"
       }
     },
     "@babel/types": {
-      "version": "7.2.2",
-      "resolved": "https://registry.npmjs.org/@babel/types/-/types-7.2.2.tgz",
-      "integrity": "sha512-fKCuD6UFUMkR541eDWL+2ih/xFZBXPOg/7EQFeTluMDebfqR4jrpaCjLhkWlQS4hT6nRa2PMEgXKbRB5/H2fpg==",
+      "version": "7.4.0",
+      "resolved": "https://registry.npmjs.org/@babel/types/-/types-7.4.0.tgz",
+      "integrity": "sha512-aPvkXyU2SPOnztlgo8n9cEiXW755mgyvueUPcpStqdzoSPm0fjO0vQBjLkt3JKJW7ufikfcnMTTPsN1xaTsBPA==",
       "requires": {
         "esutils": "^2.0.2",
-        "lodash": "^4.17.10",
+        "lodash": "^4.17.11",
         "to-fast-properties": "^2.0.0"
       }
     },
@@ -939,24 +952,24 @@
       }
     },
     "@types/babel-types": {
-      "version": "7.0.4",
-      "resolved": "https://registry.npmjs.org/@types/babel-types/-/babel-types-7.0.4.tgz",
-      "integrity": "sha512-WiZhq3SVJHFRgRYLXvpf65XnV6ipVHhnNaNvE8yCimejrGglkg38kEj0JcizqwSHxmPSjcTlig/6JouxLGEhGw==",
+      "version": "7.0.7",
+      "resolved": "https://registry.npmjs.org/@types/babel-types/-/babel-types-7.0.7.tgz",
+      "integrity": "sha512-dBtBbrc+qTHy1WdfHYjBwRln4+LWqASWakLHsWHR2NWHIFkv4W3O070IGoGLEBrJBvct3r0L1BUPuvURi7kYUQ==",
       "dev": true
     },
     "@types/babylon": {
-      "version": "6.16.4",
-      "resolved": "https://registry.npmjs.org/@types/babylon/-/babylon-6.16.4.tgz",
-      "integrity": "sha512-8dZMcGPno3g7pJ/d0AyJERo+lXh9i1JhDuCUs+4lNIN9eUe5Yh6UCLrpgSEi05Ve2JMLauL2aozdvKwNL0px1Q==",
+      "version": "6.16.5",
+      "resolved": "https://registry.npmjs.org/@types/babylon/-/babylon-6.16.5.tgz",
+      "integrity": "sha512-xH2e58elpj1X4ynnKp9qSnWlsRTIs6n3tgLGNfwAGHwePw0mulHQllV34n0T25uYSu1k0hRKkWXF890B1yS47w==",
       "dev": true,
       "requires": {
         "@types/babel-types": "*"
       }
     },
     "@types/bluebird": {
-      "version": "3.5.25",
-      "resolved": "https://registry.npmjs.org/@types/bluebird/-/bluebird-3.5.25.tgz",
-      "integrity": "sha512-yfhIBix+AIFTmYGtkC0Bi+XGjSkOINykqKvO/Wqdz/DuXlAKK7HmhLAXdPIGsV4xzKcL3ev/zYc4yLNo+OvGaw==",
+      "version": "3.5.26",
+      "resolved": "https://registry.npmjs.org/@types/bluebird/-/bluebird-3.5.26.tgz",
+      "integrity": "sha512-aj2mrBLn5ky0GmAg6IPXrQjnN0iB/ulozuJ+oZdrHRAzRbXjGmu4UXsNCjFvPbSaaPZmniocdOzsM392qLOlmQ==",
       "dev": true
     },
     "@types/chai": {
@@ -1028,9 +1041,9 @@
       "dev": true
     },
     "@types/q": {
-      "version": "1.5.1",
-      "resolved": "https://registry.npmjs.org/@types/q/-/q-1.5.1.tgz",
-      "integrity": "sha512-eqz8c/0kwNi/OEHQfvIuJVLTst3in0e7uTKeuY+WL/zfKn0xVujOTp42bS/vUUokhK5P2BppLd9JXMOMHcgbjA==",
+      "version": "1.5.2",
+      "resolved": "https://registry.npmjs.org/@types/q/-/q-1.5.2.tgz",
+      "integrity": "sha512-ce5d3q03Ex0sy4R14722Rmt6MT07Ua+k4FwDfdcToYJcMKNtRVQvJ6JCAPdAmAnbRb6CsX6aYb9m96NGod9uTw==",
       "dev": true
     },
     "@types/sinon": {
@@ -1381,7 +1394,8 @@
     "abbrev": {
       "version": "1.1.1",
       "resolved": "https://registry.npmjs.org/abbrev/-/abbrev-1.1.1.tgz",
-      "integrity": "sha512-nne9/IiQ/hzIhY6pdDnbBtz7DjPTKrY00P/zvPSm5pOFkl6xuGrGnXn/VtTNNfNtAfZ9/1RtehkszU9qcTii0Q=="
+      "integrity": "sha512-nne9/IiQ/hzIhY6pdDnbBtz7DjPTKrY00P/zvPSm5pOFkl6xuGrGnXn/VtTNNfNtAfZ9/1RtehkszU9qcTii0Q==",
+      "dev": true
     },
     "accepts": {
       "version": "1.3.5",
@@ -1394,11 +1408,28 @@
       }
     },
     "acorn": {
-      "version": "5.7.3",
-      "resolved": "https://registry.npmjs.org/acorn/-/acorn-5.7.3.tgz",
-      "integrity": "sha512-T/zvzYRfbVojPWahDsE5evJdHb3oJoQfFbsrKM7w5Zcs++Tr257tia3BmMP8XYVjp1S9RZXQMh7gao96BlqZOw==",
+      "version": "6.1.1",
+      "resolved": "https://registry.npmjs.org/acorn/-/acorn-6.1.1.tgz",
+      "integrity": "sha512-jPTiwtOxaHNaAPg/dmrJ/beuzLRnXtB0kQPQ8JpotKJgTB6rX6c8mlf315941pyjBSaPg8NHXS9fhP4u17DpGA==",
       "dev": true
     },
+    "acorn-dynamic-import": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/acorn-dynamic-import/-/acorn-dynamic-import-3.0.0.tgz",
+      "integrity": "sha512-zVWV8Z8lislJoOKKqdNMOB+s6+XV5WERty8MnKBeFgwA+19XJjJHs2RP5dzM57FftIs+jQnRToLiWazKr6sSWg==",
+      "dev": true,
+      "requires": {
+        "acorn": "^5.0.0"
+      },
+      "dependencies": {
+        "acorn": {
+          "version": "5.7.3",
+          "resolved": "https://registry.npmjs.org/acorn/-/acorn-5.7.3.tgz",
+          "integrity": "sha512-T/zvzYRfbVojPWahDsE5evJdHb3oJoQfFbsrKM7w5Zcs++Tr257tia3BmMP8XYVjp1S9RZXQMh7gao96BlqZOw==",
+          "dev": true
+        }
+      }
+    },
     "acorn-globals": {
       "version": "3.1.0",
       "resolved": "https://registry.npmjs.org/acorn-globals/-/acorn-globals-3.1.0.tgz",
@@ -1474,15 +1505,15 @@
       "integrity": "sha1-/ts5T58OAqqXaOcCvaI7UF+ufh8="
     },
     "ajv": {
-      "version": "5.5.2",
-      "resolved": "https://registry.npmjs.org/ajv/-/ajv-5.5.2.tgz",
-      "integrity": "sha1-c7Xuyj+rZT49P5Qis0GtQiBdyWU=",
+      "version": "6.10.0",
+      "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.10.0.tgz",
+      "integrity": "sha512-nffhOpkymDECQyR0mnsUtoCE8RlX38G0rYP+wgLWFyZuUyuuojSSvi/+euOiQBIn63whYwYVIIH1TvE3tu4OEg==",
       "dev": true,
       "requires": {
-        "co": "^4.6.0",
-        "fast-deep-equal": "^1.0.0",
+        "fast-deep-equal": "^2.0.1",
         "fast-json-stable-stringify": "^2.0.0",
-        "json-schema-traverse": "^0.3.0"
+        "json-schema-traverse": "^0.4.1",
+        "uri-js": "^4.2.2"
       }
     },
     "ajv-errors": {
@@ -1492,9 +1523,9 @@
       "dev": true
     },
     "ajv-keywords": {
-      "version": "3.2.0",
-      "resolved": "https://registry.npmjs.org/ajv-keywords/-/ajv-keywords-3.2.0.tgz",
-      "integrity": "sha1-6GuBnGAs+IIa1jdBNpjx3sAhhHo=",
+      "version": "3.4.0",
+      "resolved": "https://registry.npmjs.org/ajv-keywords/-/ajv-keywords-3.4.0.tgz",
+      "integrity": "sha512-aUjdRFISbuFOl0EIZc+9e4FfZp0bDZgAdOOf30bJmw8VM9v84SHyVyxDfbWxpGYbdZD/9XoKxfHVNmxPkhwyGw==",
       "dev": true
     },
     "align-text": {
@@ -1532,9 +1563,9 @@
       "dev": true
     },
     "angular": {
-      "version": "1.7.7",
-      "resolved": "https://registry.npmjs.org/angular/-/angular-1.7.7.tgz",
-      "integrity": "sha512-MH3JEGd8y/EkNCKJ8EV6Ch0j9X0rZTta/QVIDpBWaIdfh85/e5KO8+ZKgvWIb02MQuiS20pDFmMFlv4ZaLcLWg=="
+      "version": "1.7.8",
+      "resolved": "https://registry.npmjs.org/angular/-/angular-1.7.8.tgz",
+      "integrity": "sha512-wtef/y4COxM7ZVhddd7JtAAhyYObq9YXKar9tsW7558BImeVYteJiTxCKeJOL45lJ/+7B4wrAC49j8gTFYEthg=="
     },
     "angular-acl": {
       "version": "0.1.10",
@@ -1629,15 +1660,15 @@
       "integrity": "sha1-0CtjYqwbH5ZsXQ7Y8P0ri0DJP3g="
     },
     "ansi-colors": {
-      "version": "3.2.3",
-      "resolved": "https://registry.npmjs.org/ansi-colors/-/ansi-colors-3.2.3.tgz",
-      "integrity": "sha512-LEHHyuhlPY3TmuUYMh2oz89lTShfvgbmzaBcxve9t/9Wuy7Dwf4yoAKcND7KFT1HAQfqZ12qtc+DUrBMeKF9nw==",
+      "version": "3.2.4",
+      "resolved": "https://registry.npmjs.org/ansi-colors/-/ansi-colors-3.2.4.tgz",
+      "integrity": "sha512-hHUXGagefjN2iRrID63xckIvotOXOojhQKWIPUZ4mNUZ9nLZW+7FMNoE1lOkEhNWYsx/7ysGIuJYCiMAA9FnrA==",
       "dev": true
     },
     "ansi-escapes": {
-      "version": "3.1.0",
-      "resolved": "https://registry.npmjs.org/ansi-escapes/-/ansi-escapes-3.1.0.tgz",
-      "integrity": "sha512-UgAb8H9D41AQnu/PbWlCofQVcnV4Gs2bBJi9eZPxfU/hgglFh3SMDMENRIqdr7H6XFnXdoknctFByVsCOotTVw==",
+      "version": "3.2.0",
+      "resolved": "https://registry.npmjs.org/ansi-escapes/-/ansi-escapes-3.2.0.tgz",
+      "integrity": "sha512-cBhpre4ma+U0T1oM5fXg7Dy1Jw7zzwv7lt/GoCpr+hDQJoYnKVPLL4dCvSEFMmQurOQvSrwT7SL/DAlhBI97RQ==",
       "dev": true
     },
     "ansi-html": {
@@ -1667,6 +1698,17 @@
       "requires": {
         "micromatch": "^3.1.4",
         "normalize-path": "^2.1.1"
+      },
+      "dependencies": {
+        "normalize-path": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/normalize-path/-/normalize-path-2.1.1.tgz",
+          "integrity": "sha1-GrKLVW4Zg2Oowab35vogE3/mrtk=",
+          "dev": true,
+          "requires": {
+            "remove-trailing-separator": "^1.0.1"
+          }
+        }
       }
     },
     "app-root-path": {
@@ -1789,23 +1831,6 @@
       "dev": true,
       "requires": {
         "util": "0.10.3"
-      },
-      "dependencies": {
-        "inherits": {
-          "version": "2.0.1",
-          "resolved": "https://registry.npmjs.org/inherits/-/inherits-2.0.1.tgz",
-          "integrity": "sha1-sX0I0ya0Qj5Wjv9xn5GwscvfafE=",
-          "dev": true
-        },
-        "util": {
-          "version": "0.10.3",
-          "resolved": "https://registry.npmjs.org/util/-/util-0.10.3.tgz",
-          "integrity": "sha1-evsa/lCAUkZInj23/g7TeTNqwPk=",
-          "dev": true,
-          "requires": {
-            "inherits": "2.0.1"
-          }
-        }
       }
     },
     "assert-plus": {
@@ -1833,18 +1858,18 @@
       "dev": true
     },
     "async": {
-      "version": "2.6.1",
-      "resolved": "https://registry.npmjs.org/async/-/async-2.6.1.tgz",
-      "integrity": "sha512-fNEiL2+AZt6AlAw/29Cr0UDe4sRAHCpEHh54WMz+Bb7QfNcFw4h3loofyJpLeQs4Yx7yuqu/2dLgM5hKOs6HlQ==",
+      "version": "2.6.2",
+      "resolved": "https://registry.npmjs.org/async/-/async-2.6.2.tgz",
+      "integrity": "sha512-H1qVYh1MYhEEFLsP97cVKqCGo7KfCyTt6uEWqsTBr9SO84oK9Uwbyd/yCW+6rKJLHksBNUVWZDAjfS+Ccx0Bbg==",
       "dev": true,
       "requires": {
-        "lodash": "^4.17.10"
+        "lodash": "^4.17.11"
       }
     },
     "async-each": {
-      "version": "1.0.1",
-      "resolved": "https://registry.npmjs.org/async-each/-/async-each-1.0.1.tgz",
-      "integrity": "sha1-GdOGodntxufByF04iu28xW0zYC0=",
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/async-each/-/async-each-1.0.3.tgz",
+      "integrity": "sha512-z/WhQ5FPySLdvREByI2vZiTWwCnF0moMJ1hK9YQwDTHKh6I7/uSckMetoRGb5UBZPC1z0jlw+n/XCgjeH7y1AQ==",
       "dev": true
     },
     "async-foreach": {
@@ -2032,7 +2057,8 @@
     "balanced-match": {
       "version": "1.0.0",
       "resolved": "https://registry.npmjs.org/balanced-match/-/balanced-match-1.0.0.tgz",
-      "integrity": "sha1-ibTRmasr7kneFk6gK4nORi1xt2c="
+      "integrity": "sha1-ibTRmasr7kneFk6gK4nORi1xt2c=",
+      "dev": true
     },
     "base": {
       "version": "0.11.2",
@@ -2141,9 +2167,9 @@
       "integrity": "sha512-S4XzBk5sMB+Rcb/LNcpzXr57VRTxgAvaAEDAl1AwRx27j00hT84O6OkteE7u8UB3NuaaygCRrEpqox4uDOrbdQ=="
     },
     "binary-extensions": {
-      "version": "1.12.0",
-      "resolved": "https://registry.npmjs.org/binary-extensions/-/binary-extensions-1.12.0.tgz",
-      "integrity": "sha512-DYWGk01lDcxeS/K9IHPGWfT8PsJmbXRtRd2Sx72Tnb8pcYZQFF1oSDb8hJtS1vhp212q1Rzi5dUf9+nq0o9UIg==",
+      "version": "1.13.1",
+      "resolved": "https://registry.npmjs.org/binary-extensions/-/binary-extensions-1.13.1.tgz",
+      "integrity": "sha512-Un7MIEDdUC5gNpcGDV97op1Ywk748MpHcFTHoYs6qnj1Z3j7I53VG3nwZhKzoBZmbdRNnb6WRdFlwl7tSDuZGw==",
       "dev": true
     },
     "blob": {
@@ -2161,9 +2187,9 @@
       }
     },
     "bluebird": {
-      "version": "3.5.3",
-      "resolved": "https://registry.npmjs.org/bluebird/-/bluebird-3.5.3.tgz",
-      "integrity": "sha512-/qKPUQlaW1OyR51WeCPBvRnAlnZFUJkCSG5HzGnuIqhgyJtF+T94lFnn33eiazjRm2LAHVy2guNnaq48X9SJuw==",
+      "version": "3.5.4",
+      "resolved": "https://registry.npmjs.org/bluebird/-/bluebird-3.5.4.tgz",
+      "integrity": "sha512-FG+nFEZChJrbQ9tIccIfZJBz3J7mLrAhxakAbnrJWn8d7aKOC+LWifa0G+p4ZqKp4y13T7juYvdhq9NzKdsrjw==",
       "dev": true
     },
     "bn.js": {
@@ -2173,21 +2199,21 @@
       "dev": true
     },
     "body-parser": {
-      "version": "1.18.3",
-      "resolved": "https://registry.npmjs.org/body-parser/-/body-parser-1.18.3.tgz",
-      "integrity": "sha1-WykhmP/dVTs6DyDe0FkrlWlVyLQ=",
+      "version": "1.19.0",
+      "resolved": "https://registry.npmjs.org/body-parser/-/body-parser-1.19.0.tgz",
+      "integrity": "sha512-dhEPs72UPbDnAQJ9ZKMNTP6ptJaionhP5cBb541nXPlW60Jepo9RV/a4fX4XWW9CuFNK22krhrj1+rgzifNCsw==",
       "dev": true,
       "requires": {
-        "bytes": "3.0.0",
+        "bytes": "3.1.0",
         "content-type": "~1.0.4",
         "debug": "2.6.9",
         "depd": "~1.1.2",
-        "http-errors": "~1.6.3",
-        "iconv-lite": "0.4.23",
+        "http-errors": "1.7.2",
+        "iconv-lite": "0.4.24",
         "on-finished": "~2.3.0",
-        "qs": "6.5.2",
-        "raw-body": "2.3.3",
-        "type-is": "~1.6.16"
+        "qs": "6.7.0",
+        "raw-body": "2.4.0",
+        "type-is": "~1.6.17"
       },
       "dependencies": {
         "debug": {
@@ -2199,15 +2225,6 @@
             "ms": "2.0.0"
           }
         },
-        "iconv-lite": {
-          "version": "0.4.23",
-          "resolved": "https://registry.npmjs.org/iconv-lite/-/iconv-lite-0.4.23.tgz",
-          "integrity": "sha512-neyTUVFtahjf0mB3dZT77u+8O0QB89jFdnBkd5P1JgYPbPaia3gXXOVL2fq8VyU2gMMD7SaN7QukTB/pmXYvDA==",
-          "dev": true,
-          "requires": {
-            "safer-buffer": ">= 2.1.2 < 3"
-          }
-        },
         "ms": {
           "version": "2.0.0",
           "resolved": "https://registry.npmjs.org/ms/-/ms-2.0.0.tgz",
@@ -2251,6 +2268,7 @@
       "version": "1.1.11",
       "resolved": "https://registry.npmjs.org/brace-expansion/-/brace-expansion-1.1.11.tgz",
       "integrity": "sha512-iCuPHDFgrHX7H2vEI/5xpz07zSHB00TpugqhmYtVmMO6518mCuRMoOYFldEBl0g187ufozdaHgWKcYFb61qGiA==",
+      "dev": true,
       "requires": {
         "balanced-match": "^1.0.0",
         "concat-map": "0.0.1"
@@ -2374,14 +2392,14 @@
       }
     },
     "browserslist": {
-      "version": "4.3.7",
-      "resolved": "https://registry.npmjs.org/browserslist/-/browserslist-4.3.7.tgz",
-      "integrity": "sha512-pWQv51Ynb0MNk9JGMCZ8VkM785/4MQNXiFYtPqI7EEP0TJO+/d/NqRVn1uiAN0DNbnlUSpL2sh16Kspasv3pUQ==",
+      "version": "4.5.5",
+      "resolved": "https://registry.npmjs.org/browserslist/-/browserslist-4.5.5.tgz",
+      "integrity": "sha512-0QFO1r/2c792Ohkit5XI8Cm8pDtZxgNl2H6HU4mHrpYz7314pEYcsAVVatM0l/YmxPnEzh9VygXouj4gkFUTKA==",
       "dev": true,
       "requires": {
-        "caniuse-lite": "^1.0.30000925",
-        "electron-to-chromium": "^1.3.96",
-        "node-releases": "^1.1.3"
+        "caniuse-lite": "^1.0.30000960",
+        "electron-to-chromium": "^1.3.124",
+        "node-releases": "^1.1.14"
       }
     },
     "bson-objectid": {
@@ -2389,6 +2407,17 @@
       "resolved": "https://registry.npmjs.org/bson-objectid/-/bson-objectid-1.1.5.tgz",
       "integrity": "sha1-S54hCpjBxOqp7fY6ygeEyzC3m14="
     },
+    "buffer": {
+      "version": "4.9.1",
+      "resolved": "https://registry.npmjs.org/buffer/-/buffer-4.9.1.tgz",
+      "integrity": "sha1-bRu2AbB6TvztlwlBMgkwJ8lbwpg=",
+      "dev": true,
+      "requires": {
+        "base64-js": "^1.0.2",
+        "ieee754": "^1.1.4",
+        "isarray": "^1.0.0"
+      }
+    },
     "buffer-alloc": {
       "version": "1.2.0",
       "resolved": "https://registry.npmjs.org/buffer-alloc/-/buffer-alloc-1.2.0.tgz",
@@ -2429,12 +2458,6 @@
       "integrity": "sha1-JuYe0UIvtw3ULm42cp7VHYVf6Nk=",
       "dev": true
     },
-    "builtin-modules": {
-      "version": "1.1.1",
-      "resolved": "https://registry.npmjs.org/builtin-modules/-/builtin-modules-1.1.1.tgz",
-      "integrity": "sha1-Jw8HbFpywC9bZaR9+Uxf46J4iS8=",
-      "dev": true
-    },
     "builtin-status-codes": {
       "version": "3.0.0",
       "resolved": "https://registry.npmjs.org/builtin-status-codes/-/builtin-status-codes-3.0.0.tgz",
@@ -2442,9 +2465,9 @@
       "dev": true
     },
     "bytes": {
-      "version": "3.0.0",
-      "resolved": "https://registry.npmjs.org/bytes/-/bytes-3.0.0.tgz",
-      "integrity": "sha1-0ygVQE1olpn4Wk6k+odV3ROpYEg=",
+      "version": "3.1.0",
+      "resolved": "https://registry.npmjs.org/bytes/-/bytes-3.1.0.tgz",
+      "integrity": "sha512-zauLjrfCG+xvoyaqLoV8bLVXXNGC4JqlxFCutSDWA6fJrTo2ZuvLYTqZ7aHBLZSMOopbzwv8f+wZcVzfVTI2Dg==",
       "dev": true
     },
     "cacache": {
@@ -2497,9 +2520,9 @@
       "integrity": "sha1-KAOY5dZkvXQDi28JBRU+borxvCA="
     },
     "callsites": {
-      "version": "3.0.0",
-      "resolved": "https://registry.npmjs.org/callsites/-/callsites-3.0.0.tgz",
-      "integrity": "sha512-tWnkwu9YEq2uzlBDI4RcLn8jrFvF9AOi8PxDNU3hZZjJcjkcRAq3vCI+vZcg1SuxISDYe86k9VZFwAxDiJGoAw==",
+      "version": "3.1.0",
+      "resolved": "https://registry.npmjs.org/callsites/-/callsites-3.1.0.tgz",
+      "integrity": "sha512-P8BjAsXvZS+VIDUI11hHCQEv74YT67YUi5JJFNWIqL235sBmjX4+qx9Muvls5ivyNENctx46xQLQ3aTuE7ssaQ==",
       "dev": true
     },
     "camel-case": {
@@ -2513,9 +2536,9 @@
       }
     },
     "camelcase": {
-      "version": "2.1.1",
-      "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-2.1.1.tgz",
-      "integrity": "sha1-fB0W1nmhu+WcoCys7PsBHiAfWh8=",
+      "version": "5.3.1",
+      "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.3.1.tgz",
+      "integrity": "sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==",
       "dev": true
     },
     "camelcase-keys": {
@@ -2526,6 +2549,14 @@
       "requires": {
         "camelcase": "^2.0.0",
         "map-obj": "^1.0.0"
+      },
+      "dependencies": {
+        "camelcase": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-2.1.1.tgz",
+          "integrity": "sha1-fB0W1nmhu+WcoCys7PsBHiAfWh8=",
+          "dev": true
+        }
       }
     },
     "caniuse-api": {
@@ -2553,15 +2584,15 @@
       }
     },
     "caniuse-db": {
-      "version": "1.0.30000928",
-      "resolved": "https://registry.npmjs.org/caniuse-db/-/caniuse-db-1.0.30000928.tgz",
-      "integrity": "sha512-nAoeTspAEzLjqGSeibzM09WojORi08faeOOI5GBmFWC3/brydovb9lYJWM+p48rEQsdevfpufK58gPiDtwOWKw==",
+      "version": "1.0.30000963",
+      "resolved": "https://registry.npmjs.org/caniuse-db/-/caniuse-db-1.0.30000963.tgz",
+      "integrity": "sha512-5Qk1jSsqRY3dD7BAjU018y0MsznzYb+kMTKzGknue8vSWlHkw2S345vRnd0cVEerzZ6ugUfoKaUOOVbBxWLWCA==",
       "dev": true
     },
     "caniuse-lite": {
-      "version": "1.0.30000928",
-      "resolved": "https://registry.npmjs.org/caniuse-lite/-/caniuse-lite-1.0.30000928.tgz",
-      "integrity": "sha512-aSpMWRXL6ZXNnzm8hgE4QDLibG5pVJ2Ujzsuj3icazlIkxXkPXtL+BWnMx6FBkWmkZgBHGUxPZQvrbRw2ZTxhg==",
+      "version": "1.0.30000963",
+      "resolved": "https://registry.npmjs.org/caniuse-lite/-/caniuse-lite-1.0.30000963.tgz",
+      "integrity": "sha512-n4HUiullc7Lw0LyzpeLa2ffP8KxFBGdxqD/8G3bSL6oB758hZ2UE2CVK+tQN958tJIi0/tfpjAc67aAtoHgnrQ==",
       "dev": true
     },
     "caseless": {
@@ -2598,6 +2629,7 @@
       "version": "2.1.0",
       "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.1.0.tgz",
       "integrity": "sha512-LUHGS/dge4ujbXMJrnihYMcL4AoOweGnw9Tp3kQuqy1Kx5c1qKjqvMJZ6nVJPMWJtKCTN72ZogH3oeSO9g9rXQ==",
+      "dev": true,
       "requires": {
         "ansi-styles": "^3.1.0",
         "escape-string-regexp": "^1.0.5",
@@ -2607,12 +2639,14 @@
         "has-flag": {
           "version": "2.0.0",
           "resolved": "https://registry.npmjs.org/has-flag/-/has-flag-2.0.0.tgz",
-          "integrity": "sha1-6CB68cx7MNRGzHC3NLXovhj4jVE="
+          "integrity": "sha1-6CB68cx7MNRGzHC3NLXovhj4jVE=",
+          "dev": true
         },
         "supports-color": {
           "version": "4.5.0",
           "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-4.5.0.tgz",
           "integrity": "sha1-vnoN5ITexcXN34s9WRJQRJEvY1s=",
+          "dev": true,
           "requires": {
             "has-flag": "^2.0.0"
           }
@@ -2644,11 +2678,11 @@
       }
     },
     "chartjs-color": {
-      "version": "2.2.0",
-      "resolved": "https://registry.npmjs.org/chartjs-color/-/chartjs-color-2.2.0.tgz",
-      "integrity": "sha1-hKL7dVeH7YXDndbdjHsdiEKbrq4=",
+      "version": "2.3.0",
+      "resolved": "https://registry.npmjs.org/chartjs-color/-/chartjs-color-2.3.0.tgz",
+      "integrity": "sha512-hEvVheqczsoHD+fZ+tfPUE+1+RbV6b+eksp2LwAhwRTVXEjCSEavvk+Hg3H6SZfGlPh/UfmWKGIvZbtobOEm3g==",
       "requires": {
-        "chartjs-color-string": "^0.5.0",
+        "chartjs-color-string": "^0.6.0",
         "color-convert": "^0.5.3"
       },
       "dependencies": {
@@ -2660,9 +2694,9 @@
       }
     },
     "chartjs-color-string": {
-      "version": "0.5.0",
-      "resolved": "https://registry.npmjs.org/chartjs-color-string/-/chartjs-color-string-0.5.0.tgz",
-      "integrity": "sha512-amWNvCOXlOUYxZVDSa0YOab5K/lmEhbFNKI55PWc4mlv28BDzA7zaoQTGxSBgJMHIW+hGX8YUrvw/FH4LyhwSQ==",
+      "version": "0.6.0",
+      "resolved": "https://registry.npmjs.org/chartjs-color-string/-/chartjs-color-string-0.6.0.tgz",
+      "integrity": "sha512-TIB5OKn1hPJvO7JcteW4WY/63v6KwEdt6udfnDE9iCAZgy+V4SrbSxoIbTw/xkUIapjEI4ExGtD0+6D3KyFd7A==",
       "requires": {
         "color-name": "^1.0.0"
       }
@@ -2700,26 +2734,13 @@
         "path-is-absolute": "^1.0.0",
         "readdirp": "^2.2.1",
         "upath": "^1.1.1"
-      },
-      "dependencies": {
-        "normalize-path": {
-          "version": "3.0.0",
-          "resolved": "https://registry.npmjs.org/normalize-path/-/normalize-path-3.0.0.tgz",
-          "integrity": "sha512-6eZs5Ls3WtCisHWp9S2GUy8dqkpGi4BVSz3GaqiE6ezub0512ESztXUwUB6C6IKbQkY2Pnb/mD4WYojCRwcwLA==",
-          "dev": true
-        },
-        "upath": {
-          "version": "1.1.2",
-          "resolved": "https://registry.npmjs.org/upath/-/upath-1.1.2.tgz",
-          "integrity": "sha512-kXpym8nmDmlCBr7nKdIx8P2jNBa+pBpIUFRnKJ4dr8htyYGJFokkr2ZvERRtUN+9SY+JqXouNgUPtv6JQva/2Q==",
-          "dev": true
-        }
       }
     },
     "chownr": {
       "version": "1.1.1",
       "resolved": "https://registry.npmjs.org/chownr/-/chownr-1.1.1.tgz",
-      "integrity": "sha512-j38EvO5+LHX84jlo6h4UzmOwi0UgW61WRyPtJz4qaadK5eY3BTS5TY/S1Stc3Uk2lIM6TPevAlULiEJwie860g=="
+      "integrity": "sha512-j38EvO5+LHX84jlo6h4UzmOwi0UgW61WRyPtJz4qaadK5eY3BTS5TY/S1Stc3Uk2lIM6TPevAlULiEJwie860g==",
+      "dev": true
     },
     "chrome-trace-event": {
       "version": "1.0.0",
@@ -2862,49 +2883,29 @@
       "dev": true
     },
     "cliui": {
-      "version": "3.2.0",
-      "resolved": "https://registry.npmjs.org/cliui/-/cliui-3.2.0.tgz",
-      "integrity": "sha1-EgYBU3qRbSmUD5NNo7SNWFo5IT0=",
+      "version": "4.1.0",
+      "resolved": "https://registry.npmjs.org/cliui/-/cliui-4.1.0.tgz",
+      "integrity": "sha512-4FG+RSG9DL7uEwRUZXZn3SS34DiDPfzP0VOiEwtUWlE+AR2EIg+hSyvrIgUUfhdgR/UkAeW2QHgeP+hWrXs7jQ==",
       "dev": true,
       "requires": {
-        "string-width": "^1.0.1",
-        "strip-ansi": "^3.0.1",
+        "string-width": "^2.1.1",
+        "strip-ansi": "^4.0.0",
         "wrap-ansi": "^2.0.0"
       },
       "dependencies": {
         "ansi-regex": {
-          "version": "2.1.1",
-          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-2.1.1.tgz",
-          "integrity": "sha1-w7M6te42DYbg5ijwRorn7yfWVN8=",
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-3.0.0.tgz",
+          "integrity": "sha1-7QMXwyIGT3lGbAKWa922Bas32Zg=",
           "dev": true
         },
-        "is-fullwidth-code-point": {
-          "version": "1.0.0",
-          "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-1.0.0.tgz",
-          "integrity": "sha1-754xOG8DGn8NZDr4L95QxFfvAMs=",
-          "dev": true,
-          "requires": {
-            "number-is-nan": "^1.0.0"
-          }
-        },
-        "string-width": {
-          "version": "1.0.2",
-          "resolved": "https://registry.npmjs.org/string-width/-/string-width-1.0.2.tgz",
-          "integrity": "sha1-EYvfW4zcUaKn5w0hHgfisLmxB9M=",
-          "dev": true,
-          "requires": {
-            "code-point-at": "^1.0.0",
-            "is-fullwidth-code-point": "^1.0.0",
-            "strip-ansi": "^3.0.0"
-          }
-        },
         "strip-ansi": {
-          "version": "3.0.1",
-          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-3.0.1.tgz",
-          "integrity": "sha1-ajhfuIU9lS1f8F0Oiq+UJ43GPc8=",
+          "version": "4.0.0",
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
+          "integrity": "sha1-qEeQIusaw2iocTibY1JixQXuNo8=",
           "dev": true,
           "requires": {
-            "ansi-regex": "^2.0.0"
+            "ansi-regex": "^3.0.0"
           }
         }
       }
@@ -2925,17 +2926,6 @@
         "is-plain-object": "^2.0.4",
         "kind-of": "^6.0.0",
         "shallow-clone": "^1.0.0"
-      },
-      "dependencies": {
-        "for-own": {
-          "version": "1.0.0",
-          "resolved": "https://registry.npmjs.org/for-own/-/for-own-1.0.0.tgz",
-          "integrity": "sha1-xjMy9BXO3EsE2/5wz4NklMU8tEs=",
-          "dev": true,
-          "requires": {
-            "for-in": "^1.0.1"
-          }
-        }
       }
     },
     "co": {
@@ -3029,9 +3019,9 @@
       }
     },
     "commander": {
-      "version": "2.17.1",
-      "resolved": "https://registry.npmjs.org/commander/-/commander-2.17.1.tgz",
-      "integrity": "sha512-wPMUt6FnH2yzG95SA6mzjQOEKUU3aLaDEmzs1ti+1E9h+CsrZghRlqEM/EJ4KscsQVG8uNN4uVreUeT8+drlgg==",
+      "version": "2.20.0",
+      "resolved": "https://registry.npmjs.org/commander/-/commander-2.20.0.tgz",
+      "integrity": "sha512-7j2y+40w61zy6YC2iRNpUe/NwhNyoXrYpHMrSunaMG64nRnaf96zO/KMQR4OyN/UnE5KLyEBnKHd4aG3rskjpQ==",
       "dev": true
     },
     "commondir": {
@@ -3056,20 +3046,12 @@
       "integrity": "sha1-ZF/ErfWLcrZJ1crmUTVhnbJv8UM="
     },
     "compressible": {
-      "version": "2.0.16",
-      "resolved": "https://registry.npmjs.org/compressible/-/compressible-2.0.16.tgz",
-      "integrity": "sha512-JQfEOdnI7dASwCuSPWIeVYwc/zMsu/+tRhoUvEfXz2gxOA2DNjmG5vhtFdBlhWPPGo+RdT9S3tgc/uH5qgDiiA==",
+      "version": "2.0.17",
+      "resolved": "https://registry.npmjs.org/compressible/-/compressible-2.0.17.tgz",
+      "integrity": "sha512-BGHeLCK1GV7j1bSmQQAi26X+GgWcTjLr/0tzSvMCl3LH1w1IJ4PFSPoV5316b30cneTziC+B1a+3OjoSUcQYmw==",
       "dev": true,
       "requires": {
-        "mime-db": ">= 1.38.0 < 2"
-      },
-      "dependencies": {
-        "mime-db": {
-          "version": "1.39.0",
-          "resolved": "https://registry.npmjs.org/mime-db/-/mime-db-1.39.0.tgz",
-          "integrity": "sha512-DTsrw/iWVvwHH+9Otxccdyy0Tgiil6TWK/xhfARJZF/QFhwOgZgOIvA2/VIGpM8U7Q8z5nDmdDWC6tuVMJNibw==",
-          "dev": true
-        }
+        "mime-db": ">= 1.40.0 < 2"
       }
     },
     "compression": {
@@ -3087,6 +3069,12 @@
         "vary": "~1.1.2"
       },
       "dependencies": {
+        "bytes": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/bytes/-/bytes-3.0.0.tgz",
+          "integrity": "sha1-0ygVQE1olpn4Wk6k+odV3ROpYEg=",
+          "dev": true
+        },
         "debug": {
           "version": "2.6.9",
           "resolved": "https://registry.npmjs.org/debug/-/debug-2.6.9.tgz",
@@ -3107,7 +3095,8 @@
     "concat-map": {
       "version": "0.0.1",
       "resolved": "https://registry.npmjs.org/concat-map/-/concat-map-0.0.1.tgz",
-      "integrity": "sha1-2Klr13/Wjfd5OnMDajug1UBdR3s="
+      "integrity": "sha1-2Klr13/Wjfd5OnMDajug1UBdR3s=",
+      "dev": true
     },
     "concat-stream": {
       "version": "1.6.2",
@@ -3307,9 +3296,9 @@
       }
     },
     "core-js": {
-      "version": "2.6.2",
-      "resolved": "https://registry.npmjs.org/core-js/-/core-js-2.6.2.tgz",
-      "integrity": "sha512-NdBPF/RVwPW6jr0NCILuyN9RiqLo2b1mddWHkUL+VnvcB7dzlnBJ1bXYntjpTGOgkZiiLWj2JxmOr7eGE3qK6g=="
+      "version": "2.6.5",
+      "resolved": "https://registry.npmjs.org/core-js/-/core-js-2.6.5.tgz",
+      "integrity": "sha512-klh/kDpwX8hryYL14M9w/xei6vrv6sE8gTHDG7/T/+SEovB/G4ejwcfE/CBzO6Edsu+OETZMZ3wcX/EjUkrl5A=="
     },
     "core-util-is": {
       "version": "1.0.2",
@@ -3354,12 +3343,14 @@
       }
     },
     "cross-spawn": {
-      "version": "5.1.0",
-      "resolved": "https://registry.npmjs.org/cross-spawn/-/cross-spawn-5.1.0.tgz",
-      "integrity": "sha1-6L0O/uWPz/b4+UUQoKVUu/ojVEk=",
+      "version": "6.0.5",
+      "resolved": "https://registry.npmjs.org/cross-spawn/-/cross-spawn-6.0.5.tgz",
+      "integrity": "sha512-eTVLrBSt7fjbDygz805pMnstIs2VTBNkRm0qxZd+M7A5XDdxVRWO5MxGBXZhjY4cqLYLdtrGqRf8mBPmzwSpWQ==",
       "dev": true,
       "requires": {
-        "lru-cache": "^4.0.1",
+        "nice-try": "^1.0.4",
+        "path-key": "^2.0.1",
+        "semver": "^5.5.0",
         "shebang-command": "^1.2.0",
         "which": "^1.2.9"
       }
@@ -3511,9 +3502,9 @@
       "dev": true
     },
     "css-what": {
-      "version": "2.1.2",
-      "resolved": "https://registry.npmjs.org/css-what/-/css-what-2.1.2.tgz",
-      "integrity": "sha512-wan8dMWQ0GUeF7DGEPVjhHemVW/vy6xUYmFzRY8RYqgA0JtXC9rJmbScBjqSu6dg9q0lwPQy6ZAmJVr3PPTvqQ==",
+      "version": "2.1.3",
+      "resolved": "https://registry.npmjs.org/css-what/-/css-what-2.1.3.tgz",
+      "integrity": "sha512-a+EPoD+uZiNfh+5fxw2nO9QwFa6nJe2Or35fGY6Ipw1R3R4AGz1d1TEZrCegvw2YTmZ0jXirGYlzxxpYSHwpEg==",
       "dev": true
     },
     "cssesc": {
@@ -3662,13 +3653,6 @@
       "integrity": "sha1-9dJgKStmDghO/0zbyfCK0yR0SLU=",
       "dev": true
     },
-    "deep-extend": {
-      "version": "0.6.0",
-      "resolved": "https://registry.npmjs.org/deep-extend/-/deep-extend-0.6.0.tgz",
-      "integrity": "sha512-LOHxIOaPYdHlJRtCQfDIVZtfw/ufM8+rVj649RIHzcm/vGwQRXFt6OPqIFWsm2XEMrNIEtWR64sY1LEKD2vAOA==",
-      "dev": true,
-      "optional": true
-    },
     "deep-is": {
       "version": "0.1.3",
       "resolved": "https://registry.npmjs.org/deep-is/-/deep-is-0.1.3.tgz",
@@ -3824,13 +3808,6 @@
       "integrity": "sha1-l4hXRCxEdJ5CBmE+N5RiBYJqvYA=",
       "dev": true
     },
-    "detect-libc": {
-      "version": "1.0.3",
-      "resolved": "https://registry.npmjs.org/detect-libc/-/detect-libc-1.0.3.tgz",
-      "integrity": "sha1-+hN8S9aY7fVc1c0CrFWfkaTEups=",
-      "dev": true,
-      "optional": true
-    },
     "detect-node": {
       "version": "2.0.4",
       "resolved": "https://registry.npmjs.org/detect-node/-/detect-node-2.0.4.tgz",
@@ -3844,9 +3821,9 @@
       "dev": true
     },
     "diff": {
-      "version": "3.2.0",
-      "resolved": "https://registry.npmjs.org/diff/-/diff-3.2.0.tgz",
-      "integrity": "sha1-yc45Okt8vQsFinJck98pkCeGj/k=",
+      "version": "3.5.0",
+      "resolved": "https://registry.npmjs.org/diff/-/diff-3.5.0.tgz",
+      "integrity": "sha512-A46qtFgd+g7pDZinpnwiRJtxbC1hpgf0uzP3iG89scHk0AUC7A1TGxf5OiiOUv/JMZR8GOt8hL900hV0bOy5xA==",
       "dev": true
     },
     "diffie-hellman": {
@@ -3861,9 +3838,9 @@
       }
     },
     "dir-glob": {
-      "version": "2.2.1",
-      "resolved": "https://registry.npmjs.org/dir-glob/-/dir-glob-2.2.1.tgz",
-      "integrity": "sha512-UN6X6XwRjllabfRhBdkVSo63uurJ8nSvMGrwl94EYVz6g+exhTV+yVSYk5VC/xl3MBFBTtC0J20uFKce4Brrng==",
+      "version": "2.2.2",
+      "resolved": "https://registry.npmjs.org/dir-glob/-/dir-glob-2.2.2.tgz",
+      "integrity": "sha512-f9LBi5QWzIW3I6e//uxZoLBlUt9kcp66qo0sSCxL6YZKc75R1c4MFCoe/LaZiBGmgujvQdxc5Bn3QhfyvK5Hsw==",
       "dev": true,
       "requires": {
         "path-type": "^3.0.0"
@@ -3931,27 +3908,19 @@
       }
     },
     "dom-serializer": {
-      "version": "0.1.0",
-      "resolved": "https://registry.npmjs.org/dom-serializer/-/dom-serializer-0.1.0.tgz",
-      "integrity": "sha1-BzxpdUbOB4DOI75KKOKT5AvDDII=",
+      "version": "0.1.1",
+      "resolved": "https://registry.npmjs.org/dom-serializer/-/dom-serializer-0.1.1.tgz",
+      "integrity": "sha512-l0IU0pPzLWSHBcieZbpOKgkIn3ts3vAh7ZuFyXNwJxJXk/c4Gwj9xaTJwIDVQCXawWD0qb3IzMGH5rglQaO0XA==",
       "dev": true,
       "requires": {
-        "domelementtype": "~1.1.1",
-        "entities": "~1.1.1"
-      },
-      "dependencies": {
-        "domelementtype": {
-          "version": "1.1.3",
-          "resolved": "https://registry.npmjs.org/domelementtype/-/domelementtype-1.1.3.tgz",
-          "integrity": "sha1-vSh3PiZCiBrsUVRJJCmcXNgiGFs=",
-          "dev": true
-        }
+        "domelementtype": "^1.3.0",
+        "entities": "^1.1.1"
       }
     },
     "domain-browser": {
-      "version": "1.1.7",
-      "resolved": "https://registry.npmjs.org/domain-browser/-/domain-browser-1.1.7.tgz",
-      "integrity": "sha1-hnqksJP6oF8d4IwG9NeyH9+GmLw=",
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/domain-browser/-/domain-browser-1.2.0.tgz",
+      "integrity": "sha512-jnjyiM6eRyZl2H+W8Q/zLMA481hzi0eszAaBUzIVnmYVDBbnLxVNnfu1HgEBvCbL+71FrxMl3E6lpKH7Ge3OXA==",
       "dev": true
     },
     "domelementtype": {
@@ -3986,9 +3955,9 @@
       }
     },
     "duplexify": {
-      "version": "3.6.1",
-      "resolved": "https://registry.npmjs.org/duplexify/-/duplexify-3.6.1.tgz",
-      "integrity": "sha512-vM58DwdnKmty+FSPzT14K9JXb90H+j5emaR4KYbr2KTIz00WHGbWOe5ghQTx233ZCLZtrGDALzKwcjEtSt35mA==",
+      "version": "3.7.1",
+      "resolved": "https://registry.npmjs.org/duplexify/-/duplexify-3.7.1.tgz",
+      "integrity": "sha512-07z8uv2wMyS51kKhD1KsdXJg5WQ6t93RneqRxUHnskXVtlYYkLqM0gqStQZ3pj073g687jPCHrqNfCzawLYh5g==",
       "dev": true,
       "requires": {
         "end-of-stream": "^1.0.0",
@@ -4014,9 +3983,9 @@
       "dev": true
     },
     "electron-to-chromium": {
-      "version": "1.3.100",
-      "resolved": "https://registry.npmjs.org/electron-to-chromium/-/electron-to-chromium-1.3.100.tgz",
-      "integrity": "sha512-cEUzis2g/RatrVf8x26L8lK5VEls1AGnLHk6msluBUg/NTB4wcXzExTsGscFq+Vs4WBBU2zbLLySvD4C0C3hwg==",
+      "version": "1.3.127",
+      "resolved": "https://registry.npmjs.org/electron-to-chromium/-/electron-to-chromium-1.3.127.tgz",
+      "integrity": "sha512-1o25iFRf/dbgauTWalEzmD1EmRN3a2CzP/K7UVpYLEBduk96LF0FyUdCcf4Ry2mAWJ1VxyblFjC93q6qlLwA2A==",
       "dev": true
     },
     "elliptic": {
@@ -4273,49 +4242,18 @@
         "text-table": "^0.2.0"
       },
       "dependencies": {
-        "ajv": {
-          "version": "6.7.0",
-          "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.7.0.tgz",
-          "integrity": "sha512-RZXPviBTtfmtka9n9sy1N5M5b82CbxWIR6HIis4s3WQTXDJamc/0gpCWNGz6EWdWp4DOfjzJfhz/AS9zVPjjWg==",
-          "dev": true,
-          "requires": {
-            "fast-deep-equal": "^2.0.1",
-            "fast-json-stable-stringify": "^2.0.0",
-            "json-schema-traverse": "^0.4.1",
-            "uri-js": "^4.2.2"
-          }
-        },
         "ansi-regex": {
           "version": "3.0.0",
           "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-3.0.0.tgz",
           "integrity": "sha1-7QMXwyIGT3lGbAKWa922Bas32Zg=",
           "dev": true
         },
-        "cross-spawn": {
-          "version": "6.0.5",
-          "resolved": "https://registry.npmjs.org/cross-spawn/-/cross-spawn-6.0.5.tgz",
-          "integrity": "sha512-eTVLrBSt7fjbDygz805pMnstIs2VTBNkRm0qxZd+M7A5XDdxVRWO5MxGBXZhjY4cqLYLdtrGqRf8mBPmzwSpWQ==",
-          "dev": true,
-          "requires": {
-            "nice-try": "^1.0.4",
-            "path-key": "^2.0.1",
-            "semver": "^5.5.0",
-            "shebang-command": "^1.2.0",
-            "which": "^1.2.9"
-          }
-        },
         "esprima": {
           "version": "4.0.1",
           "resolved": "https://registry.npmjs.org/esprima/-/esprima-4.0.1.tgz",
           "integrity": "sha512-eGuFFw7Upda+g4p+QHvnW0RyTX/SVeJBDM/gCtMARO0cLuT2HcEKnTPvhjV6aGeqrCB/sbNop0Kszm0jsaWU4A==",
           "dev": true
         },
-        "fast-deep-equal": {
-          "version": "2.0.1",
-          "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-2.0.1.tgz",
-          "integrity": "sha1-ewUhjd+WZ79/Nwv3/bLLFf3Qqkk=",
-          "dev": true
-        },
         "ignore": {
           "version": "4.0.6",
           "resolved": "https://registry.npmjs.org/ignore/-/ignore-4.0.6.tgz",
@@ -4323,21 +4261,15 @@
           "dev": true
         },
         "js-yaml": {
-          "version": "3.12.1",
-          "resolved": "https://registry.npmjs.org/js-yaml/-/js-yaml-3.12.1.tgz",
-          "integrity": "sha512-um46hB9wNOKlwkHgiuyEVAybXBjwFUV0Z/RaHJblRd9DXltue9FTYvzCr9ErQrK9Adz5MU4gHWVaNUfdmrC8qA==",
+          "version": "3.13.1",
+          "resolved": "https://registry.npmjs.org/js-yaml/-/js-yaml-3.13.1.tgz",
+          "integrity": "sha512-YfbcO7jXDdyj0DGxYVSlSeQNHbD7XPWvrVWeVUujrQEoZzWJIRrCPoyk6kL6IAjAG2IolMK4T0hNUe0HOUs5Jw==",
           "dev": true,
           "requires": {
             "argparse": "^1.0.7",
             "esprima": "^4.0.0"
           }
         },
-        "json-schema-traverse": {
-          "version": "0.4.1",
-          "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.4.1.tgz",
-          "integrity": "sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==",
-          "dev": true
-        },
         "strip-ansi": {
           "version": "4.0.0",
           "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
@@ -4393,9 +4325,9 @@
       }
     },
     "eslint-scope": {
-      "version": "4.0.0",
-      "resolved": "https://registry.npmjs.org/eslint-scope/-/eslint-scope-4.0.0.tgz",
-      "integrity": "sha512-1G6UTDi7Jc1ELFwnR58HV4fK9OQK4S6N985f166xqXxpjU6plxFISJa2Ba9KCQuFa8RCnj/lSFJbHo7UFDBnUA==",
+      "version": "4.0.3",
+      "resolved": "https://registry.npmjs.org/eslint-scope/-/eslint-scope-4.0.3.tgz",
+      "integrity": "sha512-p7VutNr1O/QrxysMo3E45FjYDTeXBy0iTltPFNSqKAIfjDSXC+4dj+qfyuD8bfAXrW/y6lW3O76VaYNPKfpKrg==",
       "dev": true,
       "requires": {
         "esrecurse": "^4.1.0",
@@ -4415,22 +4347,14 @@
       "dev": true
     },
     "espree": {
-      "version": "5.0.0",
-      "resolved": "https://registry.npmjs.org/espree/-/espree-5.0.0.tgz",
-      "integrity": "sha512-1MpUfwsdS9MMoN7ZXqAr9e9UKdVHDcvrJpyx7mm1WuQlx/ygErEQBzgi5Nh5qBHIoYweprhtMkTCb9GhcAIcsA==",
+      "version": "5.0.1",
+      "resolved": "https://registry.npmjs.org/espree/-/espree-5.0.1.tgz",
+      "integrity": "sha512-qWAZcWh4XE/RwzLJejfcofscgMc9CamR6Tn1+XRXNzrvUSSbiAjGOI/fggztjIi7y9VLPqnICMIPiGyr8JaZ0A==",
       "dev": true,
       "requires": {
-        "acorn": "^6.0.2",
+        "acorn": "^6.0.7",
         "acorn-jsx": "^5.0.0",
         "eslint-visitor-keys": "^1.0.0"
-      },
-      "dependencies": {
-        "acorn": {
-          "version": "6.0.5",
-          "resolved": "https://registry.npmjs.org/acorn/-/acorn-6.0.5.tgz",
-          "integrity": "sha512-i33Zgp3XWtmZBMNvCr4azvOFeWVw1Rk6p3hfi3LUDvIFraOMywb1kAtrbi+med14m4Xfpqm3zRZMT+c0FNE7kg==",
-          "dev": true
-        }
       }
     },
     "esprima": {
@@ -4481,9 +4405,9 @@
       "dev": true
     },
     "events": {
-      "version": "1.1.1",
-      "resolved": "https://registry.npmjs.org/events/-/events-1.1.1.tgz",
-      "integrity": "sha1-nr23Y1rQmccNzEwqH1AEKI6L2SQ=",
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/events/-/events-3.0.0.tgz",
+      "integrity": "sha512-Dc381HFWJzEOhQ+d8pkNon++bk9h6cdAoAj4iE6Q4y6xgTzySWXlKn05/TVNpjnfRqi/X0EpJEJohPjNI3zpVA==",
       "dev": true
     },
     "eventsource": {
@@ -4518,21 +4442,6 @@
         "p-finally": "^1.0.0",
         "signal-exit": "^3.0.0",
         "strip-eof": "^1.0.0"
-      },
-      "dependencies": {
-        "cross-spawn": {
-          "version": "6.0.5",
-          "resolved": "https://registry.npmjs.org/cross-spawn/-/cross-spawn-6.0.5.tgz",
-          "integrity": "sha512-eTVLrBSt7fjbDygz805pMnstIs2VTBNkRm0qxZd+M7A5XDdxVRWO5MxGBXZhjY4cqLYLdtrGqRf8mBPmzwSpWQ==",
-          "dev": true,
-          "requires": {
-            "nice-try": "^1.0.4",
-            "path-key": "^2.0.1",
-            "semver": "^5.5.0",
-            "shebang-command": "^1.2.0",
-            "which": "^1.2.9"
-          }
-        }
       }
     },
     "expand-brackets": {
@@ -4635,6 +4544,30 @@
           "integrity": "sha1-ml9pkFGx5wczKPKgCJaLZOopVdI=",
           "dev": true
         },
+        "body-parser": {
+          "version": "1.18.3",
+          "resolved": "https://registry.npmjs.org/body-parser/-/body-parser-1.18.3.tgz",
+          "integrity": "sha1-WykhmP/dVTs6DyDe0FkrlWlVyLQ=",
+          "dev": true,
+          "requires": {
+            "bytes": "3.0.0",
+            "content-type": "~1.0.4",
+            "debug": "2.6.9",
+            "depd": "~1.1.2",
+            "http-errors": "~1.6.3",
+            "iconv-lite": "0.4.23",
+            "on-finished": "~2.3.0",
+            "qs": "6.5.2",
+            "raw-body": "2.3.3",
+            "type-is": "~1.6.16"
+          }
+        },
+        "bytes": {
+          "version": "3.0.0",
+          "resolved": "https://registry.npmjs.org/bytes/-/bytes-3.0.0.tgz",
+          "integrity": "sha1-0ygVQE1olpn4Wk6k+odV3ROpYEg=",
+          "dev": true
+        },
         "debug": {
           "version": "2.6.9",
           "resolved": "https://registry.npmjs.org/debug/-/debug-2.6.9.tgz",
@@ -4659,6 +4592,27 @@
             "unpipe": "~1.0.0"
           }
         },
+        "http-errors": {
+          "version": "1.6.3",
+          "resolved": "https://registry.npmjs.org/http-errors/-/http-errors-1.6.3.tgz",
+          "integrity": "sha1-i1VoC7S+KDoLW/TqLjhYC+HZMg0=",
+          "dev": true,
+          "requires": {
+            "depd": "~1.1.2",
+            "inherits": "2.0.3",
+            "setprototypeof": "1.1.0",
+            "statuses": ">= 1.4.0 < 2"
+          }
+        },
+        "iconv-lite": {
+          "version": "0.4.23",
+          "resolved": "https://registry.npmjs.org/iconv-lite/-/iconv-lite-0.4.23.tgz",
+          "integrity": "sha512-neyTUVFtahjf0mB3dZT77u+8O0QB89jFdnBkd5P1JgYPbPaia3gXXOVL2fq8VyU2gMMD7SaN7QukTB/pmXYvDA==",
+          "dev": true,
+          "requires": {
+            "safer-buffer": ">= 2.1.2 < 3"
+          }
+        },
         "ms": {
           "version": "2.0.0",
           "resolved": "https://registry.npmjs.org/ms/-/ms-2.0.0.tgz",
@@ -4671,6 +4625,30 @@
           "integrity": "sha1-32BBeABfUi8V60SQ5yR6G/qmf4w=",
           "dev": true
         },
+        "qs": {
+          "version": "6.5.2",
+          "resolved": "https://registry.npmjs.org/qs/-/qs-6.5.2.tgz",
+          "integrity": "sha512-N5ZAX4/LxJmF+7wN74pUD6qAh9/wnvdQcjq9TZjevvXzSUo7bfmw91saqMjzGS2xq91/odN2dW/WOl7qQHNDGA==",
+          "dev": true
+        },
+        "raw-body": {
+          "version": "2.3.3",
+          "resolved": "https://registry.npmjs.org/raw-body/-/raw-body-2.3.3.tgz",
+          "integrity": "sha512-9esiElv1BrZoI3rCDuOuKCBRbuApGGaDPQfjSflGxdy4oyzqghxu6klEkkVIvBje+FF0BX9coEv8KqW6X/7njw==",
+          "dev": true,
+          "requires": {
+            "bytes": "3.0.0",
+            "http-errors": "1.6.3",
+            "iconv-lite": "0.4.23",
+            "unpipe": "1.0.0"
+          }
+        },
+        "setprototypeof": {
+          "version": "1.1.0",
+          "resolved": "https://registry.npmjs.org/setprototypeof/-/setprototypeof-1.1.0.tgz",
+          "integrity": "sha512-BvE/TwpZX4FXExxOxZyRGQQv651MSwmWKZGqvmPcRIjDqWub67kTKuIMx43cZZrS/cBBzwBcNDWoFxt2XEFIpQ==",
+          "dev": true
+        },
         "statuses": {
           "version": "1.4.0",
           "resolved": "https://registry.npmjs.org/statuses/-/statuses-1.4.0.tgz",
@@ -4789,9 +4767,9 @@
       "dev": true
     },
     "fast-deep-equal": {
-      "version": "1.1.0",
-      "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-1.1.0.tgz",
-      "integrity": "sha1-wFNHeBfIa1HaqFPIHgWbcz0CNhQ=",
+      "version": "2.0.1",
+      "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-2.0.1.tgz",
+      "integrity": "sha1-ewUhjd+WZ79/Nwv3/bLLFf3Qqkk=",
       "dev": true
     },
     "fast-glob": {
@@ -4992,13 +4970,45 @@
       "dev": true
     },
     "flush-write-stream": {
-      "version": "1.0.3",
-      "resolved": "https://registry.npmjs.org/flush-write-stream/-/flush-write-stream-1.0.3.tgz",
-      "integrity": "sha512-calZMC10u0FMUqoiunI2AiGIIUtUIvifNwkHhNupZH4cbNnW1Itkoh/Nf5HFYmDrwWPjrUxpkZT0KhuCq0jmGw==",
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/flush-write-stream/-/flush-write-stream-1.1.1.tgz",
+      "integrity": "sha512-3Z4XhFZ3992uIq0XOqb9AreonueSYphE6oYbpt5+3u06JWklbsPkNv3ZKkP9Bz/r+1MWCaMoSQ28P85+1Yc77w==",
       "dev": true,
       "requires": {
-        "inherits": "^2.0.1",
-        "readable-stream": "^2.0.4"
+        "inherits": "^2.0.3",
+        "readable-stream": "^2.3.6"
+      },
+      "dependencies": {
+        "process-nextick-args": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/process-nextick-args/-/process-nextick-args-2.0.0.tgz",
+          "integrity": "sha512-MtEC1TqN0EU5nephaJ4rAtThHtC86dNN9qCuEhtshvpVBkAW5ZO7BASN9REnF9eoXGcRub+pFuKEpOHE+HbEMw==",
+          "dev": true
+        },
+        "readable-stream": {
+          "version": "2.3.6",
+          "resolved": "https://registry.npmjs.org/readable-stream/-/readable-stream-2.3.6.tgz",
+          "integrity": "sha512-tQtKA9WIAhBF3+VLAseyMqZeBjW0AHJoxOtYqSUZNJxauErmLbVm2FW1y+J/YA9dUrAC39ITejlZWhVIwawkKw==",
+          "dev": true,
+          "requires": {
+            "core-util-is": "~1.0.0",
+            "inherits": "~2.0.3",
+            "isarray": "~1.0.0",
+            "process-nextick-args": "~2.0.0",
+            "safe-buffer": "~5.1.1",
+            "string_decoder": "~1.1.1",
+            "util-deprecate": "~1.0.1"
+          }
+        },
+        "string_decoder": {
+          "version": "1.1.1",
+          "resolved": "https://registry.npmjs.org/string_decoder/-/string_decoder-1.1.1.tgz",
+          "integrity": "sha512-n/ShnvDi6FHbbVfviro+WojiFzv+s8MPMHBczVePfUpDJLwoLT0ht1l4YwBCbi8pJAveEEdnkHyPyTP/mzRfwg==",
+          "dev": true,
+          "requires": {
+            "safe-buffer": "~5.1.0"
+          }
+        }
       }
     },
     "follow-redirects": {
@@ -5032,6 +5042,15 @@
       "integrity": "sha1-gQaNKVqBQuwKxybG4iAMMPttXoA=",
       "dev": true
     },
+    "for-own": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/for-own/-/for-own-1.0.0.tgz",
+      "integrity": "sha1-xjMy9BXO3EsE2/5wz4NklMU8tEs=",
+      "dev": true,
+      "requires": {
+        "for-in": "^1.0.1"
+      }
+    },
     "forever-agent": {
       "version": "0.6.1",
       "resolved": "https://registry.npmjs.org/forever-agent/-/forever-agent-0.6.1.tgz",
@@ -5109,14 +5128,6 @@
         "universalify": "^0.1.0"
       }
     },
-    "fs-minipass": {
-      "version": "1.2.5",
-      "resolved": "https://registry.npmjs.org/fs-minipass/-/fs-minipass-1.2.5.tgz",
-      "integrity": "sha512-JhBl0skXjUPCFH7x6x61gQxrKyXsxB5gcgePLZCwfyCGGsTISMoIeObbrvVeP6Xmyaudw4TT43qV2Gz+iyd2oQ==",
-      "requires": {
-        "minipass": "^2.2.1"
-      }
-    },
     "fs-write-stream-atomic": {
       "version": "1.0.10",
       "resolved": "https://registry.npmjs.org/fs-write-stream-atomic/-/fs-write-stream-atomic-1.0.10.tgz",
@@ -5132,36 +5143,151 @@
     "fs.realpath": {
       "version": "1.0.0",
       "resolved": "https://registry.npmjs.org/fs.realpath/-/fs.realpath-1.0.0.tgz",
-      "integrity": "sha1-FQStJSMVjKpA20onh8sBQRmU6k8="
+      "integrity": "sha1-FQStJSMVjKpA20onh8sBQRmU6k8=",
+      "dev": true
     },
     "fsevents": {
-      "version": "1.2.7",
-      "resolved": "https://registry.npmjs.org/fsevents/-/fsevents-1.2.7.tgz",
-      "integrity": "sha512-Pxm6sI2MeBD7RdD12RYsqaP0nMiwx8eZBXCa6z2L+mRHm2DYrOYwihmhjpkdjUHwQhslWQjRpEgNq4XvBmaAuw==",
+      "version": "1.2.8",
+      "resolved": "https://registry.npmjs.org/fsevents/-/fsevents-1.2.8.tgz",
+      "integrity": "sha512-tPvHgPGB7m40CZ68xqFGkKuzN+RnpGmSV+hgeKxhRpbxdqKXUFJGC3yonBOLzQBcJyGpdZFDfCsdOC2KFsXzeA==",
       "dev": true,
       "optional": true,
       "requires": {
-        "nan": "^2.9.2",
-        "node-pre-gyp": "^0.10.0"
+        "nan": "^2.12.1",
+        "node-pre-gyp": "^0.12.0"
       },
       "dependencies": {
+        "abbrev": {
+          "version": "1.1.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
         "ansi-regex": {
           "version": "2.1.1",
-          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-2.1.1.tgz",
-          "integrity": "sha1-w7M6te42DYbg5ijwRorn7yfWVN8="
+          "bundled": true,
+          "dev": true
+        },
+        "aproba": {
+          "version": "1.2.0",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "are-we-there-yet": {
+          "version": "1.1.5",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "delegates": "^1.0.0",
+            "readable-stream": "^2.0.6"
+          }
+        },
+        "balanced-match": {
+          "version": "1.0.0",
+          "bundled": true,
+          "dev": true
+        },
+        "brace-expansion": {
+          "version": "1.1.11",
+          "bundled": true,
+          "dev": true,
+          "requires": {
+            "balanced-match": "^1.0.0",
+            "concat-map": "0.0.1"
+          }
+        },
+        "chownr": {
+          "version": "1.1.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "code-point-at": {
+          "version": "1.1.0",
+          "bundled": true,
+          "dev": true
+        },
+        "concat-map": {
+          "version": "0.0.1",
+          "bundled": true,
+          "dev": true
+        },
+        "console-control-strings": {
+          "version": "1.1.0",
+          "bundled": true,
+          "dev": true
+        },
+        "core-util-is": {
+          "version": "1.0.2",
+          "bundled": true,
+          "dev": true,
+          "optional": true
         },
         "debug": {
-          "version": "2.6.9",
-          "resolved": "https://registry.npmjs.org/debug/-/debug-2.6.9.tgz",
-          "integrity": "sha512-bC7ElrdJaJnPbAP+1EotYvqZsb3ecl5wi6Bfi6BJTUcNowp6cvspg0jXznRTKDjm/E7AdgFBVeAPVMNcKGsHMA==",
+          "version": "4.1.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
           "requires": {
-            "ms": "2.0.0"
+            "ms": "^2.1.1"
+          }
+        },
+        "deep-extend": {
+          "version": "0.6.0",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "delegates": {
+          "version": "1.0.0",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "detect-libc": {
+          "version": "1.0.3",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "fs-minipass": {
+          "version": "1.2.5",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "minipass": "^2.2.1"
+          }
+        },
+        "fs.realpath": {
+          "version": "1.0.0",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "gauge": {
+          "version": "2.7.4",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "aproba": "^1.0.3",
+            "console-control-strings": "^1.0.0",
+            "has-unicode": "^2.0.0",
+            "object-assign": "^4.1.0",
+            "signal-exit": "^3.0.0",
+            "string-width": "^1.0.1",
+            "strip-ansi": "^3.0.1",
+            "wide-align": "^1.1.0"
           }
         },
         "glob": {
           "version": "7.1.3",
-          "resolved": "https://registry.npmjs.org/glob/-/glob-7.1.3.tgz",
-          "integrity": "sha512-vcfuiIxogLV4DlGBHIUOwI0IbrJ8HWPc4MU7HzviGeNho/UJDfi6B5p3sHeWIQ0KGIU0Jpxi5ZHxemQfLkkAwQ==",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
           "requires": {
             "fs.realpath": "^1.0.0",
             "inflight": "^1.0.4",
@@ -5171,72 +5297,347 @@
             "path-is-absolute": "^1.0.0"
           }
         },
+        "has-unicode": {
+          "version": "2.0.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "iconv-lite": {
+          "version": "0.4.24",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "safer-buffer": ">= 2.1.2 < 3"
+          }
+        },
+        "ignore-walk": {
+          "version": "3.0.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "minimatch": "^3.0.4"
+          }
+        },
+        "inflight": {
+          "version": "1.0.6",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "once": "^1.3.0",
+            "wrappy": "1"
+          }
+        },
+        "inherits": {
+          "version": "2.0.3",
+          "bundled": true,
+          "dev": true
+        },
+        "ini": {
+          "version": "1.3.5",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
         "is-fullwidth-code-point": {
           "version": "1.0.0",
-          "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-1.0.0.tgz",
-          "integrity": "sha1-754xOG8DGn8NZDr4L95QxFfvAMs=",
+          "bundled": true,
+          "dev": true,
           "requires": {
             "number-is-nan": "^1.0.0"
           }
         },
+        "isarray": {
+          "version": "1.0.0",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "minimatch": {
+          "version": "3.0.4",
+          "bundled": true,
+          "dev": true,
+          "requires": {
+            "brace-expansion": "^1.1.7"
+          }
+        },
         "minimist": {
           "version": "0.0.8",
-          "resolved": "https://registry.npmjs.org/minimist/-/minimist-0.0.8.tgz",
-          "integrity": "sha1-hX/Kv8M5fSYluCKCYuhqp6ARsF0="
-        },
-        "ms": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/ms/-/ms-2.0.0.tgz",
-          "integrity": "sha1-VgiurfwAvmwpAd9fmGF4jeDVl8g="
+          "bundled": true,
+          "dev": true
         },
-        "nopt": {
-          "version": "4.0.1",
-          "resolved": "https://registry.npmjs.org/nopt/-/nopt-4.0.1.tgz",
-          "integrity": "sha1-0NRoWv1UFRk8jHUFYC0NF81kR00=",
+        "minipass": {
+          "version": "2.3.5",
+          "bundled": true,
+          "dev": true,
           "requires": {
-            "abbrev": "1",
-            "osenv": "^0.1.4"
+            "safe-buffer": "^5.1.2",
+            "yallist": "^3.0.0"
           }
         },
-        "process-nextick-args": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/process-nextick-args/-/process-nextick-args-2.0.0.tgz",
-          "integrity": "sha512-MtEC1TqN0EU5nephaJ4rAtThHtC86dNN9qCuEhtshvpVBkAW5ZO7BASN9REnF9eoXGcRub+pFuKEpOHE+HbEMw=="
+        "minizlib": {
+          "version": "1.2.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "minipass": "^2.2.1"
+          }
         },
-        "readable-stream": {
-          "version": "2.3.6",
-          "resolved": "https://registry.npmjs.org/readable-stream/-/readable-stream-2.3.6.tgz",
-          "integrity": "sha512-tQtKA9WIAhBF3+VLAseyMqZeBjW0AHJoxOtYqSUZNJxauErmLbVm2FW1y+J/YA9dUrAC39ITejlZWhVIwawkKw==",
+        "mkdirp": {
+          "version": "0.5.1",
+          "bundled": true,
+          "dev": true,
           "requires": {
-            "core-util-is": "~1.0.0",
-            "inherits": "~2.0.3",
-            "isarray": "~1.0.0",
-            "process-nextick-args": "~2.0.0",
-            "safe-buffer": "~5.1.1",
-            "string_decoder": "~1.1.1",
-            "util-deprecate": "~1.0.1"
+            "minimist": "0.0.8"
+          }
+        },
+        "ms": {
+          "version": "2.1.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "needle": {
+          "version": "2.3.0",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "debug": "^4.1.0",
+            "iconv-lite": "^0.4.4",
+            "sax": "^1.2.4"
+          }
+        },
+        "node-pre-gyp": {
+          "version": "0.12.0",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "detect-libc": "^1.0.2",
+            "mkdirp": "^0.5.1",
+            "needle": "^2.2.1",
+            "nopt": "^4.0.1",
+            "npm-packlist": "^1.1.6",
+            "npmlog": "^4.0.2",
+            "rc": "^1.2.7",
+            "rimraf": "^2.6.1",
+            "semver": "^5.3.0",
+            "tar": "^4"
+          }
+        },
+        "nopt": {
+          "version": "4.0.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "abbrev": "1",
+            "osenv": "^0.1.4"
+          }
+        },
+        "npm-bundled": {
+          "version": "1.0.6",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "npm-packlist": {
+          "version": "1.4.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "ignore-walk": "^3.0.1",
+            "npm-bundled": "^1.0.1"
+          }
+        },
+        "npmlog": {
+          "version": "4.1.2",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "are-we-there-yet": "~1.1.2",
+            "console-control-strings": "~1.1.0",
+            "gauge": "~2.7.3",
+            "set-blocking": "~2.0.0"
+          }
+        },
+        "number-is-nan": {
+          "version": "1.0.1",
+          "bundled": true,
+          "dev": true
+        },
+        "object-assign": {
+          "version": "4.1.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "once": {
+          "version": "1.4.0",
+          "bundled": true,
+          "dev": true,
+          "requires": {
+            "wrappy": "1"
+          }
+        },
+        "os-homedir": {
+          "version": "1.0.2",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "os-tmpdir": {
+          "version": "1.0.2",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "osenv": {
+          "version": "0.1.5",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "os-homedir": "^1.0.0",
+            "os-tmpdir": "^1.0.0"
+          }
+        },
+        "path-is-absolute": {
+          "version": "1.0.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "process-nextick-args": {
+          "version": "2.0.0",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "rc": {
+          "version": "1.2.8",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "deep-extend": "^0.6.0",
+            "ini": "~1.3.0",
+            "minimist": "^1.2.0",
+            "strip-json-comments": "~2.0.1"
+          },
+          "dependencies": {
+            "minimist": {
+              "version": "1.2.0",
+              "bundled": true,
+              "dev": true,
+              "optional": true
+            }
+          }
+        },
+        "readable-stream": {
+          "version": "2.3.6",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "core-util-is": "~1.0.0",
+            "inherits": "~2.0.3",
+            "isarray": "~1.0.0",
+            "process-nextick-args": "~2.0.0",
+            "safe-buffer": "~5.1.1",
+            "string_decoder": "~1.1.1",
+            "util-deprecate": "~1.0.1"
+          }
+        },
+        "rimraf": {
+          "version": "2.6.3",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "glob": "^7.1.3"
+          }
+        },
+        "safe-buffer": {
+          "version": "5.1.2",
+          "bundled": true,
+          "dev": true
+        },
+        "safer-buffer": {
+          "version": "2.1.2",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "sax": {
+          "version": "1.2.4",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "semver": {
+          "version": "5.7.0",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "set-blocking": {
+          "version": "2.0.0",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "signal-exit": {
+          "version": "3.0.2",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "string-width": {
+          "version": "1.0.2",
+          "bundled": true,
+          "dev": true,
+          "requires": {
+            "code-point-at": "^1.0.0",
+            "is-fullwidth-code-point": "^1.0.0",
+            "strip-ansi": "^3.0.0"
           }
         },
         "string_decoder": {
           "version": "1.1.1",
-          "resolved": "https://registry.npmjs.org/string_decoder/-/string_decoder-1.1.1.tgz",
-          "integrity": "sha512-n/ShnvDi6FHbbVfviro+WojiFzv+s8MPMHBczVePfUpDJLwoLT0ht1l4YwBCbi8pJAveEEdnkHyPyTP/mzRfwg==",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
           "requires": {
             "safe-buffer": "~5.1.0"
           }
         },
         "strip-ansi": {
           "version": "3.0.1",
-          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-3.0.1.tgz",
-          "integrity": "sha1-ajhfuIU9lS1f8F0Oiq+UJ43GPc8=",
+          "bundled": true,
+          "dev": true,
           "requires": {
             "ansi-regex": "^2.0.0"
           }
         },
+        "strip-json-comments": {
+          "version": "2.0.1",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
         "tar": {
           "version": "4.4.8",
-          "resolved": "https://registry.npmjs.org/tar/-/tar-4.4.8.tgz",
-          "integrity": "sha512-LzHF64s5chPQQS0IYBn9IN5h3i98c12bo4NCO7e0sGM2llXQ3p2FGC5sdENN4cTW48O915Sh+x+EXx7XW96xYQ==",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
           "requires": {
             "chownr": "^1.1.1",
             "fs-minipass": "^1.2.5",
@@ -5247,10 +5648,30 @@
             "yallist": "^3.0.2"
           }
         },
+        "util-deprecate": {
+          "version": "1.0.2",
+          "bundled": true,
+          "dev": true,
+          "optional": true
+        },
+        "wide-align": {
+          "version": "1.1.3",
+          "bundled": true,
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "string-width": "^1.0.2 || 2"
+          }
+        },
+        "wrappy": {
+          "version": "1.0.2",
+          "bundled": true,
+          "dev": true
+        },
         "yallist": {
           "version": "3.0.3",
-          "resolved": "https://registry.npmjs.org/yallist/-/yallist-3.0.3.tgz",
-          "integrity": "sha512-S+Zk8DEWE6oKpV+vI3qWkaK+jSbIK86pCwe2IF/xwIpQ8jEuxpw9NyaGjmp9+BoJv5FV2piqCDcoCtStppiq2A=="
+          "bundled": true,
+          "dev": true
         }
       }
     },
@@ -5341,9 +5762,9 @@
       }
     },
     "get-caller-file": {
-      "version": "1.0.3",
-      "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-1.0.3.tgz",
-      "integrity": "sha512-3t6rVToeoZfYSGd8YoLFR2DJkiQrIiUrGcjvFX2mDw3bn6k2OtwHN0TNCLbBO+w8qTvimhDkv+LSscbJY1vE6w==",
+      "version": "2.0.5",
+      "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-2.0.5.tgz",
+      "integrity": "sha512-DyFP3BM/3YHTQOCUL/w0OZHR0lpKeGrxotcHWcqNEdnltqFwXVfhEBQ94eIo34AfQpo0rGki4cyIiftY06h2Fg==",
       "dev": true
     },
     "get-func-name": {
@@ -5442,9 +5863,9 @@
       "dev": true
     },
     "globals": {
-      "version": "11.10.0",
-      "resolved": "https://registry.npmjs.org/globals/-/globals-11.10.0.tgz",
-      "integrity": "sha512-0GZF1RiPKU97IHUO5TORo9w1PwrH/NBPl+fS7oMLdaTRiYmYbwK4NWoZWrAdd0/abG9R2BU+OiwyQpTpE6pdfQ=="
+      "version": "11.11.0",
+      "resolved": "https://registry.npmjs.org/globals/-/globals-11.11.0.tgz",
+      "integrity": "sha512-WHq43gS+6ufNOEqlrDBxVEbb8ntfXrfAUU2ZOpCxrBdGKW3gyv8mCxAfIBD0DroPKGrJ2eSsXsLtY9MPntsyTw=="
     },
     "globby": {
       "version": "8.0.1",
@@ -5504,32 +5925,6 @@
       "requires": {
         "ajv": "^6.5.5",
         "har-schema": "^2.0.0"
-      },
-      "dependencies": {
-        "ajv": {
-          "version": "6.6.2",
-          "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.6.2.tgz",
-          "integrity": "sha512-FBHEW6Jf5TB9MGBgUUA9XHkTbjXYfAUjY43ACMfmdMRHniyoMHjHjzD50OK8LGDWQwp4rWEsIq5kEqq7rvIM1g==",
-          "dev": true,
-          "requires": {
-            "fast-deep-equal": "^2.0.1",
-            "fast-json-stable-stringify": "^2.0.0",
-            "json-schema-traverse": "^0.4.1",
-            "uri-js": "^4.2.2"
-          }
-        },
-        "fast-deep-equal": {
-          "version": "2.0.1",
-          "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-2.0.1.tgz",
-          "integrity": "sha1-ewUhjd+WZ79/Nwv3/bLLFf3Qqkk=",
-          "dev": true
-        },
-        "json-schema-traverse": {
-          "version": "0.4.1",
-          "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.4.1.tgz",
-          "integrity": "sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==",
-          "dev": true
-        }
       }
     },
     "has": {
@@ -5572,8 +5967,7 @@
     "has-flag": {
       "version": "3.0.0",
       "resolved": "https://registry.npmjs.org/has-flag/-/has-flag-3.0.0.tgz",
-      "integrity": "sha1-tdRU3CGZriJWmfNGfloH87lVuv0=",
-      "dev": true
+      "integrity": "sha1-tdRU3CGZriJWmfNGfloH87lVuv0="
     },
     "has-symbols": {
       "version": "1.0.0",
@@ -5712,6 +6106,14 @@
         "param-case": "2.1.x",
         "relateurl": "0.2.x",
         "uglify-js": "3.4.x"
+      },
+      "dependencies": {
+        "commander": {
+          "version": "2.17.1",
+          "resolved": "https://registry.npmjs.org/commander/-/commander-2.17.1.tgz",
+          "integrity": "sha512-wPMUt6FnH2yzG95SA6mzjQOEKUU3aLaDEmzs1ti+1E9h+CsrZghRlqEM/EJ4KscsQVG8uNN4uVreUeT8+drlgg==",
+          "dev": true
+        }
       }
     },
     "html-webpack-plugin": {
@@ -5813,9 +6215,9 @@
           "dev": true
         },
         "js-yaml": {
-          "version": "3.12.1",
-          "resolved": "https://registry.npmjs.org/js-yaml/-/js-yaml-3.12.1.tgz",
-          "integrity": "sha512-um46hB9wNOKlwkHgiuyEVAybXBjwFUV0Z/RaHJblRd9DXltue9FTYvzCr9ErQrK9Adz5MU4gHWVaNUfdmrC8qA==",
+          "version": "3.13.1",
+          "resolved": "https://registry.npmjs.org/js-yaml/-/js-yaml-3.13.1.tgz",
+          "integrity": "sha512-YfbcO7jXDdyj0DGxYVSlSeQNHbD7XPWvrVWeVUujrQEoZzWJIRrCPoyk6kL6IAjAG2IolMK4T0hNUe0HOUs5Jw==",
           "dev": true,
           "requires": {
             "argparse": "^1.0.7",
@@ -5823,23 +6225,23 @@
           }
         },
         "svgo": {
-          "version": "1.1.1",
-          "resolved": "https://registry.npmjs.org/svgo/-/svgo-1.1.1.tgz",
-          "integrity": "sha512-GBkJbnTuFpM4jFbiERHDWhZc/S/kpHToqmZag3aEBjPYK44JAN2QBjvrGIxLOoCyMZjuFQIfTO2eJd8uwLY/9g==",
+          "version": "1.2.2",
+          "resolved": "https://registry.npmjs.org/svgo/-/svgo-1.2.2.tgz",
+          "integrity": "sha512-rAfulcwp2D9jjdGu+0CuqlrAUin6bBWrpoqXWwKDZZZJfXcUXQSxLJOFJCQCSA0x0pP2U0TxSlJu2ROq5Bq6qA==",
           "dev": true,
           "requires": {
-            "coa": "~2.0.1",
-            "colors": "~1.1.2",
+            "chalk": "^2.4.1",
+            "coa": "^2.0.2",
             "css-select": "^2.0.0",
-            "css-select-base-adapter": "~0.1.0",
+            "css-select-base-adapter": "^0.1.1",
             "css-tree": "1.0.0-alpha.28",
             "css-url-regex": "^1.1.0",
-            "csso": "^3.5.0",
-            "js-yaml": "^3.12.0",
+            "csso": "^3.5.1",
+            "js-yaml": "^3.13.1",
             "mkdirp": "~0.5.1",
-            "object.values": "^1.0.4",
+            "object.values": "^1.1.0",
             "sax": "~1.2.4",
-            "stable": "~0.1.6",
+            "stable": "^0.1.8",
             "unquote": "~1.1.1",
             "util.promisify": "~1.0.0"
           }
@@ -5847,23 +6249,23 @@
       }
     },
     "htmlparser2": {
-      "version": "3.10.0",
-      "resolved": "https://registry.npmjs.org/htmlparser2/-/htmlparser2-3.10.0.tgz",
-      "integrity": "sha512-J1nEUGv+MkXS0weHNWVKJJ+UrLfePxRWpN3C9bEi9fLxL2+ggW94DQvgYVXsaT30PGwYRIZKNZXuyMhp3Di4bQ==",
+      "version": "3.10.1",
+      "resolved": "https://registry.npmjs.org/htmlparser2/-/htmlparser2-3.10.1.tgz",
+      "integrity": "sha512-IgieNijUMbkDovyoKObU1DUhm1iwNYE/fuifEoEHfd1oZKZDaONBSkal7Y01shxsM49R4XaMdGez3WnF9UfiCQ==",
       "dev": true,
       "requires": {
-        "domelementtype": "^1.3.0",
+        "domelementtype": "^1.3.1",
         "domhandler": "^2.3.0",
         "domutils": "^1.5.1",
         "entities": "^1.1.1",
         "inherits": "^2.0.1",
-        "readable-stream": "^3.0.6"
+        "readable-stream": "^3.1.1"
       },
       "dependencies": {
         "readable-stream": {
-          "version": "3.1.1",
-          "resolved": "https://registry.npmjs.org/readable-stream/-/readable-stream-3.1.1.tgz",
-          "integrity": "sha512-DkN66hPyqDhnIQ6Jcsvx9bFjhw214O4poMBcIMgPVpQvNy9a0e0Uhg5SqySyDKAmUlwt8LonTBz1ezOnM8pUdA==",
+          "version": "3.3.0",
+          "resolved": "https://registry.npmjs.org/readable-stream/-/readable-stream-3.3.0.tgz",
+          "integrity": "sha512-EsI+s3k3XsW+fU8fQACLN59ky34AZ14LoeVZpYwmZvldCFo0r0gnelwF2TcMjLor/BTL5aDJVBMkss0dthToPw==",
           "dev": true,
           "requires": {
             "inherits": "^2.0.3",
@@ -5889,15 +6291,16 @@
       "dev": true
     },
     "http-errors": {
-      "version": "1.6.3",
-      "resolved": "https://registry.npmjs.org/http-errors/-/http-errors-1.6.3.tgz",
-      "integrity": "sha1-i1VoC7S+KDoLW/TqLjhYC+HZMg0=",
+      "version": "1.7.2",
+      "resolved": "https://registry.npmjs.org/http-errors/-/http-errors-1.7.2.tgz",
+      "integrity": "sha512-uUQBt3H/cSIVfch6i1EuPNy/YsRSOUBXTVfZ+yR7Zjez3qjBz6i9+i4zjNaoqcoFVI4lQJ5plg63TvGfRSDCRg==",
       "dev": true,
       "requires": {
         "depd": "~1.1.2",
         "inherits": "2.0.3",
-        "setprototypeof": "1.1.0",
-        "statuses": ">= 1.4.0 < 2"
+        "setprototypeof": "1.1.1",
+        "statuses": ">= 1.5.0 < 2",
+        "toidentifier": "1.0.0"
       }
     },
     "http-parser-js": {
@@ -6001,9 +6404,9 @@
       }
     },
     "ieee754": {
-      "version": "1.1.12",
-      "resolved": "https://registry.npmjs.org/ieee754/-/ieee754-1.1.12.tgz",
-      "integrity": "sha512-GguP+DRY+pJ3soyIiGPTvdiVXjZ+DbXOxGpXn3eMvNW4x4irjqXm4wHKscC+TfxSJ0yw/S1F24tqdMNsMZTiLA==",
+      "version": "1.1.13",
+      "resolved": "https://registry.npmjs.org/ieee754/-/ieee754-1.1.13.tgz",
+      "integrity": "sha512-4vf7I2LYV/HaWerSo3XmlMkp5eZ83i+/CDluXi/IGTs/O1sejBNhTtnxzmRZfvOUqj7lZjqHkeTvpgSFDlWZTg==",
       "dev": true
     },
     "iferr": {
@@ -6024,16 +6427,6 @@
       "integrity": "sha1-2B8kA3bQuk8Nd4lyw60lh0EXpGM=",
       "dev": true
     },
-    "ignore-walk": {
-      "version": "3.0.1",
-      "resolved": "https://registry.npmjs.org/ignore-walk/-/ignore-walk-3.0.1.tgz",
-      "integrity": "sha512-DTVlMx3IYPe0/JJcYP7Gxg7ttZZu3IInhuEhbchuqneY9wWe5Ojy2mXLBaQFUQmo0AW2r3qG7m1mg86js+gnlQ==",
-      "dev": true,
-      "optional": true,
-      "requires": {
-        "minimatch": "^3.0.4"
-      }
-    },
     "image-size": {
       "version": "0.5.5",
       "resolved": "https://registry.npmjs.org/image-size/-/image-size-0.5.5.tgz",
@@ -6101,6 +6494,7 @@
       "version": "1.0.6",
       "resolved": "https://registry.npmjs.org/inflight/-/inflight-1.0.6.tgz",
       "integrity": "sha1-Sb1jMdfQLQwJvJEKEHW6gWW1bfk=",
+      "dev": true,
       "requires": {
         "once": "^1.3.0",
         "wrappy": "1"
@@ -6111,47 +6505,60 @@
       "resolved": "https://registry.npmjs.org/inherits/-/inherits-2.0.3.tgz",
       "integrity": "sha1-Yzwsg+PaQqUC9SRmAiSA9CCCYd4="
     },
-    "ini": {
-      "version": "1.3.5",
-      "resolved": "https://registry.npmjs.org/ini/-/ini-1.3.5.tgz",
-      "integrity": "sha512-RZY5huIKCMRWDUqZlEi72f/lmXKMvuszcMBduliQ3nnWbx9X/ZBQO7DijMEYS9EhHBb2qacRUMtC7svLwe0lcw==",
-      "dev": true,
-      "optional": true
-    },
     "inquirer": {
-      "version": "6.2.1",
-      "resolved": "https://registry.npmjs.org/inquirer/-/inquirer-6.2.1.tgz",
-      "integrity": "sha512-088kl3DRT2dLU5riVMKKr1DlImd6X7smDhpXUCkJDCKvTEJeRiXh0G132HG9u5a+6Ylw9plFRY7RuTnwohYSpg==",
+      "version": "6.3.1",
+      "resolved": "https://registry.npmjs.org/inquirer/-/inquirer-6.3.1.tgz",
+      "integrity": "sha512-MmL624rfkFt4TG9y/Jvmt8vdmOo836U7Y0Hxr2aFk3RelZEGX4Igk0KabWrcaaZaTv9uzglOqWh1Vly+FAWAXA==",
       "dev": true,
       "requires": {
-        "ansi-escapes": "^3.0.0",
-        "chalk": "^2.0.0",
+        "ansi-escapes": "^3.2.0",
+        "chalk": "^2.4.2",
         "cli-cursor": "^2.1.0",
         "cli-width": "^2.0.0",
-        "external-editor": "^3.0.0",
+        "external-editor": "^3.0.3",
         "figures": "^2.0.0",
-        "lodash": "^4.17.10",
+        "lodash": "^4.17.11",
         "mute-stream": "0.0.7",
         "run-async": "^2.2.0",
-        "rxjs": "^6.1.0",
+        "rxjs": "^6.4.0",
         "string-width": "^2.1.0",
-        "strip-ansi": "^5.0.0",
+        "strip-ansi": "^5.1.0",
         "through": "^2.3.6"
       },
       "dependencies": {
         "ansi-regex": {
-          "version": "4.0.0",
-          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-4.0.0.tgz",
-          "integrity": "sha512-iB5Dda8t/UqpPI/IjsejXu5jOGDrzn41wJyljwPH65VCIbk6+1BzFIMJGFwTNrYXT1CrD+B4l19U7awiQ8rk7w==",
+          "version": "4.1.0",
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-4.1.0.tgz",
+          "integrity": "sha512-1apePfXM1UOSqw0o9IiFAovVz9M5S1Dg+4TrDwfMewQ6p/rmMueb7tWZjQ1rx4Loy1ArBggoqGpfqqdI4rondg==",
           "dev": true
         },
+        "chalk": {
+          "version": "2.4.2",
+          "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.4.2.tgz",
+          "integrity": "sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==",
+          "dev": true,
+          "requires": {
+            "ansi-styles": "^3.2.1",
+            "escape-string-regexp": "^1.0.5",
+            "supports-color": "^5.3.0"
+          }
+        },
+        "rxjs": {
+          "version": "6.5.1",
+          "resolved": "https://registry.npmjs.org/rxjs/-/rxjs-6.5.1.tgz",
+          "integrity": "sha512-y0j31WJc83wPu31vS1VlAFW5JGrnGC+j+TtGAa1fRQphy48+fDYiDmX8tjGloToEsMkxnouOg/1IzXGKkJnZMg==",
+          "dev": true,
+          "requires": {
+            "tslib": "^1.9.0"
+          }
+        },
         "strip-ansi": {
-          "version": "5.0.0",
-          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-5.0.0.tgz",
-          "integrity": "sha512-Uu7gQyZI7J7gn5qLn1Np3G9vcYGTVqB+lFTytnDJv83dd8T22aGH451P3jueT2/QemInJDfxHB5Tde5OzgG1Ow==",
+          "version": "5.2.0",
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-5.2.0.tgz",
+          "integrity": "sha512-DuRs1gKbBqsMKIZlrffwlug8MHkcnpjs5VPmL1PAh+mA30U0DTotfDZ0d2UUsXpPmPmMMJ6W773MaA3J+lbiWA==",
           "dev": true,
           "requires": {
-            "ansi-regex": "^4.0.0"
+            "ansi-regex": "^4.1.0"
           }
         }
       }
@@ -6164,14 +6571,6 @@
       "requires": {
         "default-gateway": "^4.2.0",
         "ipaddr.js": "^1.9.0"
-      },
-      "dependencies": {
-        "ipaddr.js": {
-          "version": "1.9.0",
-          "resolved": "https://registry.npmjs.org/ipaddr.js/-/ipaddr.js-1.9.0.tgz",
-          "integrity": "sha512-M4Sjn6N/+O6/IXSJseKqHoFc+5FdGJ22sXqnjTpdZweHK64MzEPAyQZyEU3R/KRv2GLoa7nNtg/C2Ev6m7z+eA==",
-          "dev": true
-        }
       }
     },
     "interpret": {
@@ -6190,9 +6589,9 @@
       }
     },
     "invert-kv": {
-      "version": "1.0.0",
-      "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-1.0.0.tgz",
-      "integrity": "sha1-EEqOSqym09jNFXqO+L+rLXo//bY=",
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-2.0.0.tgz",
+      "integrity": "sha512-wPVv/y/QQ/Uiirj/vh3oP+1Ww+AWehmi1g5fFWGPF6IpCBCDVrhgHRMvrLfdYcwDh3QJbGXDW4JAuzxElLSqKA==",
       "dev": true
     },
     "ip": {
@@ -6208,9 +6607,9 @@
       "dev": true
     },
     "ipaddr.js": {
-      "version": "1.8.0",
-      "resolved": "https://registry.npmjs.org/ipaddr.js/-/ipaddr.js-1.8.0.tgz",
-      "integrity": "sha1-6qM9bd16zo9/b+DJygRA5wZzix4=",
+      "version": "1.9.0",
+      "resolved": "https://registry.npmjs.org/ipaddr.js/-/ipaddr.js-1.9.0.tgz",
+      "integrity": "sha512-M4Sjn6N/+O6/IXSJseKqHoFc+5FdGJ22sXqnjTpdZweHK64MzEPAyQZyEU3R/KRv2GLoa7nNtg/C2Ev6m7z+eA==",
       "dev": true
     },
     "is-absolute-url": {
@@ -6260,15 +6659,6 @@
       "integrity": "sha512-NcdALwpXkTm5Zvvbk7owOUSvVvBKDgKP5/ewfXEznmQFfs4ZRmanOeKBTjRVjka3QFoN6XJ+9F3USqfHqTaU5w==",
       "dev": true
     },
-    "is-builtin-module": {
-      "version": "1.0.0",
-      "resolved": "https://registry.npmjs.org/is-builtin-module/-/is-builtin-module-1.0.0.tgz",
-      "integrity": "sha1-VAVy0096wxGfj3bDDLwbHgN6/74=",
-      "dev": true,
-      "requires": {
-        "builtin-modules": "^1.0.0"
-      }
-    },
     "is-callable": {
       "version": "1.1.4",
       "resolved": "https://registry.npmjs.org/is-callable/-/is-callable-1.1.4.tgz",
@@ -6366,9 +6756,9 @@
       "dev": true
     },
     "is-glob": {
-      "version": "4.0.0",
-      "resolved": "https://registry.npmjs.org/is-glob/-/is-glob-4.0.0.tgz",
-      "integrity": "sha1-lSHHaEXMJhCoUgPd8ICpWML/q8A=",
+      "version": "4.0.1",
+      "resolved": "https://registry.npmjs.org/is-glob/-/is-glob-4.0.1.tgz",
+      "integrity": "sha512-5G0tKtBTFImOqDnLB2hG6Bp2qcKEFduo4tZu9MT/H6NQv/ghhy30o55ufafxJ/LdH79LLs2Kfrn85TLKyA7BUg==",
       "dev": true,
       "requires": {
         "is-extglob": "^2.1.1"
@@ -6395,27 +6785,27 @@
       }
     },
     "is-path-cwd": {
-      "version": "2.0.0",
-      "resolved": "https://registry.npmjs.org/is-path-cwd/-/is-path-cwd-2.0.0.tgz",
-      "integrity": "sha512-m5dHHzpOXEiv18JEORttBO64UgTEypx99vCxQLjbBvGhOJxnTNglYoFXxwo6AbsQb79sqqycQEHv2hWkHZAijA==",
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/is-path-cwd/-/is-path-cwd-2.1.0.tgz",
+      "integrity": "sha512-Sc5j3/YnM8tDeyCsVeKlm/0p95075DyLmDEIkSgQ7mXkrOX+uTCtmQFm0CYzVyJwcCCmO3k8qfJt17SxQwB5Zw==",
       "dev": true
     },
     "is-path-in-cwd": {
-      "version": "2.0.0",
-      "resolved": "https://registry.npmjs.org/is-path-in-cwd/-/is-path-in-cwd-2.0.0.tgz",
-      "integrity": "sha512-6Vz5Gc9s/sDA3JBVu0FzWufm8xaBsqy1zn8Q6gmvGP6nSDMw78aS4poBNeatWjaRpTpxxLn1WOndAiOlk+qY8A==",
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/is-path-in-cwd/-/is-path-in-cwd-2.1.0.tgz",
+      "integrity": "sha512-rNocXHgipO+rvnP6dk3zI20RpOtrAM/kzbB258Uw5BWr3TpXi861yzjo16Dn4hUox07iw5AyeMLHWsujkjzvRQ==",
       "dev": true,
       "requires": {
-        "is-path-inside": "^1.0.0"
+        "is-path-inside": "^2.1.0"
       }
     },
     "is-path-inside": {
-      "version": "1.0.1",
-      "resolved": "https://registry.npmjs.org/is-path-inside/-/is-path-inside-1.0.1.tgz",
-      "integrity": "sha1-jvW33lBDej/cprToZe96pVy0gDY=",
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/is-path-inside/-/is-path-inside-2.1.0.tgz",
+      "integrity": "sha512-wiyhTzfDWsvwAW53OBWF5zuvaOGlZ6PwYxAbPVDhpm+gM09xKQGjBq/8uYN12aDvMxnAnq3dxTyoSoRNmg5YFg==",
       "dev": true,
       "requires": {
-        "path-is-inside": "^1.0.1"
+        "path-is-inside": "^1.0.2"
       }
     },
     "is-plain-obj": {
@@ -6534,9 +6924,9 @@
       "integrity": "sha1-XE2d5lKvbNCncBVKYxu6ErAVx4c="
     },
     "js-base64": {
-      "version": "2.5.0",
-      "resolved": "https://registry.npmjs.org/js-base64/-/js-base64-2.5.0.tgz",
-      "integrity": "sha512-wlEBIZ5LP8usDylWbDNhKPEFVFdI5hCHpnVoT/Ysvoi/PRhJENm/Rlh9TvjYB38HFfKZN7OzEbRjmjvLkFw11g==",
+      "version": "2.5.1",
+      "resolved": "https://registry.npmjs.org/js-base64/-/js-base64-2.5.1.tgz",
+      "integrity": "sha512-M7kLczedRMYX4L8Mdh4MzyAMM9O5osx+4FcOQuTvr3A9F2D9S5JXheN0ewNbrvK2UatkTRhL5ejGmGSjNMiZuw==",
       "dev": true
     },
     "js-levenshtein": {
@@ -6598,9 +6988,9 @@
       "dev": true
     },
     "json-schema-traverse": {
-      "version": "0.3.1",
-      "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.3.1.tgz",
-      "integrity": "sha1-NJptRMU6Ud6JtAgFxdXlm0F9M0A=",
+      "version": "0.4.1",
+      "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.4.1.tgz",
+      "integrity": "sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==",
       "dev": true
     },
     "json-stable-stringify-without-jsonify": {
@@ -6710,9 +7100,9 @@
       }
     },
     "karma": {
-      "version": "4.0.1",
-      "resolved": "https://registry.npmjs.org/karma/-/karma-4.0.1.tgz",
-      "integrity": "sha512-ind+4s03BqIXas7ZmraV3/kc5+mnqwCd+VDX1FndS6jxbt03kQKX2vXrWxNLuCjVYmhMwOZosAEKMM0a2q7w7A==",
+      "version": "4.1.0",
+      "resolved": "https://registry.npmjs.org/karma/-/karma-4.1.0.tgz",
+      "integrity": "sha512-xckiDqyNi512U4dXGOOSyLKPwek6X/vUizSy2f3geYevbLj+UIdvNwbn7IwfUIL2g1GXEPWt/87qFD1fBbl/Uw==",
       "dev": true,
       "requires": {
         "bluebird": "^3.3.0",
@@ -6875,12 +7265,12 @@
       "dev": true
     },
     "lcid": {
-      "version": "1.0.0",
-      "resolved": "https://registry.npmjs.org/lcid/-/lcid-1.0.0.tgz",
-      "integrity": "sha1-MIrMr6C8SDo4Z7S28rlQYlHRuDU=",
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/lcid/-/lcid-2.0.0.tgz",
+      "integrity": "sha512-avPEb8P8EGnwXKClwsNUgryVjllcRqtMYa49NTsbQagYuT1DcXnl1915oxWjoyGrXR6zH/Y0Zc96xWsPcoDKeA==",
       "dev": true,
       "requires": {
-        "invert-kv": "^1.0.0"
+        "invert-kv": "^2.0.0"
       }
     },
     "levn": {
@@ -6923,9 +7313,9 @@
       }
     },
     "loader-fs-cache": {
-      "version": "1.0.1",
-      "resolved": "https://registry.npmjs.org/loader-fs-cache/-/loader-fs-cache-1.0.1.tgz",
-      "integrity": "sha1-VuC/CL2XCLJqdltoUJhAyN7J/bw=",
+      "version": "1.0.2",
+      "resolved": "https://registry.npmjs.org/loader-fs-cache/-/loader-fs-cache-1.0.2.tgz",
+      "integrity": "sha512-70IzT/0/L+M20jUlEqZhZyArTU6VKLRTYRDAYN26g4jfzpJqjipLL3/hgYpySqI9PwsVRHHFja0LfEmsx9X2Cw==",
       "dev": true,
       "requires": {
         "find-cache-dir": "^0.1.1",
@@ -6974,9 +7364,9 @@
       }
     },
     "loader-runner": {
-      "version": "2.3.1",
-      "resolved": "https://registry.npmjs.org/loader-runner/-/loader-runner-2.3.1.tgz",
-      "integrity": "sha512-By6ZFY7ETWOc9RFaAIb23IjJVcM4dvJC/N57nmdz9RSkMXvAXGI7SyVlAw3v8vjtDRlqThgVDVmTnr9fqMlxkw==",
+      "version": "2.4.0",
+      "resolved": "https://registry.npmjs.org/loader-runner/-/loader-runner-2.4.0.tgz",
+      "integrity": "sha512-Jsmr89RcXGIwivFY21FcRrisYZfvLMTWx5kOLc+JTxtpBOG6xML0vzbc6SEQG2FO9/4Fc3wW4LVcB5DmGflaRw==",
       "dev": true
     },
     "loader-utils": {
@@ -7079,12 +7469,6 @@
       "integrity": "sha1-4j8/nE+Pvd6HJSnBBxhXoIblzO8=",
       "dev": true
     },
-    "lodash.debounce": {
-      "version": "4.0.8",
-      "resolved": "https://registry.npmjs.org/lodash.debounce/-/lodash.debounce-4.0.8.tgz",
-      "integrity": "sha1-gteb/zCmfEAF/9XiUVMArZyk168=",
-      "dev": true
-    },
     "lodash.defaults": {
       "version": "4.2.0",
       "resolved": "https://registry.npmjs.org/lodash.defaults/-/lodash.defaults-4.2.0.tgz",
@@ -7300,14 +7684,22 @@
       "dev": true
     },
     "mem": {
-      "version": "4.0.0",
-      "resolved": "https://registry.npmjs.org/mem/-/mem-4.0.0.tgz",
-      "integrity": "sha512-WQxG/5xYc3tMbYLXoXPm81ET2WDULiU5FxbuIoNbJqLOOI8zehXFdZuiUEgfdrU2mVB1pxBZUGlYORSrpuJreA==",
+      "version": "4.3.0",
+      "resolved": "https://registry.npmjs.org/mem/-/mem-4.3.0.tgz",
+      "integrity": "sha512-qX2bG48pTqYRVmDB37rn/6PT7LcR8T7oAX3bf99u1Tt1nzxYfxkgqDwUwolPlXweM0XzBOBFzSx4kfp7KP1s/w==",
       "dev": true,
       "requires": {
         "map-age-cleaner": "^0.1.1",
-        "mimic-fn": "^1.0.0",
-        "p-is-promise": "^1.1.0"
+        "mimic-fn": "^2.0.0",
+        "p-is-promise": "^2.0.0"
+      },
+      "dependencies": {
+        "mimic-fn": {
+          "version": "2.1.0",
+          "resolved": "https://registry.npmjs.org/mimic-fn/-/mimic-fn-2.1.0.tgz",
+          "integrity": "sha512-OqbOk5oEQeAZ8WXWydlu9HJjz9WVdEIvamMCcXmuqUYjTknH/sqsWvhQ3vgwKFRR1HpjvNBKQ37nbJgYzGqGcg==",
+          "dev": true
+        }
       }
     },
     "memory-fs": {
@@ -7403,18 +7795,18 @@
       "dev": true
     },
     "mime-db": {
-      "version": "1.37.0",
-      "resolved": "https://registry.npmjs.org/mime-db/-/mime-db-1.37.0.tgz",
-      "integrity": "sha512-R3C4db6bgQhlIhPU48fUtdVmKnflq+hRdad7IyKhtFj06VPNVdk2RhiYL3UjQIlso8L+YxAtFkobT0VK+S/ybg==",
+      "version": "1.40.0",
+      "resolved": "https://registry.npmjs.org/mime-db/-/mime-db-1.40.0.tgz",
+      "integrity": "sha512-jYdeOMPy9vnxEqFRRo6ZvTZ8d9oPb+k18PKoYNYUe2stVEBPPwsln/qWzdbmaIvnhZ9v2P+CuecK+fpUfsV2mA==",
       "dev": true
     },
     "mime-types": {
-      "version": "2.1.21",
-      "resolved": "https://registry.npmjs.org/mime-types/-/mime-types-2.1.21.tgz",
-      "integrity": "sha512-3iL6DbwpyLzjR3xHSFNFeb9Nz/M8WDkX33t1GFQnFOllWk8pOrh/LSrB5OXlnlW5P9LH73X6loW/eogc+F5lJg==",
+      "version": "2.1.24",
+      "resolved": "https://registry.npmjs.org/mime-types/-/mime-types-2.1.24.tgz",
+      "integrity": "sha512-WaFHS3MCl5fapm3oLxU4eYDw77IQM2ACcxQ9RIxfaC3ooc6PFuBMGZZsYpvoXS5D5QTWPieo1jjLdAm3TBP3cQ==",
       "dev": true,
       "requires": {
-        "mime-db": "~1.37.0"
+        "mime-db": "1.40.0"
       }
     },
     "mimic-fn": {
@@ -7434,30 +7826,6 @@
         "webpack-sources": "^1.1.0"
       },
       "dependencies": {
-        "ajv": {
-          "version": "6.6.2",
-          "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.6.2.tgz",
-          "integrity": "sha512-FBHEW6Jf5TB9MGBgUUA9XHkTbjXYfAUjY43ACMfmdMRHniyoMHjHjzD50OK8LGDWQwp4rWEsIq5kEqq7rvIM1g==",
-          "dev": true,
-          "requires": {
-            "fast-deep-equal": "^2.0.1",
-            "fast-json-stable-stringify": "^2.0.0",
-            "json-schema-traverse": "^0.4.1",
-            "uri-js": "^4.2.2"
-          }
-        },
-        "fast-deep-equal": {
-          "version": "2.0.1",
-          "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-2.0.1.tgz",
-          "integrity": "sha1-ewUhjd+WZ79/Nwv3/bLLFf3Qqkk=",
-          "dev": true
-        },
-        "json-schema-traverse": {
-          "version": "0.4.1",
-          "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.4.1.tgz",
-          "integrity": "sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==",
-          "dev": true
-        },
         "schema-utils": {
           "version": "1.0.0",
           "resolved": "https://registry.npmjs.org/schema-utils/-/schema-utils-1.0.0.tgz",
@@ -7487,6 +7855,7 @@
       "version": "3.0.4",
       "resolved": "https://registry.npmjs.org/minimatch/-/minimatch-3.0.4.tgz",
       "integrity": "sha512-yJHVQEhyqPLUTgt9B83PXu6W3rx4MvvHvSUvToogpwoGDOUQ+yDrR0HRot+yOCdCO7u4hX3pWft6kWBBcqh0UA==",
+      "dev": true,
       "requires": {
         "brace-expansion": "^1.1.7"
       }
@@ -7497,30 +7866,6 @@
       "integrity": "sha1-o1AIsg9BOD7sH7kU9M1d95omQoQ=",
       "dev": true
     },
-    "minipass": {
-      "version": "2.3.5",
-      "resolved": "https://registry.npmjs.org/minipass/-/minipass-2.3.5.tgz",
-      "integrity": "sha512-Gi1W4k059gyRbyVUZQ4mEqLm0YIUiGYfvxhF6SIlk3ui1WVxMTGfGdQ2SInh3PDrRTVvPKgULkpJtT4RH10+VA==",
-      "requires": {
-        "safe-buffer": "^5.1.2",
-        "yallist": "^3.0.0"
-      },
-      "dependencies": {
-        "yallist": {
-          "version": "3.0.3",
-          "resolved": "https://registry.npmjs.org/yallist/-/yallist-3.0.3.tgz",
-          "integrity": "sha512-S+Zk8DEWE6oKpV+vI3qWkaK+jSbIK86pCwe2IF/xwIpQ8jEuxpw9NyaGjmp9+BoJv5FV2piqCDcoCtStppiq2A=="
-        }
-      }
-    },
-    "minizlib": {
-      "version": "1.2.1",
-      "resolved": "https://registry.npmjs.org/minizlib/-/minizlib-1.2.1.tgz",
-      "integrity": "sha512-7+4oTUOWKg7AuL3vloEWekXY2/D20cevzsrNT2kGWm+39J9hGTCBv8VI5Pm5lXZ/o3/mdR4f8rflAPhnQb8mPA==",
-      "requires": {
-        "minipass": "^2.2.1"
-      }
-    },
     "mississippi": {
       "version": "2.0.0",
       "resolved": "https://registry.npmjs.org/mississippi/-/mississippi-2.0.0.tgz",
@@ -7588,6 +7933,7 @@
       "version": "0.5.1",
       "resolved": "https://registry.npmjs.org/mkdirp/-/mkdirp-0.5.1.tgz",
       "integrity": "sha1-MAV0OOrGz3+MR2fzhkjWaX11yQM=",
+      "dev": true,
       "requires": {
         "minimist": "0.0.8"
       },
@@ -7595,14 +7941,15 @@
         "minimist": {
           "version": "0.0.8",
           "resolved": "https://registry.npmjs.org/minimist/-/minimist-0.0.8.tgz",
-          "integrity": "sha1-hX/Kv8M5fSYluCKCYuhqp6ARsF0="
+          "integrity": "sha1-hX/Kv8M5fSYluCKCYuhqp6ARsF0=",
+          "dev": true
         }
       }
     },
     "mocha": {
-      "version": "6.1.3",
-      "resolved": "https://registry.npmjs.org/mocha/-/mocha-6.1.3.tgz",
-      "integrity": "sha512-QdE/w//EPHrqgT5PNRUjRVHy6IJAzAf1R8n2O8W8K2RZ+NbPfOD5cBDp+PGa2Gptep37C/TdBiaNwakppEzEbg==",
+      "version": "6.1.4",
+      "resolved": "https://registry.npmjs.org/mocha/-/mocha-6.1.4.tgz",
+      "integrity": "sha512-PN8CIy4RXsIoxoFJzS4QNnCH4psUCPWc4/rPrst/ecSJJbLBkubMiyGCP2Kj/9YnWbotFqAoeXyXMucj7gwCFg==",
       "dev": true,
       "requires": {
         "ansi-colors": "3.2.3",
@@ -7614,7 +7961,7 @@
         "glob": "7.1.3",
         "growl": "1.10.5",
         "he": "1.2.0",
-        "js-yaml": "3.13.0",
+        "js-yaml": "3.13.1",
         "log-symbols": "2.2.0",
         "minimatch": "3.0.4",
         "mkdirp": "0.5.1",
@@ -7630,40 +7977,17 @@
         "yargs-unparser": "1.5.0"
       },
       "dependencies": {
-        "ansi-regex": {
-          "version": "3.0.0",
-          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-3.0.0.tgz",
-          "integrity": "sha1-7QMXwyIGT3lGbAKWa922Bas32Zg=",
-          "dev": true
-        },
-        "camelcase": {
-          "version": "5.3.1",
-          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.3.1.tgz",
-          "integrity": "sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==",
+        "ansi-colors": {
+          "version": "3.2.3",
+          "resolved": "https://registry.npmjs.org/ansi-colors/-/ansi-colors-3.2.3.tgz",
+          "integrity": "sha512-LEHHyuhlPY3TmuUYMh2oz89lTShfvgbmzaBcxve9t/9Wuy7Dwf4yoAKcND7KFT1HAQfqZ12qtc+DUrBMeKF9nw==",
           "dev": true
         },
-        "cliui": {
+        "ansi-regex": {
           "version": "4.1.0",
-          "resolved": "https://registry.npmjs.org/cliui/-/cliui-4.1.0.tgz",
-          "integrity": "sha512-4FG+RSG9DL7uEwRUZXZn3SS34DiDPfzP0VOiEwtUWlE+AR2EIg+hSyvrIgUUfhdgR/UkAeW2QHgeP+hWrXs7jQ==",
-          "dev": true,
-          "requires": {
-            "string-width": "^2.1.1",
-            "strip-ansi": "^4.0.0",
-            "wrap-ansi": "^2.0.0"
-          },
-          "dependencies": {
-            "string-width": {
-              "version": "2.1.1",
-              "resolved": "https://registry.npmjs.org/string-width/-/string-width-2.1.1.tgz",
-              "integrity": "sha512-nOqH59deCq9SRHlxq1Aw85Jnt4w6KvLKqWVik6oA9ZklXLNIOlqg4F2yrT1MVaTjAqvVwdfeZ7w7aCvJD7ugkw==",
-              "dev": true,
-              "requires": {
-                "is-fullwidth-code-point": "^2.0.0",
-                "strip-ansi": "^4.0.0"
-              }
-            }
-          }
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-4.1.0.tgz",
+          "integrity": "sha512-1apePfXM1UOSqw0o9IiFAovVz9M5S1Dg+4TrDwfMewQ6p/rmMueb7tWZjQ1rx4Loy1ArBggoqGpfqqdI4rondg==",
+          "dev": true
         },
         "debug": {
           "version": "3.2.6",
@@ -7674,12 +7998,6 @@
             "ms": "^2.1.1"
           }
         },
-        "diff": {
-          "version": "3.5.0",
-          "resolved": "https://registry.npmjs.org/diff/-/diff-3.5.0.tgz",
-          "integrity": "sha512-A46qtFgd+g7pDZinpnwiRJtxbC1hpgf0uzP3iG89scHk0AUC7A1TGxf5OiiOUv/JMZR8GOt8hL900hV0bOy5xA==",
-          "dev": true
-        },
         "esprima": {
           "version": "4.0.1",
           "resolved": "https://registry.npmjs.org/esprima/-/esprima-4.0.1.tgz",
@@ -7695,12 +8013,6 @@
             "locate-path": "^3.0.0"
           }
         },
-        "get-caller-file": {
-          "version": "2.0.5",
-          "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-2.0.5.tgz",
-          "integrity": "sha512-DyFP3BM/3YHTQOCUL/w0OZHR0lpKeGrxotcHWcqNEdnltqFwXVfhEBQ94eIo34AfQpo0rGki4cyIiftY06h2Fg==",
-          "dev": true
-        },
         "glob": {
           "version": "7.1.3",
           "resolved": "https://registry.npmjs.org/glob/-/glob-7.1.3.tgz",
@@ -7715,31 +8027,16 @@
             "path-is-absolute": "^1.0.0"
           }
         },
-        "invert-kv": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-2.0.0.tgz",
-          "integrity": "sha512-wPVv/y/QQ/Uiirj/vh3oP+1Ww+AWehmi1g5fFWGPF6IpCBCDVrhgHRMvrLfdYcwDh3QJbGXDW4JAuzxElLSqKA==",
-          "dev": true
-        },
         "js-yaml": {
-          "version": "3.13.0",
-          "resolved": "https://registry.npmjs.org/js-yaml/-/js-yaml-3.13.0.tgz",
-          "integrity": "sha512-pZZoSxcCYco+DIKBTimr67J6Hy+EYGZDY/HCWC+iAEA9h1ByhMXAIVUXMcMFpOCxQ/xjXmPI2MkDL5HRm5eFrQ==",
+          "version": "3.13.1",
+          "resolved": "https://registry.npmjs.org/js-yaml/-/js-yaml-3.13.1.tgz",
+          "integrity": "sha512-YfbcO7jXDdyj0DGxYVSlSeQNHbD7XPWvrVWeVUujrQEoZzWJIRrCPoyk6kL6IAjAG2IolMK4T0hNUe0HOUs5Jw==",
           "dev": true,
           "requires": {
             "argparse": "^1.0.7",
             "esprima": "^4.0.0"
           }
         },
-        "lcid": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/lcid/-/lcid-2.0.0.tgz",
-          "integrity": "sha512-avPEb8P8EGnwXKClwsNUgryVjllcRqtMYa49NTsbQagYuT1DcXnl1915oxWjoyGrXR6zH/Y0Zc96xWsPcoDKeA==",
-          "dev": true,
-          "requires": {
-            "invert-kv": "^2.0.0"
-          }
-        },
         "locate-path": {
           "version": "3.0.0",
           "resolved": "https://registry.npmjs.org/locate-path/-/locate-path-3.0.0.tgz",
@@ -7750,17 +8047,6 @@
             "path-exists": "^3.0.0"
           }
         },
-        "os-locale": {
-          "version": "3.1.0",
-          "resolved": "https://registry.npmjs.org/os-locale/-/os-locale-3.1.0.tgz",
-          "integrity": "sha512-Z8l3R4wYWM40/52Z+S265okfFj8Kt2cC2MKY+xNi3kFs+XGI7WXu/I309QQQYbRW4ijiZ+yxs9pqEhJh0DqW3Q==",
-          "dev": true,
-          "requires": {
-            "execa": "^1.0.0",
-            "lcid": "^2.0.0",
-            "mem": "^4.0.0"
-          }
-        },
         "p-limit": {
           "version": "2.2.0",
           "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.2.0.tgz",
@@ -7785,12 +8071,6 @@
           "integrity": "sha512-R4nPAVTAU0B9D35/Gk3uJf/7XYbQcyohSKdvAxIRSNghFl4e71hVoGnBNQz9cWaXxO2I10KTC+3jMdvvoKw6dQ==",
           "dev": true
         },
-        "require-main-filename": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-2.0.0.tgz",
-          "integrity": "sha512-NKN5kMDylKuldxYLSUfrbo5Tuzh4hd+2E8NPPX02mZtn1VuREQToYe/ZdlJy+J3uCpfaiGF05e7B8W0iXbQHmg==",
-          "dev": true
-        },
         "string-width": {
           "version": "3.1.0",
           "resolved": "https://registry.npmjs.org/string-width/-/string-width-3.1.0.tgz",
@@ -7800,32 +8080,15 @@
             "emoji-regex": "^7.0.1",
             "is-fullwidth-code-point": "^2.0.0",
             "strip-ansi": "^5.1.0"
-          },
-          "dependencies": {
-            "ansi-regex": {
-              "version": "4.1.0",
-              "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-4.1.0.tgz",
-              "integrity": "sha512-1apePfXM1UOSqw0o9IiFAovVz9M5S1Dg+4TrDwfMewQ6p/rmMueb7tWZjQ1rx4Loy1ArBggoqGpfqqdI4rondg==",
-              "dev": true
-            },
-            "strip-ansi": {
-              "version": "5.2.0",
-              "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-5.2.0.tgz",
-              "integrity": "sha512-DuRs1gKbBqsMKIZlrffwlug8MHkcnpjs5VPmL1PAh+mA30U0DTotfDZ0d2UUsXpPmPmMMJ6W773MaA3J+lbiWA==",
-              "dev": true,
-              "requires": {
-                "ansi-regex": "^4.1.0"
-              }
-            }
           }
         },
         "strip-ansi": {
-          "version": "4.0.0",
-          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
-          "integrity": "sha1-qEeQIusaw2iocTibY1JixQXuNo8=",
+          "version": "5.2.0",
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-5.2.0.tgz",
+          "integrity": "sha512-DuRs1gKbBqsMKIZlrffwlug8MHkcnpjs5VPmL1PAh+mA30U0DTotfDZ0d2UUsXpPmPmMMJ6W773MaA3J+lbiWA==",
           "dev": true,
           "requires": {
-            "ansi-regex": "^3.0.0"
+            "ansi-regex": "^4.1.0"
           }
         },
         "supports-color": {
@@ -7837,12 +8100,6 @@
             "has-flag": "^3.0.0"
           }
         },
-        "which-module": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/which-module/-/which-module-2.0.0.tgz",
-          "integrity": "sha1-2e8H3Od7mQK4o6j6SzHD4/fm6Ho=",
-          "dev": true
-        },
         "yargs": {
           "version": "13.2.2",
           "resolved": "https://registry.npmjs.org/yargs/-/yargs-13.2.2.tgz",
@@ -7861,16 +8118,6 @@
             "y18n": "^4.0.0",
             "yargs-parser": "^13.0.0"
           }
-        },
-        "yargs-parser": {
-          "version": "13.0.0",
-          "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-13.0.0.tgz",
-          "integrity": "sha512-w2LXjoL8oRdRQN+hOyppuXs+V/fVAYtpcrRxZuF7Kt/Oc+Jr2uAcVntaUTNT6w5ihoWfFDpNY8CPx1QskxZ/pw==",
-          "dev": true,
-          "requires": {
-            "camelcase": "^5.0.0",
-            "decamelize": "^1.2.0"
-          }
         }
       }
     },
@@ -7884,9 +8131,9 @@
       }
     },
     "moment": {
-      "version": "2.23.0",
-      "resolved": "https://registry.npmjs.org/moment/-/moment-2.23.0.tgz",
-      "integrity": "sha512-3IE39bHVqFbWWaPOMHZF98Q9c3LDKGTmypMiTM2QygGXXElkFWIH7GxfmlwmY2vwa+wmNsoYZmG2iusf1ZjJoA=="
+      "version": "2.24.0",
+      "resolved": "https://registry.npmjs.org/moment/-/moment-2.24.0.tgz",
+      "integrity": "sha512-bV7f+6l2QigeBBZSM/6yTNq4P2fNpSWj/0e7jQcy87A8e7o2nAfP/34/2ky5Vw4B9S446EtIhodAzkFCcR4dQg=="
     },
     "move-concurrently": {
       "version": "1.0.1",
@@ -7930,9 +8177,9 @@
       "dev": true
     },
     "nan": {
-      "version": "2.12.1",
-      "resolved": "https://registry.npmjs.org/nan/-/nan-2.12.1.tgz",
-      "integrity": "sha512-JY7V6lRkStKcKTvHO5NVSQRv+RV+FIL5pvDoLiAtSL9pKlC5x9PKQcZDsq7m4FO4d57mkhC6Z+QhAh3Jdk5JFw==",
+      "version": "2.13.2",
+      "resolved": "https://registry.npmjs.org/nan/-/nan-2.13.2.tgz",
+      "integrity": "sha512-TghvYc72wlMGMVMluVo9WRJc0mB8KxxF/gZ4YYFy7V2ZQX9l7rgbPg7vjS9mt6U5HXODVFVI2bOduCzwOMv/lw==",
       "dev": true
     },
     "nanomatch": {
@@ -7971,37 +8218,6 @@
       "resolved": "https://registry.npmjs.org/natural-compare-lite/-/natural-compare-lite-1.4.0.tgz",
       "integrity": "sha1-F7CVgZiJef3a/gIB6TG6kzyWy7Q="
     },
-    "needle": {
-      "version": "2.2.4",
-      "resolved": "https://registry.npmjs.org/needle/-/needle-2.2.4.tgz",
-      "integrity": "sha512-HyoqEb4wr/rsoaIDfTH2aVL9nWtQqba2/HvMv+++m8u0dz808MaagKILxtfeSN7QU7nvbQ79zk3vYOJp9zsNEA==",
-      "dev": true,
-      "optional": true,
-      "requires": {
-        "debug": "^2.1.2",
-        "iconv-lite": "^0.4.4",
-        "sax": "^1.2.4"
-      },
-      "dependencies": {
-        "debug": {
-          "version": "2.6.9",
-          "resolved": "https://registry.npmjs.org/debug/-/debug-2.6.9.tgz",
-          "integrity": "sha512-bC7ElrdJaJnPbAP+1EotYvqZsb3ecl5wi6Bfi6BJTUcNowp6cvspg0jXznRTKDjm/E7AdgFBVeAPVMNcKGsHMA==",
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "ms": "2.0.0"
-          }
-        },
-        "ms": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/ms/-/ms-2.0.0.tgz",
-          "integrity": "sha1-VgiurfwAvmwpAd9fmGF4jeDVl8g=",
-          "dev": true,
-          "optional": true
-        }
-      }
-    },
     "negotiator": {
       "version": "0.6.1",
       "resolved": "https://registry.npmjs.org/negotiator/-/negotiator-0.6.1.tgz",
@@ -8045,14 +8261,6 @@
       "requires": {
         "object.getownpropertydescriptors": "^2.0.3",
         "semver": "^5.7.0"
-      },
-      "dependencies": {
-        "semver": {
-          "version": "5.7.0",
-          "resolved": "https://registry.npmjs.org/semver/-/semver-5.7.0.tgz",
-          "integrity": "sha512-Ya52jSX2u7QKghxeoFGpLwCtGlt7j0oY9DYb5apt9nPlJ42ID+ulTXESnt/qAQcoSERyZ5sl3LDIOw0nAn/5DA==",
-          "dev": true
-        }
       }
     },
     "node-fetch": {
@@ -8100,9 +8308,9 @@
       }
     },
     "node-libs-browser": {
-      "version": "2.1.0",
-      "resolved": "https://registry.npmjs.org/node-libs-browser/-/node-libs-browser-2.1.0.tgz",
-      "integrity": "sha512-5AzFzdoIMb89hBGMZglEegffzgRg+ZFoUmisQ8HI4j1KDdpx13J0taNp2y9xPbur6W61gepGDDotGBVQ7mfUCg==",
+      "version": "2.2.0",
+      "resolved": "https://registry.npmjs.org/node-libs-browser/-/node-libs-browser-2.2.0.tgz",
+      "integrity": "sha512-5MQunG/oyOaBdttrL40dA7bUfPORLRWMUJLQtMg7nluxUvk5XwnLdL9twQHFAjRx/y7mIMkLKT9++qPbbk6BZA==",
       "dev": true,
       "requires": {
         "assert": "^1.1.1",
@@ -8112,7 +8320,7 @@
         "constants-browserify": "^1.0.0",
         "crypto-browserify": "^3.11.0",
         "domain-browser": "^1.1.1",
-        "events": "^1.0.0",
+        "events": "^3.0.0",
         "https-browserify": "^1.0.0",
         "os-browserify": "^0.3.0",
         "path-browserify": "0.0.0",
@@ -8126,27 +8334,10 @@
         "timers-browserify": "^2.0.4",
         "tty-browserify": "0.0.0",
         "url": "^0.11.0",
-        "util": "^0.10.3",
+        "util": "^0.11.0",
         "vm-browserify": "0.0.4"
       },
       "dependencies": {
-        "buffer": {
-          "version": "4.9.1",
-          "resolved": "https://registry.npmjs.org/buffer/-/buffer-4.9.1.tgz",
-          "integrity": "sha1-bRu2AbB6TvztlwlBMgkwJ8lbwpg=",
-          "dev": true,
-          "requires": {
-            "base64-js": "^1.0.2",
-            "ieee754": "^1.1.4",
-            "isarray": "^1.0.0"
-          }
-        },
-        "path-browserify": {
-          "version": "0.0.0",
-          "resolved": "https://registry.npmjs.org/path-browserify/-/path-browserify-0.0.0.tgz",
-          "integrity": "sha1-oLhwcpquIUAFt9UDLsLLuw+0RRo=",
-          "dev": true
-        },
         "process-nextick-args": {
           "version": "2.0.0",
           "resolved": "https://registry.npmjs.org/process-nextick-args/-/process-nextick-args-2.0.0.tgz",
@@ -8194,82 +8385,21 @@
             "safe-buffer": "~5.1.0"
           }
         },
-        "timers-browserify": {
-          "version": "2.0.10",
-          "resolved": "https://registry.npmjs.org/timers-browserify/-/timers-browserify-2.0.10.tgz",
-          "integrity": "sha512-YvC1SV1XdOUaL6gx5CoGroT3Gu49pK9+TZ38ErPldOWW4j49GI1HKs9DV+KGq/w6y+LZ72W1c8cKz2vzY+qpzg==",
-          "dev": true,
-          "requires": {
-            "setimmediate": "^1.0.4"
-          }
-        },
-        "tty-browserify": {
-          "version": "0.0.0",
-          "resolved": "https://registry.npmjs.org/tty-browserify/-/tty-browserify-0.0.0.tgz",
-          "integrity": "sha1-oVe6QC2iTpv5V/mqadUk7tQpAaY=",
-          "dev": true
-        }
-      }
-    },
-    "node-pre-gyp": {
-      "version": "0.10.3",
-      "resolved": "https://registry.npmjs.org/node-pre-gyp/-/node-pre-gyp-0.10.3.tgz",
-      "integrity": "sha512-d1xFs+C/IPS8Id0qPTZ4bUT8wWryfR/OzzAFxweG+uLN85oPzyo2Iw6bVlLQ/JOdgNonXLCoRyqDzDWq4iw72A==",
-      "dev": true,
-      "optional": true,
-      "requires": {
-        "detect-libc": "^1.0.2",
-        "mkdirp": "^0.5.1",
-        "needle": "^2.2.1",
-        "nopt": "^4.0.1",
-        "npm-packlist": "^1.1.6",
-        "npmlog": "^4.0.2",
-        "rc": "^1.2.7",
-        "rimraf": "^2.6.1",
-        "semver": "^5.3.0",
-        "tar": "^4"
-      },
-      "dependencies": {
-        "nopt": {
-          "version": "4.0.1",
-          "resolved": "https://registry.npmjs.org/nopt/-/nopt-4.0.1.tgz",
-          "integrity": "sha1-0NRoWv1UFRk8jHUFYC0NF81kR00=",
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "abbrev": "1",
-            "osenv": "^0.1.4"
-          }
-        },
-        "tar": {
-          "version": "4.4.8",
-          "resolved": "https://registry.npmjs.org/tar/-/tar-4.4.8.tgz",
-          "integrity": "sha512-LzHF64s5chPQQS0IYBn9IN5h3i98c12bo4NCO7e0sGM2llXQ3p2FGC5sdENN4cTW48O915Sh+x+EXx7XW96xYQ==",
+        "util": {
+          "version": "0.11.1",
+          "resolved": "https://registry.npmjs.org/util/-/util-0.11.1.tgz",
+          "integrity": "sha512-HShAsny+zS2TZfaXxD9tYj4HQGlBezXZMZuM/S5PKLLoZkShZiGk9o5CzukI1LVHZvjdvZ2Sj1aW/Ndn2NB/HQ==",
           "dev": true,
-          "optional": true,
           "requires": {
-            "chownr": "^1.1.1",
-            "fs-minipass": "^1.2.5",
-            "minipass": "^2.3.4",
-            "minizlib": "^1.1.1",
-            "mkdirp": "^0.5.0",
-            "safe-buffer": "^5.1.2",
-            "yallist": "^3.0.2"
+            "inherits": "2.0.3"
           }
-        },
-        "yallist": {
-          "version": "3.0.3",
-          "resolved": "https://registry.npmjs.org/yallist/-/yallist-3.0.3.tgz",
-          "integrity": "sha512-S+Zk8DEWE6oKpV+vI3qWkaK+jSbIK86pCwe2IF/xwIpQ8jEuxpw9NyaGjmp9+BoJv5FV2piqCDcoCtStppiq2A==",
-          "dev": true,
-          "optional": true
         }
       }
     },
     "node-releases": {
-      "version": "1.1.3",
-      "resolved": "https://registry.npmjs.org/node-releases/-/node-releases-1.1.3.tgz",
-      "integrity": "sha512-6VrvH7z6jqqNFY200kdB6HdzkgM96Oaj9v3dqGfgp6mF+cHmU4wyQKZ2/WPDRVoR0Jz9KqbamaBN0ZhdUaysUQ==",
+      "version": "1.1.17",
+      "resolved": "https://registry.npmjs.org/node-releases/-/node-releases-1.1.17.tgz",
+      "integrity": "sha512-/SCjetyta1m7YXLgtACZGDYJdCSIBAWorDWkGCGZlydP2Ll7J48l7j/JxNYZ+xsgSPbWfdulVS/aY+GdjUsQ7Q==",
       "dev": true,
       "requires": {
         "semver": "^5.3.0"
@@ -8373,25 +8503,22 @@
       }
     },
     "normalize-package-data": {
-      "version": "2.4.0",
-      "resolved": "https://registry.npmjs.org/normalize-package-data/-/normalize-package-data-2.4.0.tgz",
-      "integrity": "sha512-9jjUFbTPfEy3R/ad/2oNbKtW9Hgovl5O1FvFWKkKblNXoN/Oou6+9+KKohPK13Yc3/TyunyWhJp6gvRNR/PPAw==",
+      "version": "2.5.0",
+      "resolved": "https://registry.npmjs.org/normalize-package-data/-/normalize-package-data-2.5.0.tgz",
+      "integrity": "sha512-/5CMN3T0R4XTj4DcGaexo+roZSdSFW/0AOOTROrjxzCG1wrWXEsGbRKevjlIL+ZDE4sZlJr5ED4YW0yqmkK+eA==",
       "dev": true,
       "requires": {
         "hosted-git-info": "^2.1.4",
-        "is-builtin-module": "^1.0.0",
+        "resolve": "^1.10.0",
         "semver": "2 || 3 || 4 || 5",
         "validate-npm-package-license": "^3.0.1"
       }
     },
     "normalize-path": {
-      "version": "2.1.1",
-      "resolved": "https://registry.npmjs.org/normalize-path/-/normalize-path-2.1.1.tgz",
-      "integrity": "sha1-GrKLVW4Zg2Oowab35vogE3/mrtk=",
-      "dev": true,
-      "requires": {
-        "remove-trailing-separator": "^1.0.1"
-      }
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/normalize-path/-/normalize-path-3.0.0.tgz",
+      "integrity": "sha512-6eZs5Ls3WtCisHWp9S2GUy8dqkpGi4BVSz3GaqiE6ezub0512ESztXUwUB6C6IKbQkY2Pnb/mD4WYojCRwcwLA==",
+      "dev": true
     },
     "normalize-range": {
       "version": "0.1.2",
@@ -8411,24 +8538,6 @@
         "sort-keys": "^1.0.0"
       }
     },
-    "npm-bundled": {
-      "version": "1.0.5",
-      "resolved": "https://registry.npmjs.org/npm-bundled/-/npm-bundled-1.0.5.tgz",
-      "integrity": "sha512-m/e6jgWu8/v5niCUKQi9qQl8QdeEduFA96xHDDzFGqly0OOjI7c+60KM/2sppfnUU9JJagf+zs+yGhqSOFj71g==",
-      "dev": true,
-      "optional": true
-    },
-    "npm-packlist": {
-      "version": "1.2.0",
-      "resolved": "https://registry.npmjs.org/npm-packlist/-/npm-packlist-1.2.0.tgz",
-      "integrity": "sha512-7Mni4Z8Xkx0/oegoqlcao/JpPCPEMtUvsmB0q7mgvlMinykJLSRTYuFqoQLYgGY8biuxIeiHO+QNJKbCfljewQ==",
-      "dev": true,
-      "optional": true,
-      "requires": {
-        "ignore-walk": "^3.0.1",
-        "npm-bundled": "^1.0.1"
-      }
-    },
     "npm-run-path": {
       "version": "2.0.2",
       "resolved": "https://registry.npmjs.org/npm-run-path/-/npm-run-path-2.0.2.tgz",
@@ -8474,7 +8583,8 @@
     "number-is-nan": {
       "version": "1.0.1",
       "resolved": "https://registry.npmjs.org/number-is-nan/-/number-is-nan-1.0.1.tgz",
-      "integrity": "sha1-CXtgK1NCKlIsGvuHkDGDNpQaAR0="
+      "integrity": "sha1-CXtgK1NCKlIsGvuHkDGDNpQaAR0=",
+      "dev": true
     },
     "nvd3": {
       "version": "1.8.6",
@@ -8536,9 +8646,9 @@
       "dev": true
     },
     "object-keys": {
-      "version": "1.0.12",
-      "resolved": "https://registry.npmjs.org/object-keys/-/object-keys-1.0.12.tgz",
-      "integrity": "sha512-FTMyFUm2wBcGHnH2eXmz7tC6IwlqQZ6mVZ+6dm6vZ4IQIHjs6FdNsQBuKGPuUUUY6NfJw2PshC08Tn6LzLDOag==",
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/object-keys/-/object-keys-1.1.1.tgz",
+      "integrity": "sha512-NuAESUOUMrlIXOfHKzD6bpPu3tYt3xvjNdRIQ+FeT0lNb4K8WR70CaDxhuNguS2XG+GjkyMwOzsN5ZktImfhLA==",
       "dev": true
     },
     "object-path": {
@@ -8624,6 +8734,7 @@
       "version": "1.4.0",
       "resolved": "https://registry.npmjs.org/once/-/once-1.4.0.tgz",
       "integrity": "sha1-WDsap3WWHUsROsF9nFC6753Xa9E=",
+      "dev": true,
       "requires": {
         "wrappy": "1"
       }
@@ -8702,26 +8813,31 @@
     "os-homedir": {
       "version": "1.0.2",
       "resolved": "https://registry.npmjs.org/os-homedir/-/os-homedir-1.0.2.tgz",
-      "integrity": "sha1-/7xJiDNuDoM94MFox+8VISGqf7M="
+      "integrity": "sha1-/7xJiDNuDoM94MFox+8VISGqf7M=",
+      "dev": true
     },
     "os-locale": {
-      "version": "1.4.0",
-      "resolved": "https://registry.npmjs.org/os-locale/-/os-locale-1.4.0.tgz",
-      "integrity": "sha1-IPnxeuKe00XoveWDsT0gCYA8FNk=",
+      "version": "3.1.0",
+      "resolved": "https://registry.npmjs.org/os-locale/-/os-locale-3.1.0.tgz",
+      "integrity": "sha512-Z8l3R4wYWM40/52Z+S265okfFj8Kt2cC2MKY+xNi3kFs+XGI7WXu/I309QQQYbRW4ijiZ+yxs9pqEhJh0DqW3Q==",
       "dev": true,
       "requires": {
-        "lcid": "^1.0.0"
+        "execa": "^1.0.0",
+        "lcid": "^2.0.0",
+        "mem": "^4.0.0"
       }
     },
     "os-tmpdir": {
       "version": "1.0.2",
       "resolved": "https://registry.npmjs.org/os-tmpdir/-/os-tmpdir-1.0.2.tgz",
-      "integrity": "sha1-u+Z0BseaqFxc/sdm/lc0VV36EnQ="
+      "integrity": "sha1-u+Z0BseaqFxc/sdm/lc0VV36EnQ=",
+      "dev": true
     },
     "osenv": {
       "version": "0.1.5",
       "resolved": "https://registry.npmjs.org/osenv/-/osenv-0.1.5.tgz",
       "integrity": "sha512-0CWcCECdMVc2Rw3U5w9ZjqX6ga6ubk1xDVKxtBQPK7wis/0F2r9T6k4ydGYhecl7YUBxBVxhL5oisPsNxAPe2g==",
+      "dev": true,
       "requires": {
         "os-homedir": "^1.0.0",
         "os-tmpdir": "^1.0.0"
@@ -8745,9 +8861,9 @@
       "dev": true
     },
     "p-is-promise": {
-      "version": "1.1.0",
-      "resolved": "https://registry.npmjs.org/p-is-promise/-/p-is-promise-1.1.0.tgz",
-      "integrity": "sha1-nJRWmJ6fZYgBewQ01WCXZ1w9oF4=",
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/p-is-promise/-/p-is-promise-2.1.0.tgz",
+      "integrity": "sha512-Y3W0wlRPK8ZMRbNq97l4M5otioeA5lm1z7bkNkxCka8HSPjR0xRWmpCmc9utiaLP9Jb1eD8BgeIxTW4AIF45Pg==",
       "dev": true
     },
     "p-limit": {
@@ -8838,25 +8954,26 @@
       }
     },
     "parent-module": {
-      "version": "1.0.0",
-      "resolved": "https://registry.npmjs.org/parent-module/-/parent-module-1.0.0.tgz",
-      "integrity": "sha512-8Mf5juOMmiE4FcmzYc4IaiS9L3+9paz2KOiXzkRviCP6aDmN49Hz6EMWz0lGNp9pX80GvvAuLADtyGfW/Em3TA==",
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/parent-module/-/parent-module-1.0.1.tgz",
+      "integrity": "sha512-GQ2EWRpQV8/o+Aw8YqtfZZPfNRWZYkbidE9k5rpl/hC3vtHHBfGm2Ifi6qWV+coDGkrUKZAxE3Lot5kcsRlh+g==",
       "dev": true,
       "requires": {
         "callsites": "^3.0.0"
       }
     },
     "parse-asn1": {
-      "version": "5.1.1",
-      "resolved": "https://registry.npmjs.org/parse-asn1/-/parse-asn1-5.1.1.tgz",
-      "integrity": "sha512-KPx7flKXg775zZpnp9SxJlz00gTd4BmJ2yJufSc44gMCRrRQ7NSzAcSJQfifuOLgW6bEi+ftrALtsgALeB2Adw==",
+      "version": "5.1.4",
+      "resolved": "https://registry.npmjs.org/parse-asn1/-/parse-asn1-5.1.4.tgz",
+      "integrity": "sha512-Qs5duJcuvNExRfFZ99HDD3z4mAi3r9Wl/FOjEOijlxwCZs7E7mW2vjTpgQ4J8LpTF8x5v+1Vn5UQFejmWT11aw==",
       "dev": true,
       "requires": {
         "asn1.js": "^4.0.0",
         "browserify-aes": "^1.0.0",
         "create-hash": "^1.1.0",
         "evp_bytestokey": "^1.0.0",
-        "pbkdf2": "^3.0.3"
+        "pbkdf2": "^3.0.3",
+        "safe-buffer": "^5.1.1"
       }
     },
     "parse-json": {
@@ -8885,9 +9002,9 @@
       }
     },
     "parseurl": {
-      "version": "1.3.2",
-      "resolved": "https://registry.npmjs.org/parseurl/-/parseurl-1.3.2.tgz",
-      "integrity": "sha1-/CidTtiZMRlGDBViUyYs3I3mW/M=",
+      "version": "1.3.3",
+      "resolved": "https://registry.npmjs.org/parseurl/-/parseurl-1.3.3.tgz",
+      "integrity": "sha512-CiyeOxFT/JZyN5m0z9PfXw4SCBJ6Sygz1Dpl0wqjlhDEGGBP1GnsUVEL0p63hoG1fcj3fHynXi9NYO4nWOL+qQ==",
       "dev": true
     },
     "pascalcase": {
@@ -8896,6 +9013,12 @@
       "integrity": "sha1-s2PlXoAGym/iF4TS2yK9FdeRfxQ=",
       "dev": true
     },
+    "path-browserify": {
+      "version": "0.0.0",
+      "resolved": "https://registry.npmjs.org/path-browserify/-/path-browserify-0.0.0.tgz",
+      "integrity": "sha1-oLhwcpquIUAFt9UDLsLLuw+0RRo=",
+      "dev": true
+    },
     "path-dirname": {
       "version": "1.0.2",
       "resolved": "https://registry.npmjs.org/path-dirname/-/path-dirname-1.0.2.tgz",
@@ -8911,7 +9034,8 @@
     "path-is-absolute": {
       "version": "1.0.1",
       "resolved": "https://registry.npmjs.org/path-is-absolute/-/path-is-absolute-1.0.1.tgz",
-      "integrity": "sha1-F0uSaHNVNP+8es5r9TpanhtcX18="
+      "integrity": "sha1-F0uSaHNVNP+8es5r9TpanhtcX18=",
+      "dev": true
     },
     "path-is-inside": {
       "version": "1.0.2",
@@ -9019,9 +9143,9 @@
       "dev": true
     },
     "popper.js": {
-      "version": "1.14.7",
-      "resolved": "https://registry.npmjs.org/popper.js/-/popper.js-1.14.7.tgz",
-      "integrity": "sha512-4q1hNvoUre/8srWsH7hnoSJ5xVmIL4qgz+s4qf2TnJIMyZFUFMGH+9vE7mXynAlHSZ/NdTmmow86muD0myUkVQ=="
+      "version": "1.15.0",
+      "resolved": "https://registry.npmjs.org/popper.js/-/popper.js-1.15.0.tgz",
+      "integrity": "sha512-w010cY1oCUmI+9KwwlWki+r5jxKfTFDVoadl7MSrIujHU5MJ5OR6HTDj6Xo8aoR/QsA56x8jKjA59qGH4ELtrA=="
     },
     "portfinder": {
       "version": "1.0.20",
@@ -9517,40 +9641,90 @@
       }
     },
     "postcss-prefix-selector": {
-      "version": "1.6.0",
-      "resolved": "https://registry.npmjs.org/postcss-prefix-selector/-/postcss-prefix-selector-1.6.0.tgz",
-      "integrity": "sha1-tJWUnWOcYxRxRWSDJoUyFvPBCQA=",
-      "dev": true,
-      "requires": {
-        "postcss": "^5.0.8"
-      }
-    },
-    "postcss-reduce-idents": {
-      "version": "2.4.0",
-      "resolved": "https://registry.npmjs.org/postcss-reduce-idents/-/postcss-reduce-idents-2.4.0.tgz",
-      "integrity": "sha1-wsbSDMlYKE9qv75j92Cb9AkFmtM=",
-      "dev": true,
-      "requires": {
-        "postcss": "^5.0.4",
-        "postcss-value-parser": "^3.0.2"
-      }
-    },
-    "postcss-reduce-initial": {
-      "version": "1.0.1",
-      "resolved": "https://registry.npmjs.org/postcss-reduce-initial/-/postcss-reduce-initial-1.0.1.tgz",
-      "integrity": "sha1-aPgGlfBF0IJjqHmtJA343WT2ROo=",
-      "dev": true,
-      "requires": {
-        "postcss": "^5.0.4"
-      }
-    },
-    "postcss-reduce-transforms": {
-      "version": "1.0.4",
-      "resolved": "https://registry.npmjs.org/postcss-reduce-transforms/-/postcss-reduce-transforms-1.0.4.tgz",
-      "integrity": "sha1-/3b02CEkN7McKYpC0uFEQCV3GuE=",
+      "version": "1.7.1",
+      "resolved": "https://registry.npmjs.org/postcss-prefix-selector/-/postcss-prefix-selector-1.7.1.tgz",
+      "integrity": "sha512-eNgr0xRk2IUPWpPkzfLL/Dlrewo4vd4vYpDj92/TEPNsLKTArAL/Y9VWFpJzrK8iPEpekPA06Ux97v8ByZ9QCQ==",
       "dev": true,
       "requires": {
-        "has": "^1.0.1",
+        "postcss": "^7.0.0"
+      },
+      "dependencies": {
+        "chalk": {
+          "version": "2.4.2",
+          "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.4.2.tgz",
+          "integrity": "sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==",
+          "dev": true,
+          "requires": {
+            "ansi-styles": "^3.2.1",
+            "escape-string-regexp": "^1.0.5",
+            "supports-color": "^5.3.0"
+          },
+          "dependencies": {
+            "supports-color": {
+              "version": "5.5.0",
+              "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-5.5.0.tgz",
+              "integrity": "sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==",
+              "dev": true,
+              "requires": {
+                "has-flag": "^3.0.0"
+              }
+            }
+          }
+        },
+        "postcss": {
+          "version": "7.0.14",
+          "resolved": "https://registry.npmjs.org/postcss/-/postcss-7.0.14.tgz",
+          "integrity": "sha512-NsbD6XUUMZvBxtQAJuWDJeeC4QFsmWsfozWxCJPWf3M55K9iu2iMDaKqyoOdTJ1R4usBXuxlVFAIo8rZPQD4Bg==",
+          "dev": true,
+          "requires": {
+            "chalk": "^2.4.2",
+            "source-map": "^0.6.1",
+            "supports-color": "^6.1.0"
+          }
+        },
+        "source-map": {
+          "version": "0.6.1",
+          "resolved": "https://registry.npmjs.org/source-map/-/source-map-0.6.1.tgz",
+          "integrity": "sha512-UjgapumWlbMhkBgzT7Ykc5YXUT46F0iKu8SGXq0bcwP5dz/h0Plj6enJqjz1Zbq2l5WaqYnrVbwWOWMyF3F47g==",
+          "dev": true
+        },
+        "supports-color": {
+          "version": "6.1.0",
+          "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-6.1.0.tgz",
+          "integrity": "sha512-qe1jfm1Mg7Nq/NSh6XE24gPXROEVsWHxC1LIx//XNlD9iw7YZQGjZNjYN7xGaEG6iKdA8EtNFW6R0gjnVXp+wQ==",
+          "dev": true,
+          "requires": {
+            "has-flag": "^3.0.0"
+          }
+        }
+      }
+    },
+    "postcss-reduce-idents": {
+      "version": "2.4.0",
+      "resolved": "https://registry.npmjs.org/postcss-reduce-idents/-/postcss-reduce-idents-2.4.0.tgz",
+      "integrity": "sha1-wsbSDMlYKE9qv75j92Cb9AkFmtM=",
+      "dev": true,
+      "requires": {
+        "postcss": "^5.0.4",
+        "postcss-value-parser": "^3.0.2"
+      }
+    },
+    "postcss-reduce-initial": {
+      "version": "1.0.1",
+      "resolved": "https://registry.npmjs.org/postcss-reduce-initial/-/postcss-reduce-initial-1.0.1.tgz",
+      "integrity": "sha1-aPgGlfBF0IJjqHmtJA343WT2ROo=",
+      "dev": true,
+      "requires": {
+        "postcss": "^5.0.4"
+      }
+    },
+    "postcss-reduce-transforms": {
+      "version": "1.0.4",
+      "resolved": "https://registry.npmjs.org/postcss-reduce-transforms/-/postcss-reduce-transforms-1.0.4.tgz",
+      "integrity": "sha1-/3b02CEkN7McKYpC0uFEQCV3GuE=",
+      "dev": true,
+      "requires": {
+        "has": "^1.0.1",
         "postcss": "^5.0.8",
         "postcss-value-parser": "^3.0.1"
       }
@@ -9826,13 +10000,13 @@
       "dev": true
     },
     "proxy-addr": {
-      "version": "2.0.4",
-      "resolved": "https://registry.npmjs.org/proxy-addr/-/proxy-addr-2.0.4.tgz",
-      "integrity": "sha512-5erio2h9jp5CHGwcybmxmVqHmnCBZeewlfJ0pex+UW7Qny7OOZXTtH56TGNyBizkgiOwhJtMKrVzDTeKcySZwA==",
+      "version": "2.0.5",
+      "resolved": "https://registry.npmjs.org/proxy-addr/-/proxy-addr-2.0.5.tgz",
+      "integrity": "sha512-t/7RxHXPH6cJtP0pRG6smSr9QJidhB+3kXu0KgXnbGYMgzEnUxRQ4/LDdfOwZEMyIh3/xHb8PX3t+lfL9z+YVQ==",
       "dev": true,
       "requires": {
         "forwarded": "~0.1.2",
-        "ipaddr.js": "1.8.0"
+        "ipaddr.js": "1.9.0"
       }
     },
     "prr": {
@@ -10122,9 +10296,9 @@
       "dev": true
     },
     "qs": {
-      "version": "6.5.2",
-      "resolved": "https://registry.npmjs.org/qs/-/qs-6.5.2.tgz",
-      "integrity": "sha512-N5ZAX4/LxJmF+7wN74pUD6qAh9/wnvdQcjq9TZjevvXzSUo7bfmw91saqMjzGS2xq91/odN2dW/WOl7qQHNDGA==",
+      "version": "6.7.0",
+      "resolved": "https://registry.npmjs.org/qs/-/qs-6.7.0.tgz",
+      "integrity": "sha512-VCdBRNFTX1fyE7Nb6FYoURo/SPe62QCaAyzJvUjwRaIsc+NePBEniHlvxFmmX56+HZphIGtV0XeCirBtpDrTyQ==",
       "dev": true
     },
     "query-string": {
@@ -10156,9 +10330,9 @@
       "dev": true
     },
     "randombytes": {
-      "version": "2.0.6",
-      "resolved": "https://registry.npmjs.org/randombytes/-/randombytes-2.0.6.tgz",
-      "integrity": "sha512-CIQ5OFxf4Jou6uOKe9t1AOgqpeU5fd70A8NPdHSGeYXqXsPe6peOwI0cUl88RWZ6sP1vPMV3avd/R6cZ5/sP1A==",
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/randombytes/-/randombytes-2.1.0.tgz",
+      "integrity": "sha512-vYl3iOX+4CKUWuxGi9Ukhie6fsqXqS9FE2Zaic4tNFD2N2QQaXOMFbuKK4QmDHC0JO6B1Zp41J0LpT0oR68amQ==",
       "dev": true,
       "requires": {
         "safe-buffer": "^5.1.0"
@@ -10181,39 +10355,15 @@
       "dev": true
     },
     "raw-body": {
-      "version": "2.3.3",
-      "resolved": "https://registry.npmjs.org/raw-body/-/raw-body-2.3.3.tgz",
-      "integrity": "sha512-9esiElv1BrZoI3rCDuOuKCBRbuApGGaDPQfjSflGxdy4oyzqghxu6klEkkVIvBje+FF0BX9coEv8KqW6X/7njw==",
+      "version": "2.4.0",
+      "resolved": "https://registry.npmjs.org/raw-body/-/raw-body-2.4.0.tgz",
+      "integrity": "sha512-4Oz8DUIwdvoa5qMJelxipzi/iJIi40O5cGV1wNYp5hvZP8ZN0T+jiNkL0QepXs+EsQ9XJ8ipEDoiH70ySUJP3Q==",
       "dev": true,
       "requires": {
-        "bytes": "3.0.0",
-        "http-errors": "1.6.3",
-        "iconv-lite": "0.4.23",
+        "bytes": "3.1.0",
+        "http-errors": "1.7.2",
+        "iconv-lite": "0.4.24",
         "unpipe": "1.0.0"
-      },
-      "dependencies": {
-        "iconv-lite": {
-          "version": "0.4.23",
-          "resolved": "https://registry.npmjs.org/iconv-lite/-/iconv-lite-0.4.23.tgz",
-          "integrity": "sha512-neyTUVFtahjf0mB3dZT77u+8O0QB89jFdnBkd5P1JgYPbPaia3gXXOVL2fq8VyU2gMMD7SaN7QukTB/pmXYvDA==",
-          "dev": true,
-          "requires": {
-            "safer-buffer": ">= 2.1.2 < 3"
-          }
-        }
-      }
-    },
-    "rc": {
-      "version": "1.2.8",
-      "resolved": "https://registry.npmjs.org/rc/-/rc-1.2.8.tgz",
-      "integrity": "sha512-y3bGgqKj3QBdxLbLkomlohkvsA8gdAiUQlSBJnBhfn+BPxg4bc62d8TcBW15wavDfgexCgccckhcZvywyQYPOw==",
-      "dev": true,
-      "optional": true,
-      "requires": {
-        "deep-extend": "^0.6.0",
-        "ini": "~1.3.0",
-        "minimist": "^1.2.0",
-        "strip-json-comments": "~2.0.1"
       }
     },
     "read-pkg": {
@@ -10354,9 +10504,9 @@
       "dev": true
     },
     "regenerate-unicode-properties": {
-      "version": "7.0.0",
-      "resolved": "https://registry.npmjs.org/regenerate-unicode-properties/-/regenerate-unicode-properties-7.0.0.tgz",
-      "integrity": "sha512-s5NGghCE4itSlUS+0WUj88G6cfMVMmH8boTPNvABf8od+2dhT9WDlWu8n01raQAJZMOK8Ch6jSexaRO7swd6aw==",
+      "version": "8.0.2",
+      "resolved": "https://registry.npmjs.org/regenerate-unicode-properties/-/regenerate-unicode-properties-8.0.2.tgz",
+      "integrity": "sha512-SbA/iNrBUf6Pv2zU8Ekv1Qbhv92yxL4hiDa2siuxs4KKn4oOoMDHXjAf7+Nz9qinUQ46B1LcWEi/PhJfPWpZWQ==",
       "dev": true,
       "requires": {
         "regenerate": "^1.4.0"
@@ -10369,9 +10519,9 @@
       "dev": true
     },
     "regenerator-transform": {
-      "version": "0.13.3",
-      "resolved": "https://registry.npmjs.org/regenerator-transform/-/regenerator-transform-0.13.3.tgz",
-      "integrity": "sha512-5ipTrZFSq5vU2YoGoww4uaRVAK4wyYC4TSICibbfEPOruUu8FFP7ErV0BjmbIOEpn3O/k9na9UEdYR/3m7N6uA==",
+      "version": "0.13.4",
+      "resolved": "https://registry.npmjs.org/regenerator-transform/-/regenerator-transform-0.13.4.tgz",
+      "integrity": "sha512-T0QMBjK3J0MtxjPmdIMXm72Wvj2Abb0Bd4HADdfijwMdoIsyQZ6fWC7kDFhk2YinBBEMZDL7Y7wh0J1sGx3S4A==",
       "dev": true,
       "requires": {
         "private": "^0.1.6"
@@ -10400,17 +10550,17 @@
       "dev": true
     },
     "regexpu-core": {
-      "version": "4.4.0",
-      "resolved": "https://registry.npmjs.org/regexpu-core/-/regexpu-core-4.4.0.tgz",
-      "integrity": "sha512-eDDWElbwwI3K0Lo6CqbQbA6FwgtCz4kYTarrri1okfkRLZAqstU+B3voZBCjg8Fl6iq0gXrJG6MvRgLthfvgOA==",
+      "version": "4.5.4",
+      "resolved": "https://registry.npmjs.org/regexpu-core/-/regexpu-core-4.5.4.tgz",
+      "integrity": "sha512-BtizvGtFQKGPUcTy56o3nk1bGRp4SZOTYrDtGNlqCQufptV5IkkLN6Emw+yunAJjzf+C9FQFtvq7IoA3+oMYHQ==",
       "dev": true,
       "requires": {
         "regenerate": "^1.4.0",
-        "regenerate-unicode-properties": "^7.0.0",
+        "regenerate-unicode-properties": "^8.0.2",
         "regjsgen": "^0.5.0",
         "regjsparser": "^0.6.0",
         "unicode-match-property-ecmascript": "^1.0.4",
-        "unicode-match-property-value-ecmascript": "^1.0.2"
+        "unicode-match-property-value-ecmascript": "^1.1.0"
       }
     },
     "regjsgen": {
@@ -10449,14 +10599,14 @@
       "dev": true
     },
     "renderkid": {
-      "version": "2.0.2",
-      "resolved": "https://registry.npmjs.org/renderkid/-/renderkid-2.0.2.tgz",
-      "integrity": "sha512-FsygIxevi1jSiPY9h7vZmBFUbAOcbYm9UwyiLNdVsLRs/5We9Ob5NMPbGYUTWiLq5L+ezlVdE0A8bbME5CWTpg==",
+      "version": "2.0.3",
+      "resolved": "https://registry.npmjs.org/renderkid/-/renderkid-2.0.3.tgz",
+      "integrity": "sha512-z8CLQp7EZBPCwCnncgf9C4XAi3WR0dv+uWu/PjIyhhAb5d6IJ/QZqlHFprHeKT+59//V6BNUsLbvN8+2LarxGA==",
       "dev": true,
       "requires": {
         "css-select": "^1.1.0",
-        "dom-converter": "~0.2",
-        "htmlparser2": "~3.3.0",
+        "dom-converter": "^0.2",
+        "htmlparser2": "^3.3.0",
         "strip-ansi": "^3.0.0",
         "utila": "^0.4.0"
       },
@@ -10479,15 +10629,6 @@
             "nth-check": "~1.0.1"
           }
         },
-        "domhandler": {
-          "version": "2.1.0",
-          "resolved": "https://registry.npmjs.org/domhandler/-/domhandler-2.1.0.tgz",
-          "integrity": "sha1-0mRvXlf2w7qxHPbLBdPArPdBJZQ=",
-          "dev": true,
-          "requires": {
-            "domelementtype": "1"
-          }
-        },
         "domutils": {
           "version": "1.5.1",
           "resolved": "https://registry.npmjs.org/domutils/-/domutils-1.5.1.tgz",
@@ -10498,47 +10639,6 @@
             "domelementtype": "1"
           }
         },
-        "htmlparser2": {
-          "version": "3.3.0",
-          "resolved": "https://registry.npmjs.org/htmlparser2/-/htmlparser2-3.3.0.tgz",
-          "integrity": "sha1-zHDQWln2VC5D8OaFyYLhTJJKnv4=",
-          "dev": true,
-          "requires": {
-            "domelementtype": "1",
-            "domhandler": "2.1",
-            "domutils": "1.1",
-            "readable-stream": "1.0"
-          },
-          "dependencies": {
-            "domutils": {
-              "version": "1.1.6",
-              "resolved": "https://registry.npmjs.org/domutils/-/domutils-1.1.6.tgz",
-              "integrity": "sha1-vdw94Jm5ou+sxRxiPyj0FuzFdIU=",
-              "dev": true,
-              "requires": {
-                "domelementtype": "1"
-              }
-            }
-          }
-        },
-        "isarray": {
-          "version": "0.0.1",
-          "resolved": "https://registry.npmjs.org/isarray/-/isarray-0.0.1.tgz",
-          "integrity": "sha1-ihis/Kmo9Bd+Cav8YDiTmwXR7t8=",
-          "dev": true
-        },
-        "readable-stream": {
-          "version": "1.0.34",
-          "resolved": "https://registry.npmjs.org/readable-stream/-/readable-stream-1.0.34.tgz",
-          "integrity": "sha1-Elgg40vIQtLyqq+v5MKRbuMsFXw=",
-          "dev": true,
-          "requires": {
-            "core-util-is": "~1.0.0",
-            "inherits": "~2.0.1",
-            "isarray": "0.0.1",
-            "string_decoder": "~0.10.x"
-          }
-        },
         "strip-ansi": {
           "version": "3.0.1",
           "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-3.0.1.tgz",
@@ -10597,6 +10697,14 @@
         "tough-cookie": "~2.4.3",
         "tunnel-agent": "^0.6.0",
         "uuid": "^3.3.2"
+      },
+      "dependencies": {
+        "qs": {
+          "version": "6.5.2",
+          "resolved": "https://registry.npmjs.org/qs/-/qs-6.5.2.tgz",
+          "integrity": "sha512-N5ZAX4/LxJmF+7wN74pUD6qAh9/wnvdQcjq9TZjevvXzSUo7bfmw91saqMjzGS2xq91/odN2dW/WOl7qQHNDGA==",
+          "dev": true
+        }
       }
     },
     "require-directory": {
@@ -10606,9 +10714,9 @@
       "dev": true
     },
     "require-main-filename": {
-      "version": "1.0.1",
-      "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-1.0.1.tgz",
-      "integrity": "sha1-l/cXtp1IeE9fUmpsWqj/3aBVpNE=",
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-2.0.0.tgz",
+      "integrity": "sha512-NKN5kMDylKuldxYLSUfrbo5Tuzh4hd+2E8NPPX02mZtn1VuREQToYe/ZdlJy+J3uCpfaiGF05e7B8W0iXbQHmg==",
       "dev": true
     },
     "requireindex": {
@@ -10629,9 +10737,9 @@
       "integrity": "sha512-M2AelyJDVR/oLnToJLtuDJRBBWUGUvvGigj1411hXhAdyFWqMaqHp7TixW3FpiLuVaikIcR1QL+zqoJoZlOgpg=="
     },
     "resolve": {
-      "version": "1.9.0",
-      "resolved": "https://registry.npmjs.org/resolve/-/resolve-1.9.0.tgz",
-      "integrity": "sha512-TZNye00tI67lwYvzxCxHGjwTNlUV70io54/Ed4j6PscB8xVfuBJpRenI/o6dVk0cY0PYTY27AgCoGGxRnYuItQ==",
+      "version": "1.10.1",
+      "resolved": "https://registry.npmjs.org/resolve/-/resolve-1.10.1.tgz",
+      "integrity": "sha512-KuIe4mf++td/eFb6wkaPbMDnP6kObCaEtIDuHOUED6MNUo4K670KZUHuuvYPZDxNF0WVLw49n06M2m2dXphEzA==",
       "dev": true,
       "requires": {
         "path-parse": "^1.0.6"
@@ -10862,6 +10970,29 @@
           "integrity": "sha1-MvxLn82vhF/N9+c7uXysImHwqwo=",
           "dev": true
         },
+        "cliui": {
+          "version": "3.2.0",
+          "resolved": "https://registry.npmjs.org/cliui/-/cliui-3.2.0.tgz",
+          "integrity": "sha1-EgYBU3qRbSmUD5NNo7SNWFo5IT0=",
+          "dev": true,
+          "requires": {
+            "string-width": "^1.0.1",
+            "strip-ansi": "^3.0.1",
+            "wrap-ansi": "^2.0.0"
+          }
+        },
+        "get-caller-file": {
+          "version": "1.0.3",
+          "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-1.0.3.tgz",
+          "integrity": "sha512-3t6rVToeoZfYSGd8YoLFR2DJkiQrIiUrGcjvFX2mDw3bn6k2OtwHN0TNCLbBO+w8qTvimhDkv+LSscbJY1vE6w==",
+          "dev": true
+        },
+        "invert-kv": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-1.0.0.tgz",
+          "integrity": "sha1-EEqOSqym09jNFXqO+L+rLXo//bY=",
+          "dev": true
+        },
         "is-fullwidth-code-point": {
           "version": "1.0.0",
           "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-1.0.0.tgz",
@@ -10871,6 +11002,30 @@
             "number-is-nan": "^1.0.0"
           }
         },
+        "lcid": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/lcid/-/lcid-1.0.0.tgz",
+          "integrity": "sha1-MIrMr6C8SDo4Z7S28rlQYlHRuDU=",
+          "dev": true,
+          "requires": {
+            "invert-kv": "^1.0.0"
+          }
+        },
+        "os-locale": {
+          "version": "1.4.0",
+          "resolved": "https://registry.npmjs.org/os-locale/-/os-locale-1.4.0.tgz",
+          "integrity": "sha1-IPnxeuKe00XoveWDsT0gCYA8FNk=",
+          "dev": true,
+          "requires": {
+            "lcid": "^1.0.0"
+          }
+        },
+        "require-main-filename": {
+          "version": "1.0.1",
+          "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-1.0.1.tgz",
+          "integrity": "sha1-l/cXtp1IeE9fUmpsWqj/3aBVpNE=",
+          "dev": true
+        },
         "string-width": {
           "version": "1.0.2",
           "resolved": "https://registry.npmjs.org/string-width/-/string-width-1.0.2.tgz",
@@ -10891,6 +11046,12 @@
             "ansi-regex": "^2.0.0"
           }
         },
+        "which-module": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/which-module/-/which-module-1.0.0.tgz",
+          "integrity": "sha1-u6Y8qGGUiZT/MHc2CJ47lgJsKk8=",
+          "dev": true
+        },
         "y18n": {
           "version": "3.2.1",
           "resolved": "https://registry.npmjs.org/y18n/-/y18n-3.2.1.tgz",
@@ -10917,6 +11078,15 @@
             "y18n": "^3.2.1",
             "yargs-parser": "^5.0.0"
           }
+        },
+        "yargs-parser": {
+          "version": "5.0.0",
+          "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-5.0.0.tgz",
+          "integrity": "sha1-J17PDX/+Bcd+ZOfIbkzZS/DhIoo=",
+          "dev": true,
+          "requires": {
+            "camelcase": "^3.0.0"
+          }
         }
       }
     },
@@ -10947,32 +11117,6 @@
       "requires": {
         "ajv": "^6.1.0",
         "ajv-keywords": "^3.1.0"
-      },
-      "dependencies": {
-        "ajv": {
-          "version": "6.6.2",
-          "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.6.2.tgz",
-          "integrity": "sha512-FBHEW6Jf5TB9MGBgUUA9XHkTbjXYfAUjY43ACMfmdMRHniyoMHjHjzD50OK8LGDWQwp4rWEsIq5kEqq7rvIM1g==",
-          "dev": true,
-          "requires": {
-            "fast-deep-equal": "^2.0.1",
-            "fast-json-stable-stringify": "^2.0.0",
-            "json-schema-traverse": "^0.4.1",
-            "uri-js": "^4.2.2"
-          }
-        },
-        "fast-deep-equal": {
-          "version": "2.0.1",
-          "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-2.0.1.tgz",
-          "integrity": "sha1-ewUhjd+WZ79/Nwv3/bLLFf3Qqkk=",
-          "dev": true
-        },
-        "json-schema-traverse": {
-          "version": "0.4.1",
-          "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.4.1.tgz",
-          "integrity": "sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==",
-          "dev": true
-        }
       }
     },
     "scss-tokenizer": {
@@ -11012,9 +11156,9 @@
       }
     },
     "semver": {
-      "version": "5.6.0",
-      "resolved": "https://registry.npmjs.org/semver/-/semver-5.6.0.tgz",
-      "integrity": "sha512-RS9R6R35NYgQn++fkDWaOmqGoj4Ek9gGs+DPxNUZKuwE183xjJroKvyo1IzVFeXvUrvmALy6FWD5xrdJT25gMg==",
+      "version": "5.7.0",
+      "resolved": "https://registry.npmjs.org/semver/-/semver-5.7.0.tgz",
+      "integrity": "sha512-Ya52jSX2u7QKghxeoFGpLwCtGlt7j0oY9DYb5apt9nPlJ42ID+ulTXESnt/qAQcoSERyZ5sl3LDIOw0nAn/5DA==",
       "dev": true
     },
     "send": {
@@ -11047,6 +11191,18 @@
             "ms": "2.0.0"
           }
         },
+        "http-errors": {
+          "version": "1.6.3",
+          "resolved": "https://registry.npmjs.org/http-errors/-/http-errors-1.6.3.tgz",
+          "integrity": "sha1-i1VoC7S+KDoLW/TqLjhYC+HZMg0=",
+          "dev": true,
+          "requires": {
+            "depd": "~1.1.2",
+            "inherits": "2.0.3",
+            "setprototypeof": "1.1.0",
+            "statuses": ">= 1.4.0 < 2"
+          }
+        },
         "mime": {
           "version": "1.4.1",
           "resolved": "https://registry.npmjs.org/mime/-/mime-1.4.1.tgz",
@@ -11059,6 +11215,12 @@
           "integrity": "sha1-VgiurfwAvmwpAd9fmGF4jeDVl8g=",
           "dev": true
         },
+        "setprototypeof": {
+          "version": "1.1.0",
+          "resolved": "https://registry.npmjs.org/setprototypeof/-/setprototypeof-1.1.0.tgz",
+          "integrity": "sha512-BvE/TwpZX4FXExxOxZyRGQQv651MSwmWKZGqvmPcRIjDqWub67kTKuIMx43cZZrS/cBBzwBcNDWoFxt2XEFIpQ==",
+          "dev": true
+        },
         "statuses": {
           "version": "1.4.0",
           "resolved": "https://registry.npmjs.org/statuses/-/statuses-1.4.0.tgz",
@@ -11068,9 +11230,9 @@
       }
     },
     "serialize-javascript": {
-      "version": "1.6.1",
-      "resolved": "https://registry.npmjs.org/serialize-javascript/-/serialize-javascript-1.6.1.tgz",
-      "integrity": "sha512-A5MOagrPFga4YaKQSWHryl7AXvbQkEqpw4NNYMTNYUNV51bA8ABHgYFpqKx+YFFrw59xMV1qGH1R4AgoNIVgCw==",
+      "version": "1.7.0",
+      "resolved": "https://registry.npmjs.org/serialize-javascript/-/serialize-javascript-1.7.0.tgz",
+      "integrity": "sha512-ke8UG8ulpFOxO8f8gRYabHQe/ZntKlcig2Mp+8+URDP1D8vJZ0KUt7LYo07q25Z/+JVSgpr/cui9PIp5H6/+nA==",
       "dev": true
     },
     "serve-index": {
@@ -11097,11 +11259,29 @@
             "ms": "2.0.0"
           }
         },
+        "http-errors": {
+          "version": "1.6.3",
+          "resolved": "https://registry.npmjs.org/http-errors/-/http-errors-1.6.3.tgz",
+          "integrity": "sha1-i1VoC7S+KDoLW/TqLjhYC+HZMg0=",
+          "dev": true,
+          "requires": {
+            "depd": "~1.1.2",
+            "inherits": "2.0.3",
+            "setprototypeof": "1.1.0",
+            "statuses": ">= 1.4.0 < 2"
+          }
+        },
         "ms": {
           "version": "2.0.0",
           "resolved": "https://registry.npmjs.org/ms/-/ms-2.0.0.tgz",
           "integrity": "sha1-VgiurfwAvmwpAd9fmGF4jeDVl8g=",
           "dev": true
+        },
+        "setprototypeof": {
+          "version": "1.1.0",
+          "resolved": "https://registry.npmjs.org/setprototypeof/-/setprototypeof-1.1.0.tgz",
+          "integrity": "sha512-BvE/TwpZX4FXExxOxZyRGQQv651MSwmWKZGqvmPcRIjDqWub67kTKuIMx43cZZrS/cBBzwBcNDWoFxt2XEFIpQ==",
+          "dev": true
         }
       }
     },
@@ -11153,9 +11333,9 @@
       "dev": true
     },
     "setprototypeof": {
-      "version": "1.1.0",
-      "resolved": "https://registry.npmjs.org/setprototypeof/-/setprototypeof-1.1.0.tgz",
-      "integrity": "sha512-BvE/TwpZX4FXExxOxZyRGQQv651MSwmWKZGqvmPcRIjDqWub67kTKuIMx43cZZrS/cBBzwBcNDWoFxt2XEFIpQ==",
+      "version": "1.1.1",
+      "resolved": "https://registry.npmjs.org/setprototypeof/-/setprototypeof-1.1.1.tgz",
+      "integrity": "sha512-JvdAWfbXeIGaZ9cILp38HntZSFSo3mWg6xGcJJsd+d4aRMOqauag1C63dJfDw7OaMYwEbHMOxEZ1lqVRYP2OAw==",
       "dev": true
     },
     "sha.js": {
@@ -11544,9 +11724,9 @@
       }
     },
     "source-map-support": {
-      "version": "0.5.9",
-      "resolved": "https://registry.npmjs.org/source-map-support/-/source-map-support-0.5.9.tgz",
-      "integrity": "sha512-gR6Rw4MvUlYy83vP0vxoVNzM6t8MUXqNuRsuBmBHQDu1Fh6X015FrLdgoDKcNdkwGubozq0P4N0Q37UyFVr1EA==",
+      "version": "0.5.12",
+      "resolved": "https://registry.npmjs.org/source-map-support/-/source-map-support-0.5.12.tgz",
+      "integrity": "sha512-4h2Pbvyy15EE02G+JOZpUCmqWJuqrs+sEkzewTm++BPi7Hvn/HwcqLAcNxYAyI0x13CpPPn+kMjl+hplXMHITQ==",
       "dev": true,
       "requires": {
         "buffer-from": "^1.0.0",
@@ -11594,9 +11774,9 @@
       }
     },
     "spdx-license-ids": {
-      "version": "3.0.3",
-      "resolved": "https://registry.npmjs.org/spdx-license-ids/-/spdx-license-ids-3.0.3.tgz",
-      "integrity": "sha512-uBIcIl3Ih6Phe3XHK1NqboJLdGfwr1UN3k6wSD1dZpmPsIkb8AGNbZYJ1fOBk834+Gxy8rpfDxrS6XLEMZMY2g==",
+      "version": "3.0.4",
+      "resolved": "https://registry.npmjs.org/spdx-license-ids/-/spdx-license-ids-3.0.4.tgz",
+      "integrity": "sha512-7j8LYJLeY/Yb6ACbQ7F76qy5jHkp0U6jgBfJsk97bwWlVUnUWsAgpyaCvo17h0/RQGnQ036tVDomiwoI4pDkQA==",
       "dev": true
     },
     "spdy": {
@@ -11664,9 +11844,9 @@
       "dev": true
     },
     "sshpk": {
-      "version": "1.16.0",
-      "resolved": "https://registry.npmjs.org/sshpk/-/sshpk-1.16.0.tgz",
-      "integrity": "sha512-Zhev35/y7hRMcID/upReIvRse+I9SVhyVre/KTJSJQWMz3C3+G+HpO7m1wK/yckEtujKZ7dS4hkVxAnmHaIGVQ==",
+      "version": "1.16.1",
+      "resolved": "https://registry.npmjs.org/sshpk/-/sshpk-1.16.1.tgz",
+      "integrity": "sha512-HXXqVUq7+pcKeLqqZj6mHFUMvXtOJt1uoUx09pFW6011inTMxqI8BA8PM95myrIyyKwdnzjdFjLiE6KBPVtJIg==",
       "dev": true,
       "requires": {
         "asn1": "~0.2.3",
@@ -11732,9 +11912,9 @@
       }
     },
     "stream-browserify": {
-      "version": "2.0.1",
-      "resolved": "https://registry.npmjs.org/stream-browserify/-/stream-browserify-2.0.1.tgz",
-      "integrity": "sha1-ZiZu5fm9uZQKTkUUyvtDu3Hlyds=",
+      "version": "2.0.2",
+      "resolved": "https://registry.npmjs.org/stream-browserify/-/stream-browserify-2.0.2.tgz",
+      "integrity": "sha512-nX6hmklHs/gr2FuxYDltq8fJA1GDlxKQCz8O/IM4atRqBH8OORmBNgfvW5gG10GT/qQ9u0CzIvr2X5Pkt6ntqg==",
       "dev": true,
       "requires": {
         "inherits": "~2.0.1",
@@ -11912,6 +12092,30 @@
         "schema-utils": "^0.3.0"
       },
       "dependencies": {
+        "ajv": {
+          "version": "5.5.2",
+          "resolved": "https://registry.npmjs.org/ajv/-/ajv-5.5.2.tgz",
+          "integrity": "sha1-c7Xuyj+rZT49P5Qis0GtQiBdyWU=",
+          "dev": true,
+          "requires": {
+            "co": "^4.6.0",
+            "fast-deep-equal": "^1.0.0",
+            "fast-json-stable-stringify": "^2.0.0",
+            "json-schema-traverse": "^0.3.0"
+          }
+        },
+        "fast-deep-equal": {
+          "version": "1.1.0",
+          "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-1.1.0.tgz",
+          "integrity": "sha1-wFNHeBfIa1HaqFPIHgWbcz0CNhQ=",
+          "dev": true
+        },
+        "json-schema-traverse": {
+          "version": "0.3.1",
+          "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.3.1.tgz",
+          "integrity": "sha1-NJptRMU6Ud6JtAgFxdXlm0F9M0A=",
+          "dev": true
+        },
         "schema-utils": {
           "version": "0.3.0",
           "resolved": "https://registry.npmjs.org/schema-utils/-/schema-utils-0.3.0.tgz",
@@ -11927,7 +12131,6 @@
       "version": "5.5.0",
       "resolved": "https://registry.npmjs.org/supports-color/-/supports-color-5.5.0.tgz",
       "integrity": "sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==",
-      "dev": true,
       "requires": {
         "has-flag": "^3.0.0"
       }
@@ -12102,47 +12305,49 @@
       }
     },
     "table": {
-      "version": "5.2.2",
-      "resolved": "https://registry.npmjs.org/table/-/table-5.2.2.tgz",
-      "integrity": "sha512-f8mJmuu9beQEDkKHLzOv4VxVYlU68NpdzjbGPl69i4Hx0sTopJuNxuzJd17iV2h24dAfa93u794OnDA5jqXvfQ==",
+      "version": "5.2.3",
+      "resolved": "https://registry.npmjs.org/table/-/table-5.2.3.tgz",
+      "integrity": "sha512-N2RsDAMvDLvYwFcwbPyF3VmVSSkuF+G1e+8inhBLtHpvwXGw4QRPEZhihQNeEN0i1up6/f6ObCJXNdlRG3YVyQ==",
       "dev": true,
       "requires": {
-        "ajv": "^6.6.1",
+        "ajv": "^6.9.1",
         "lodash": "^4.17.11",
-        "slice-ansi": "^2.0.0",
-        "string-width": "^2.1.1"
+        "slice-ansi": "^2.1.0",
+        "string-width": "^3.0.0"
       },
       "dependencies": {
-        "ajv": {
-          "version": "6.7.0",
-          "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.7.0.tgz",
-          "integrity": "sha512-RZXPviBTtfmtka9n9sy1N5M5b82CbxWIR6HIis4s3WQTXDJamc/0gpCWNGz6EWdWp4DOfjzJfhz/AS9zVPjjWg==",
+        "ansi-regex": {
+          "version": "4.1.0",
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-4.1.0.tgz",
+          "integrity": "sha512-1apePfXM1UOSqw0o9IiFAovVz9M5S1Dg+4TrDwfMewQ6p/rmMueb7tWZjQ1rx4Loy1ArBggoqGpfqqdI4rondg==",
+          "dev": true
+        },
+        "string-width": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/string-width/-/string-width-3.1.0.tgz",
+          "integrity": "sha512-vafcv6KjVZKSgz06oM/H6GDBrAtz8vdhQakGjFIvNrHA6y3HCF1CInLy+QLq8dTJPQ1b+KDUqDFctkdRW44e1w==",
           "dev": true,
           "requires": {
-            "fast-deep-equal": "^2.0.1",
-            "fast-json-stable-stringify": "^2.0.0",
-            "json-schema-traverse": "^0.4.1",
-            "uri-js": "^4.2.2"
+            "emoji-regex": "^7.0.1",
+            "is-fullwidth-code-point": "^2.0.0",
+            "strip-ansi": "^5.1.0"
           }
         },
-        "fast-deep-equal": {
-          "version": "2.0.1",
-          "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-2.0.1.tgz",
-          "integrity": "sha1-ewUhjd+WZ79/Nwv3/bLLFf3Qqkk=",
-          "dev": true
-        },
-        "json-schema-traverse": {
-          "version": "0.4.1",
-          "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.4.1.tgz",
-          "integrity": "sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==",
-          "dev": true
+        "strip-ansi": {
+          "version": "5.2.0",
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-5.2.0.tgz",
+          "integrity": "sha512-DuRs1gKbBqsMKIZlrffwlug8MHkcnpjs5VPmL1PAh+mA30U0DTotfDZ0d2UUsXpPmPmMMJ6W773MaA3J+lbiWA==",
+          "dev": true,
+          "requires": {
+            "ansi-regex": "^4.1.0"
+          }
         }
       }
     },
     "tapable": {
-      "version": "1.1.1",
-      "resolved": "https://registry.npmjs.org/tapable/-/tapable-1.1.1.tgz",
-      "integrity": "sha512-9I2ydhj8Z9veORCw5PRm4u9uebCn0mcCa6scWoNcbZ6dAtoo2618u9UUzxgmsCOreJpqDDuv61LvwofW7hLcBA==",
+      "version": "1.1.3",
+      "resolved": "https://registry.npmjs.org/tapable/-/tapable-1.1.3.tgz",
+      "integrity": "sha512-4WK/bYZmj8xLr+HUCODHGF1ZFzsYffasLUgEiMBY4fgtltdO6B4WJtlSbPaDTLpYTcGVwM2qLnFTICEcNxs3kA==",
       "dev": true
     },
     "tar": {
@@ -12163,14 +12368,14 @@
       "dev": true
     },
     "terser": {
-      "version": "3.14.1",
-      "resolved": "https://registry.npmjs.org/terser/-/terser-3.14.1.tgz",
-      "integrity": "sha512-NSo3E99QDbYSMeJaEk9YW2lTg3qS9V0aKGlb+PlOrei1X02r1wSBHCNX/O+yeTRFSWPKPIGj6MqvvdqV4rnVGw==",
+      "version": "3.17.0",
+      "resolved": "https://registry.npmjs.org/terser/-/terser-3.17.0.tgz",
+      "integrity": "sha512-/FQzzPJmCpjAH9Xvk2paiWrFq+5M6aVOf+2KRbwhByISDX/EujxsK+BAvrhb6H+2rtrLCHK9N01wO014vrIwVQ==",
       "dev": true,
       "requires": {
-        "commander": "~2.17.1",
+        "commander": "^2.19.0",
         "source-map": "~0.6.1",
-        "source-map-support": "~0.5.6"
+        "source-map-support": "~0.5.10"
       },
       "dependencies": {
         "source-map": {
@@ -12252,6 +12457,15 @@
       "integrity": "sha512-YwT8pjmNcAXBZqrubu22P4FYsh2D4dxRmnWBOL8Jk8bUcRUtc5326kx32tuTmFDAZtLOGEVNl8POAR8j896Iow==",
       "dev": true
     },
+    "timers-browserify": {
+      "version": "2.0.10",
+      "resolved": "https://registry.npmjs.org/timers-browserify/-/timers-browserify-2.0.10.tgz",
+      "integrity": "sha512-YvC1SV1XdOUaL6gx5CoGroT3Gu49pK9+TZ38ErPldOWW4j49GI1HKs9DV+KGq/w6y+LZ72W1c8cKz2vzY+qpzg==",
+      "dev": true,
+      "requires": {
+        "setimmediate": "^1.0.4"
+      }
+    },
     "tmp": {
       "version": "0.0.33",
       "resolved": "https://registry.npmjs.org/tmp/-/tmp-0.0.33.tgz",
@@ -12319,6 +12533,12 @@
         "repeat-string": "^1.6.1"
       }
     },
+    "toidentifier": {
+      "version": "1.0.0",
+      "resolved": "https://registry.npmjs.org/toidentifier/-/toidentifier-1.0.0.tgz",
+      "integrity": "sha512-yaOH/Pk/VEhBWWTlhI+qXxDFXlejDGcQipMlyxda9nthulaxLZUNcUqFxokp0vcYnvteJln5FNQDRrxj3YcbVw==",
+      "dev": true
+    },
     "token-stream": {
       "version": "0.0.1",
       "resolved": "https://registry.npmjs.org/token-stream/-/token-stream-0.0.1.tgz",
@@ -12380,6 +12600,12 @@
       "resolved": "https://registry.npmjs.org/tslib/-/tslib-1.9.3.tgz",
       "integrity": "sha512-4krF8scpejhaOgqzBEcGM7yDIEfi0/8+8zDRZhNZZ2kjmHJ4hv3zCbQWxoJGz1iw5U0Jl0nma13xzHXcncMavQ=="
     },
+    "tty-browserify": {
+      "version": "0.0.0",
+      "resolved": "https://registry.npmjs.org/tty-browserify/-/tty-browserify-0.0.0.tgz",
+      "integrity": "sha1-oVe6QC2iTpv5V/mqadUk7tQpAaY=",
+      "dev": true
+    },
     "tunnel-agent": {
       "version": "0.6.0",
       "resolved": "https://registry.npmjs.org/tunnel-agent/-/tunnel-agent-0.6.0.tgz",
@@ -12411,13 +12637,13 @@
       "dev": true
     },
     "type-is": {
-      "version": "1.6.16",
-      "resolved": "https://registry.npmjs.org/type-is/-/type-is-1.6.16.tgz",
-      "integrity": "sha512-HRkVv/5qY2G6I8iab9cI7v1bOIdhm94dVjQCPFElW9W+3GeDOSHmy2EBYe4VTApuzolPcmgFTN3ftVJRKR2J9Q==",
+      "version": "1.6.17",
+      "resolved": "https://registry.npmjs.org/type-is/-/type-is-1.6.17.tgz",
+      "integrity": "sha512-jYZzkOoAPVyQ9vlZ4xEJ4BBbHC4a7hbY1xqyCPe6AiQVVqfbZEulJm0VpqK4B+096O1VQi0l6OBGH210ejx/bA==",
       "dev": true,
       "requires": {
         "media-typer": "0.3.0",
-        "mime-types": "~2.1.18"
+        "mime-types": "~2.1.24"
       }
     },
     "typedarray": {
@@ -12433,15 +12659,21 @@
       "dev": true
     },
     "uglify-js": {
-      "version": "3.4.9",
-      "resolved": "https://registry.npmjs.org/uglify-js/-/uglify-js-3.4.9.tgz",
-      "integrity": "sha512-8CJsbKOtEbnJsTyv6LE6m6ZKniqMiFWmm9sRbopbkGs3gMPPfd3Fh8iIA4Ykv5MgaTbqHr4BaoGLJLZNhsrW1Q==",
+      "version": "3.4.10",
+      "resolved": "https://registry.npmjs.org/uglify-js/-/uglify-js-3.4.10.tgz",
+      "integrity": "sha512-Y2VsbPVs0FIshJztycsO2SfPk7/KAF/T72qzv9u5EpQ4kB2hQoHlhNQTsNyy6ul7lQtqJN/AoWeS23OzEiEFxw==",
       "dev": true,
       "requires": {
-        "commander": "~2.17.1",
+        "commander": "~2.19.0",
         "source-map": "~0.6.1"
       },
       "dependencies": {
+        "commander": {
+          "version": "2.19.0",
+          "resolved": "https://registry.npmjs.org/commander/-/commander-2.19.0.tgz",
+          "integrity": "sha512-6tvAOO+D6OENvRAh524Dh9jcfKTYDQAqvqezbCW82xj5X0pSrcpxtvRKHLG0yBY6SD7PSDrJaj+0AiOcKVd1Xg==",
+          "dev": true
+        },
         "source-map": {
           "version": "0.6.1",
           "resolved": "https://registry.npmjs.org/source-map/-/source-map-0.6.1.tgz",
@@ -12519,15 +12751,15 @@
       }
     },
     "unicode-match-property-value-ecmascript": {
-      "version": "1.0.2",
-      "resolved": "https://registry.npmjs.org/unicode-match-property-value-ecmascript/-/unicode-match-property-value-ecmascript-1.0.2.tgz",
-      "integrity": "sha512-Rx7yODZC1L/T8XKo/2kNzVAQaRE88AaMvI1EF/Xnj3GW2wzN6fop9DDWuFAKUVFH7vozkz26DzP0qyWLKLIVPQ==",
+      "version": "1.1.0",
+      "resolved": "https://registry.npmjs.org/unicode-match-property-value-ecmascript/-/unicode-match-property-value-ecmascript-1.1.0.tgz",
+      "integrity": "sha512-hDTHvaBk3RmFzvSl0UVrUmC3PuW9wKVnpoUDYH0JDkSIovzw+J5viQmeYHxVSBptubnr7PbH2e0fnpDRQnQl5g==",
       "dev": true
     },
     "unicode-property-aliases-ecmascript": {
-      "version": "1.0.4",
-      "resolved": "https://registry.npmjs.org/unicode-property-aliases-ecmascript/-/unicode-property-aliases-ecmascript-1.0.4.tgz",
-      "integrity": "sha512-2WSLa6OdYd2ng8oqiGIWnJqyFArvhn+5vgx5GTxMbUYjCYKUcuKS62YLFF0R/BDGlB1yzXjQOLtPAfHsgirEpg==",
+      "version": "1.0.5",
+      "resolved": "https://registry.npmjs.org/unicode-property-aliases-ecmascript/-/unicode-property-aliases-ecmascript-1.0.5.tgz",
+      "integrity": "sha512-L5RAqCfXqAwR3RriF8pM0lU0w4Ryf/GgzONwi6KnL1taJQa7x1TCxdJnILX59WIGOwR57IVxn7Nej0fz1Ny6fw==",
       "dev": true
     },
     "unidecode": {
@@ -12660,9 +12892,9 @@
       }
     },
     "upath": {
-      "version": "1.1.0",
-      "resolved": "https://registry.npmjs.org/upath/-/upath-1.1.0.tgz",
-      "integrity": "sha512-bzpH/oBhoS/QI/YtbkqCg6VEiPYjSZtrHQM6/QnJS6OL9pKUFLqb3aFh4Scvwm45+7iAgiMkLhSbaZxUqmrprw==",
+      "version": "1.1.2",
+      "resolved": "https://registry.npmjs.org/upath/-/upath-1.1.2.tgz",
+      "integrity": "sha512-kXpym8nmDmlCBr7nKdIx8P2jNBa+pBpIUFRnKJ4dr8htyYGJFokkr2ZvERRtUN+9SY+JqXouNgUPtv6JQva/2Q==",
       "dev": true
     },
     "upper-case": {
@@ -12705,9 +12937,9 @@
       }
     },
     "url-parse": {
-      "version": "1.4.5",
-      "resolved": "https://registry.npmjs.org/url-parse/-/url-parse-1.4.5.tgz",
-      "integrity": "sha512-4XDvC5vZRjEpjP0L4znrWeoH8P8F0XGBlfLdABi/6oV4o8xUVbTpyrxWHxkK2bT0pSIpcjdIzSoWUhlUfawCAQ==",
+      "version": "1.4.6",
+      "resolved": "https://registry.npmjs.org/url-parse/-/url-parse-1.4.6.tgz",
+      "integrity": "sha512-/B8AD9iQ01seoXmXf9z/MjLZQIdOoYl/+gvsQF6+mpnxaTfG9P7srYaiqaDMyKkR36XMXfhqSHss5MyFAO8lew==",
       "dev": true,
       "requires": {
         "querystringify": "^2.0.0",
@@ -12740,12 +12972,20 @@
       }
     },
     "util": {
-      "version": "0.10.4",
-      "resolved": "https://registry.npmjs.org/util/-/util-0.10.4.tgz",
-      "integrity": "sha512-0Pm9hTQ3se5ll1XihRic3FDIku70C+iHUdT/W926rSgHV5QgXsYbKZN8MSC3tJtSkhuROzvsQjAaFENRXr+19A==",
+      "version": "0.10.3",
+      "resolved": "https://registry.npmjs.org/util/-/util-0.10.3.tgz",
+      "integrity": "sha1-evsa/lCAUkZInj23/g7TeTNqwPk=",
       "dev": true,
       "requires": {
-        "inherits": "2.0.3"
+        "inherits": "2.0.1"
+      },
+      "dependencies": {
+        "inherits": {
+          "version": "2.0.1",
+          "resolved": "https://registry.npmjs.org/inherits/-/inherits-2.0.1.tgz",
+          "integrity": "sha1-sX0I0ya0Qj5Wjv9xn5GwscvfafE=",
+          "dev": true
+        }
       }
     },
     "util-deprecate": {
@@ -12844,39 +13084,6 @@
         "chokidar": "^2.0.2",
         "graceful-fs": "^4.1.2",
         "neo-async": "^2.5.0"
-      },
-      "dependencies": {
-        "anymatch": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/anymatch/-/anymatch-2.0.0.tgz",
-          "integrity": "sha512-5teOsQWABXHHBFP9y3skS5P3d/WfWXpv3FUpy+LorMrNYaT9pI4oLMQX7jzQ2KklNpGpWHzdCXTDT2Y3XGlZBw==",
-          "dev": true,
-          "requires": {
-            "micromatch": "^3.1.4",
-            "normalize-path": "^2.1.1"
-          }
-        },
-        "chokidar": {
-          "version": "2.0.4",
-          "resolved": "https://registry.npmjs.org/chokidar/-/chokidar-2.0.4.tgz",
-          "integrity": "sha512-z9n7yt9rOvIJrMhvDtDictKrkFHeihkNl6uWMmZlmL6tJtX9Cs+87oK+teBx+JIgzvbX3yZHT3eF8vpbDxHJXQ==",
-          "dev": true,
-          "requires": {
-            "anymatch": "^2.0.0",
-            "async-each": "^1.0.0",
-            "braces": "^2.3.0",
-            "fsevents": "^1.2.2",
-            "glob-parent": "^3.1.0",
-            "inherits": "^2.0.1",
-            "is-binary-path": "^1.0.0",
-            "is-glob": "^4.0.0",
-            "lodash.debounce": "^4.0.8",
-            "normalize-path": "^2.1.1",
-            "path-is-absolute": "^1.0.0",
-            "readdirp": "^2.0.0",
-            "upath": "^1.0.5"
-          }
-        }
       }
     },
     "wbuf": {
@@ -12920,37 +13127,10 @@
         "webpack-sources": "^1.2.0"
       },
       "dependencies": {
-        "acorn-dynamic-import": {
-          "version": "3.0.0",
-          "resolved": "https://registry.npmjs.org/acorn-dynamic-import/-/acorn-dynamic-import-3.0.0.tgz",
-          "integrity": "sha512-zVWV8Z8lislJoOKKqdNMOB+s6+XV5WERty8MnKBeFgwA+19XJjJHs2RP5dzM57FftIs+jQnRToLiWazKr6sSWg==",
-          "dev": true,
-          "requires": {
-            "acorn": "^5.0.0"
-          }
-        },
-        "ajv": {
-          "version": "6.6.2",
-          "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.6.2.tgz",
-          "integrity": "sha512-FBHEW6Jf5TB9MGBgUUA9XHkTbjXYfAUjY43ACMfmdMRHniyoMHjHjzD50OK8LGDWQwp4rWEsIq5kEqq7rvIM1g==",
-          "dev": true,
-          "requires": {
-            "fast-deep-equal": "^2.0.1",
-            "fast-json-stable-stringify": "^2.0.0",
-            "json-schema-traverse": "^0.4.1",
-            "uri-js": "^4.2.2"
-          }
-        },
-        "fast-deep-equal": {
-          "version": "2.0.1",
-          "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-2.0.1.tgz",
-          "integrity": "sha1-ewUhjd+WZ79/Nwv3/bLLFf3Qqkk=",
-          "dev": true
-        },
-        "json-schema-traverse": {
-          "version": "0.4.1",
-          "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.4.1.tgz",
-          "integrity": "sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==",
+        "acorn": {
+          "version": "5.7.3",
+          "resolved": "https://registry.npmjs.org/acorn/-/acorn-5.7.3.tgz",
+          "integrity": "sha512-T/zvzYRfbVojPWahDsE5evJdHb3oJoQfFbsrKM7w5Zcs++Tr257tia3BmMP8XYVjp1S9RZXQMh7gao96BlqZOw==",
           "dev": true
         }
       }
@@ -12974,17 +13154,6 @@
         "yargs": "^12.0.1"
       },
       "dependencies": {
-        "ansi-regex": {
-          "version": "4.0.0",
-          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-4.0.0.tgz",
-          "integrity": "sha512-iB5Dda8t/UqpPI/IjsejXu5jOGDrzn41wJyljwPH65VCIbk6+1BzFIMJGFwTNrYXT1CrD+B4l19U7awiQ8rk7w=="
-        },
-        "camelcase": {
-          "version": "5.0.0",
-          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.0.0.tgz",
-          "integrity": "sha512-faqwZqnWxbxn+F1d399ygeamQNy3lPp/H9H6rNrqYh4FSVCtcY+3cub1MxA8o9mDd55mM8Aghuu/kuyYA6VTsA==",
-          "dev": true
-        },
         "chalk": {
           "version": "2.4.2",
           "resolved": "https://registry.npmjs.org/chalk/-/chalk-2.4.2.tgz",
@@ -12996,47 +13165,6 @@
             "supports-color": "^5.3.0"
           }
         },
-        "cliui": {
-          "version": "4.1.0",
-          "resolved": "https://registry.npmjs.org/cliui/-/cliui-4.1.0.tgz",
-          "integrity": "sha512-4FG+RSG9DL7uEwRUZXZn3SS34DiDPfzP0VOiEwtUWlE+AR2EIg+hSyvrIgUUfhdgR/UkAeW2QHgeP+hWrXs7jQ==",
-          "dev": true,
-          "requires": {
-            "string-width": "^2.1.1",
-            "strip-ansi": "^4.0.0",
-            "wrap-ansi": "^2.0.0"
-          },
-          "dependencies": {
-            "ansi-regex": {
-              "version": "3.0.0",
-              "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-3.0.0.tgz",
-              "integrity": "sha1-7QMXwyIGT3lGbAKWa922Bas32Zg=",
-              "dev": true
-            },
-            "strip-ansi": {
-              "version": "4.0.0",
-              "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
-              "integrity": "sha1-qEeQIusaw2iocTibY1JixQXuNo8=",
-              "dev": true,
-              "requires": {
-                "ansi-regex": "^3.0.0"
-              }
-            }
-          }
-        },
-        "cross-spawn": {
-          "version": "6.0.5",
-          "resolved": "https://registry.npmjs.org/cross-spawn/-/cross-spawn-6.0.5.tgz",
-          "integrity": "sha512-eTVLrBSt7fjbDygz805pMnstIs2VTBNkRm0qxZd+M7A5XDdxVRWO5MxGBXZhjY4cqLYLdtrGqRf8mBPmzwSpWQ==",
-          "dev": true,
-          "requires": {
-            "nice-try": "^1.0.4",
-            "path-key": "^2.0.1",
-            "semver": "^5.5.0",
-            "shebang-command": "^1.2.0",
-            "which": "^1.2.9"
-          }
-        },
         "find-up": {
           "version": "3.0.0",
           "resolved": "https://registry.npmjs.org/find-up/-/find-up-3.0.0.tgz",
@@ -13046,21 +13174,12 @@
             "locate-path": "^3.0.0"
           }
         },
-        "invert-kv": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-2.0.0.tgz",
-          "integrity": "sha512-wPVv/y/QQ/Uiirj/vh3oP+1Ww+AWehmi1g5fFWGPF6IpCBCDVrhgHRMvrLfdYcwDh3QJbGXDW4JAuzxElLSqKA==",
+        "get-caller-file": {
+          "version": "1.0.3",
+          "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-1.0.3.tgz",
+          "integrity": "sha512-3t6rVToeoZfYSGd8YoLFR2DJkiQrIiUrGcjvFX2mDw3bn6k2OtwHN0TNCLbBO+w8qTvimhDkv+LSscbJY1vE6w==",
           "dev": true
         },
-        "lcid": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/lcid/-/lcid-2.0.0.tgz",
-          "integrity": "sha512-avPEb8P8EGnwXKClwsNUgryVjllcRqtMYa49NTsbQagYuT1DcXnl1915oxWjoyGrXR6zH/Y0Zc96xWsPcoDKeA==",
-          "dev": true,
-          "requires": {
-            "invert-kv": "^2.0.0"
-          }
-        },
         "locate-path": {
           "version": "3.0.0",
           "resolved": "https://registry.npmjs.org/locate-path/-/locate-path-3.0.0.tgz",
@@ -13071,21 +13190,10 @@
             "path-exists": "^3.0.0"
           }
         },
-        "os-locale": {
-          "version": "3.1.0",
-          "resolved": "https://registry.npmjs.org/os-locale/-/os-locale-3.1.0.tgz",
-          "integrity": "sha512-Z8l3R4wYWM40/52Z+S265okfFj8Kt2cC2MKY+xNi3kFs+XGI7WXu/I309QQQYbRW4ijiZ+yxs9pqEhJh0DqW3Q==",
-          "dev": true,
-          "requires": {
-            "execa": "^1.0.0",
-            "lcid": "^2.0.0",
-            "mem": "^4.0.0"
-          }
-        },
         "p-limit": {
-          "version": "2.1.0",
-          "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.1.0.tgz",
-          "integrity": "sha512-NhURkNcrVB+8hNfLuysU8enY5xn2KXphsHBaC2YmRNTZRc7RWusw6apSpdEj3jo4CMb6W9nrF6tTnsJsJeyu6g==",
+          "version": "2.2.0",
+          "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.2.0.tgz",
+          "integrity": "sha512-pZbTJpoUsCzV48Mc9Nh51VbwO0X9cuPFE8gYwx9BTCt9SF8/b7Zljd2fVgOxhIF/HDTKgpVzs+GPhyKfjLLFRQ==",
           "dev": true,
           "requires": {
             "p-try": "^2.0.0"
@@ -13101,23 +13209,15 @@
           }
         },
         "p-try": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/p-try/-/p-try-2.0.0.tgz",
-          "integrity": "sha512-hMp0onDKIajHfIkdRk3P4CdCmErkYAxxDtP3Wx/4nZ3aGlau2VKh3mZpcuFkH27WQkL/3WBCPOktzA9ZOAnMQQ==",
+          "version": "2.2.0",
+          "resolved": "https://registry.npmjs.org/p-try/-/p-try-2.2.0.tgz",
+          "integrity": "sha512-R4nPAVTAU0B9D35/Gk3uJf/7XYbQcyohSKdvAxIRSNghFl4e71hVoGnBNQz9cWaXxO2I10KTC+3jMdvvoKw6dQ==",
           "dev": true
         },
-        "strip-ansi": {
-          "version": "5.0.0",
-          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-5.0.0.tgz",
-          "integrity": "sha512-Uu7gQyZI7J7gn5qLn1Np3G9vcYGTVqB+lFTytnDJv83dd8T22aGH451P3jueT2/QemInJDfxHB5Tde5OzgG1Ow==",
-          "requires": {
-            "ansi-regex": "^4.0.0"
-          }
-        },
-        "which-module": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/which-module/-/which-module-2.0.0.tgz",
-          "integrity": "sha1-2e8H3Od7mQK4o6j6SzHD4/fm6Ho=",
+        "require-main-filename": {
+          "version": "1.0.1",
+          "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-1.0.1.tgz",
+          "integrity": "sha1-l/cXtp1IeE9fUmpsWqj/3aBVpNE=",
           "dev": true
         },
         "yargs": {
@@ -13153,23 +13253,15 @@
       }
     },
     "webpack-dev-middleware": {
-      "version": "3.5.0",
-      "resolved": "https://registry.npmjs.org/webpack-dev-middleware/-/webpack-dev-middleware-3.5.0.tgz",
-      "integrity": "sha512-1Zie7+dMr4Vv3nGyhr8mxGQkzTQK1PTS8K3yJ4yB1mfRGwO1DzQibgmNfUqbEfQY6eEtEEUzC+o7vhpm/Sfn5w==",
+      "version": "3.6.2",
+      "resolved": "https://registry.npmjs.org/webpack-dev-middleware/-/webpack-dev-middleware-3.6.2.tgz",
+      "integrity": "sha512-A47I5SX60IkHrMmZUlB0ZKSWi29TZTcPz7cha1Z75yYOsgWh/1AcPmQEbC8ZIbU3A1ytSv1PMU0PyPz2Lmz2jg==",
       "dev": true,
       "requires": {
-        "memory-fs": "~0.4.1",
+        "memory-fs": "^0.4.1",
         "mime": "^2.3.1",
         "range-parser": "^1.0.3",
         "webpack-log": "^2.0.0"
-      },
-      "dependencies": {
-        "mime": {
-          "version": "2.4.0",
-          "resolved": "https://registry.npmjs.org/mime/-/mime-2.4.0.tgz",
-          "integrity": "sha512-ikBcWwyqXQSHKtciCcctu9YfPbFYZ4+gbHEmE0Q8jzcTYQg5dHCr3g2wwAZjPoJfQVXZq6KXAjpXOTf5/cjT7w==",
-          "dev": true
-        }
       }
     },
     "webpack-dev-server": {
@@ -13210,64 +13302,12 @@
         "yargs": "12.0.5"
       },
       "dependencies": {
-        "ajv": {
-          "version": "6.10.0",
-          "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.10.0.tgz",
-          "integrity": "sha512-nffhOpkymDECQyR0mnsUtoCE8RlX38G0rYP+wgLWFyZuUyuuojSSvi/+euOiQBIn63whYwYVIIH1TvE3tu4OEg==",
-          "dev": true,
-          "requires": {
-            "fast-deep-equal": "^2.0.1",
-            "fast-json-stable-stringify": "^2.0.0",
-            "json-schema-traverse": "^0.4.1",
-            "uri-js": "^4.2.2"
-          }
-        },
         "ansi-regex": {
           "version": "2.1.1",
           "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-2.1.1.tgz",
           "integrity": "sha1-w7M6te42DYbg5ijwRorn7yfWVN8=",
           "dev": true
         },
-        "camelcase": {
-          "version": "5.3.1",
-          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.3.1.tgz",
-          "integrity": "sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==",
-          "dev": true
-        },
-        "cliui": {
-          "version": "4.1.0",
-          "resolved": "https://registry.npmjs.org/cliui/-/cliui-4.1.0.tgz",
-          "integrity": "sha512-4FG+RSG9DL7uEwRUZXZn3SS34DiDPfzP0VOiEwtUWlE+AR2EIg+hSyvrIgUUfhdgR/UkAeW2QHgeP+hWrXs7jQ==",
-          "dev": true,
-          "requires": {
-            "string-width": "^2.1.1",
-            "strip-ansi": "^4.0.0",
-            "wrap-ansi": "^2.0.0"
-          },
-          "dependencies": {
-            "ansi-regex": {
-              "version": "3.0.0",
-              "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-3.0.0.tgz",
-              "integrity": "sha1-7QMXwyIGT3lGbAKWa922Bas32Zg=",
-              "dev": true
-            },
-            "strip-ansi": {
-              "version": "4.0.0",
-              "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
-              "integrity": "sha1-qEeQIusaw2iocTibY1JixQXuNo8=",
-              "dev": true,
-              "requires": {
-                "ansi-regex": "^3.0.0"
-              }
-            }
-          }
-        },
-        "fast-deep-equal": {
-          "version": "2.0.1",
-          "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-2.0.1.tgz",
-          "integrity": "sha1-ewUhjd+WZ79/Nwv3/bLLFf3Qqkk=",
-          "dev": true
-        },
         "find-up": {
           "version": "3.0.0",
           "resolved": "https://registry.npmjs.org/find-up/-/find-up-3.0.0.tgz",
@@ -13277,6 +13317,12 @@
             "locate-path": "^3.0.0"
           }
         },
+        "get-caller-file": {
+          "version": "1.0.3",
+          "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-1.0.3.tgz",
+          "integrity": "sha512-3t6rVToeoZfYSGd8YoLFR2DJkiQrIiUrGcjvFX2mDw3bn6k2OtwHN0TNCLbBO+w8qTvimhDkv+LSscbJY1vE6w==",
+          "dev": true
+        },
         "import-local": {
           "version": "2.0.0",
           "resolved": "https://registry.npmjs.org/import-local/-/import-local-2.0.0.tgz",
@@ -13287,27 +13333,6 @@
             "resolve-cwd": "^2.0.0"
           }
         },
-        "invert-kv": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-2.0.0.tgz",
-          "integrity": "sha512-wPVv/y/QQ/Uiirj/vh3oP+1Ww+AWehmi1g5fFWGPF6IpCBCDVrhgHRMvrLfdYcwDh3QJbGXDW4JAuzxElLSqKA==",
-          "dev": true
-        },
-        "json-schema-traverse": {
-          "version": "0.4.1",
-          "resolved": "https://registry.npmjs.org/json-schema-traverse/-/json-schema-traverse-0.4.1.tgz",
-          "integrity": "sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==",
-          "dev": true
-        },
-        "lcid": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/lcid/-/lcid-2.0.0.tgz",
-          "integrity": "sha512-avPEb8P8EGnwXKClwsNUgryVjllcRqtMYa49NTsbQagYuT1DcXnl1915oxWjoyGrXR6zH/Y0Zc96xWsPcoDKeA==",
-          "dev": true,
-          "requires": {
-            "invert-kv": "^2.0.0"
-          }
-        },
         "locate-path": {
           "version": "3.0.0",
           "resolved": "https://registry.npmjs.org/locate-path/-/locate-path-3.0.0.tgz",
@@ -13318,17 +13343,6 @@
             "path-exists": "^3.0.0"
           }
         },
-        "os-locale": {
-          "version": "3.1.0",
-          "resolved": "https://registry.npmjs.org/os-locale/-/os-locale-3.1.0.tgz",
-          "integrity": "sha512-Z8l3R4wYWM40/52Z+S265okfFj8Kt2cC2MKY+xNi3kFs+XGI7WXu/I309QQQYbRW4ijiZ+yxs9pqEhJh0DqW3Q==",
-          "dev": true,
-          "requires": {
-            "execa": "^1.0.0",
-            "lcid": "^2.0.0",
-            "mem": "^4.0.0"
-          }
-        },
         "p-limit": {
           "version": "2.2.0",
           "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.2.0.tgz",
@@ -13362,6 +13376,12 @@
             "find-up": "^3.0.0"
           }
         },
+        "require-main-filename": {
+          "version": "1.0.1",
+          "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-1.0.1.tgz",
+          "integrity": "sha1-l/cXtp1IeE9fUmpsWqj/3aBVpNE=",
+          "dev": true
+        },
         "schema-utils": {
           "version": "1.0.0",
           "resolved": "https://registry.npmjs.org/schema-utils/-/schema-utils-1.0.0.tgz",
@@ -13397,24 +13417,6 @@
             "has-flag": "^3.0.0"
           }
         },
-        "webpack-dev-middleware": {
-          "version": "3.6.2",
-          "resolved": "https://registry.npmjs.org/webpack-dev-middleware/-/webpack-dev-middleware-3.6.2.tgz",
-          "integrity": "sha512-A47I5SX60IkHrMmZUlB0ZKSWi29TZTcPz7cha1Z75yYOsgWh/1AcPmQEbC8ZIbU3A1ytSv1PMU0PyPz2Lmz2jg==",
-          "dev": true,
-          "requires": {
-            "memory-fs": "^0.4.1",
-            "mime": "^2.3.1",
-            "range-parser": "^1.0.3",
-            "webpack-log": "^2.0.0"
-          }
-        },
-        "which-module": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/which-module/-/which-module-2.0.0.tgz",
-          "integrity": "sha1-2e8H3Od7mQK4o6j6SzHD4/fm6Ho=",
-          "dev": true
-        },
         "yargs": {
           "version": "12.0.5",
           "resolved": "https://registry.npmjs.org/yargs/-/yargs-12.0.5.tgz",
@@ -13516,9 +13518,9 @@
       }
     },
     "which-module": {
-      "version": "1.0.0",
-      "resolved": "https://registry.npmjs.org/which-module/-/which-module-1.0.0.tgz",
-      "integrity": "sha1-u6Y8qGGUiZT/MHc2CJ47lgJsKk8=",
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/which-module/-/which-module-2.0.0.tgz",
+      "integrity": "sha1-2e8H3Od7mQK4o6j6SzHD4/fm6Ho=",
       "dev": true
     },
     "wide-align": {
@@ -13629,7 +13631,8 @@
     "wrappy": {
       "version": "1.0.2",
       "resolved": "https://registry.npmjs.org/wrappy/-/wrappy-1.0.2.tgz",
-      "integrity": "sha1-tSQ9jz7BqjXxNkYFvA0QNuMKtp8="
+      "integrity": "sha1-tSQ9jz7BqjXxNkYFvA0QNuMKtp8=",
+      "dev": true
     },
     "write": {
       "version": "0.2.1",
@@ -13694,12 +13697,53 @@
         "yargs-parser": "^7.0.0"
       },
       "dependencies": {
+        "ansi-regex": {
+          "version": "2.1.1",
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-2.1.1.tgz",
+          "integrity": "sha1-w7M6te42DYbg5ijwRorn7yfWVN8=",
+          "dev": true
+        },
         "camelcase": {
           "version": "4.1.0",
           "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-4.1.0.tgz",
           "integrity": "sha1-1UVjW+HjPFQmScaRc+Xeas+uNN0=",
           "dev": true
         },
+        "cliui": {
+          "version": "3.2.0",
+          "resolved": "https://registry.npmjs.org/cliui/-/cliui-3.2.0.tgz",
+          "integrity": "sha1-EgYBU3qRbSmUD5NNo7SNWFo5IT0=",
+          "dev": true,
+          "requires": {
+            "string-width": "^1.0.1",
+            "strip-ansi": "^3.0.1",
+            "wrap-ansi": "^2.0.0"
+          },
+          "dependencies": {
+            "string-width": {
+              "version": "1.0.2",
+              "resolved": "https://registry.npmjs.org/string-width/-/string-width-1.0.2.tgz",
+              "integrity": "sha1-EYvfW4zcUaKn5w0hHgfisLmxB9M=",
+              "dev": true,
+              "requires": {
+                "code-point-at": "^1.0.0",
+                "is-fullwidth-code-point": "^1.0.0",
+                "strip-ansi": "^3.0.0"
+              }
+            }
+          }
+        },
+        "cross-spawn": {
+          "version": "5.1.0",
+          "resolved": "https://registry.npmjs.org/cross-spawn/-/cross-spawn-5.1.0.tgz",
+          "integrity": "sha1-6L0O/uWPz/b4+UUQoKVUu/ojVEk=",
+          "dev": true,
+          "requires": {
+            "lru-cache": "^4.0.1",
+            "shebang-command": "^1.2.0",
+            "which": "^1.2.9"
+          }
+        },
         "execa": {
           "version": "0.7.0",
           "resolved": "https://registry.npmjs.org/execa/-/execa-0.7.0.tgz",
@@ -13715,12 +13759,42 @@
             "strip-eof": "^1.0.0"
           }
         },
+        "get-caller-file": {
+          "version": "1.0.3",
+          "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-1.0.3.tgz",
+          "integrity": "sha512-3t6rVToeoZfYSGd8YoLFR2DJkiQrIiUrGcjvFX2mDw3bn6k2OtwHN0TNCLbBO+w8qTvimhDkv+LSscbJY1vE6w==",
+          "dev": true
+        },
         "get-stream": {
           "version": "3.0.0",
           "resolved": "https://registry.npmjs.org/get-stream/-/get-stream-3.0.0.tgz",
           "integrity": "sha1-jpQ9E1jcN1VQVOy+LtsFqhdO3hQ=",
           "dev": true
         },
+        "invert-kv": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-1.0.0.tgz",
+          "integrity": "sha1-EEqOSqym09jNFXqO+L+rLXo//bY=",
+          "dev": true
+        },
+        "is-fullwidth-code-point": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-1.0.0.tgz",
+          "integrity": "sha1-754xOG8DGn8NZDr4L95QxFfvAMs=",
+          "dev": true,
+          "requires": {
+            "number-is-nan": "^1.0.0"
+          }
+        },
+        "lcid": {
+          "version": "1.0.0",
+          "resolved": "https://registry.npmjs.org/lcid/-/lcid-1.0.0.tgz",
+          "integrity": "sha1-MIrMr6C8SDo4Z7S28rlQYlHRuDU=",
+          "dev": true,
+          "requires": {
+            "invert-kv": "^1.0.0"
+          }
+        },
         "load-json-file": {
           "version": "2.0.0",
           "resolved": "https://registry.npmjs.org/load-json-file/-/load-json-file-2.0.0.tgz",
@@ -13789,18 +13863,27 @@
             "read-pkg": "^2.0.0"
           }
         },
+        "require-main-filename": {
+          "version": "1.0.1",
+          "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-1.0.1.tgz",
+          "integrity": "sha1-l/cXtp1IeE9fUmpsWqj/3aBVpNE=",
+          "dev": true
+        },
+        "strip-ansi": {
+          "version": "3.0.1",
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-3.0.1.tgz",
+          "integrity": "sha1-ajhfuIU9lS1f8F0Oiq+UJ43GPc8=",
+          "dev": true,
+          "requires": {
+            "ansi-regex": "^2.0.0"
+          }
+        },
         "strip-bom": {
           "version": "3.0.0",
           "resolved": "https://registry.npmjs.org/strip-bom/-/strip-bom-3.0.0.tgz",
           "integrity": "sha1-IzTBjpx1n3vdVv3vfprj1YjmjtM=",
           "dev": true
         },
-        "which-module": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/which-module/-/which-module-2.0.0.tgz",
-          "integrity": "sha1-2e8H3Od7mQK4o6j6SzHD4/fm6Ho=",
-          "dev": true
-        },
         "y18n": {
           "version": "3.2.1",
           "resolved": "https://registry.npmjs.org/y18n/-/y18n-3.2.1.tgz",
@@ -13819,20 +13902,13 @@
       }
     },
     "yargs-parser": {
-      "version": "5.0.0",
-      "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-5.0.0.tgz",
-      "integrity": "sha1-J17PDX/+Bcd+ZOfIbkzZS/DhIoo=",
+      "version": "13.0.0",
+      "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-13.0.0.tgz",
+      "integrity": "sha512-w2LXjoL8oRdRQN+hOyppuXs+V/fVAYtpcrRxZuF7Kt/Oc+Jr2uAcVntaUTNT6w5ihoWfFDpNY8CPx1QskxZ/pw==",
       "dev": true,
       "requires": {
-        "camelcase": "^3.0.0"
-      },
-      "dependencies": {
-        "camelcase": {
-          "version": "3.0.0",
-          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-3.0.0.tgz",
-          "integrity": "sha1-MvxLn82vhF/N9+c7uXysImHwqwo=",
-          "dev": true
-        }
+        "camelcase": "^5.0.0",
+        "decamelize": "^1.2.0"
       }
     },
     "yargs-unparser": {
@@ -13846,29 +13922,6 @@
         "yargs": "^12.0.5"
       },
       "dependencies": {
-        "ansi-regex": {
-          "version": "3.0.0",
-          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-3.0.0.tgz",
-          "integrity": "sha1-7QMXwyIGT3lGbAKWa922Bas32Zg=",
-          "dev": true
-        },
-        "camelcase": {
-          "version": "5.3.1",
-          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.3.1.tgz",
-          "integrity": "sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==",
-          "dev": true
-        },
-        "cliui": {
-          "version": "4.1.0",
-          "resolved": "https://registry.npmjs.org/cliui/-/cliui-4.1.0.tgz",
-          "integrity": "sha512-4FG+RSG9DL7uEwRUZXZn3SS34DiDPfzP0VOiEwtUWlE+AR2EIg+hSyvrIgUUfhdgR/UkAeW2QHgeP+hWrXs7jQ==",
-          "dev": true,
-          "requires": {
-            "string-width": "^2.1.1",
-            "strip-ansi": "^4.0.0",
-            "wrap-ansi": "^2.0.0"
-          }
-        },
         "find-up": {
           "version": "3.0.0",
           "resolved": "https://registry.npmjs.org/find-up/-/find-up-3.0.0.tgz",
@@ -13878,21 +13931,12 @@
             "locate-path": "^3.0.0"
           }
         },
-        "invert-kv": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/invert-kv/-/invert-kv-2.0.0.tgz",
-          "integrity": "sha512-wPVv/y/QQ/Uiirj/vh3oP+1Ww+AWehmi1g5fFWGPF6IpCBCDVrhgHRMvrLfdYcwDh3QJbGXDW4JAuzxElLSqKA==",
+        "get-caller-file": {
+          "version": "1.0.3",
+          "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-1.0.3.tgz",
+          "integrity": "sha512-3t6rVToeoZfYSGd8YoLFR2DJkiQrIiUrGcjvFX2mDw3bn6k2OtwHN0TNCLbBO+w8qTvimhDkv+LSscbJY1vE6w==",
           "dev": true
         },
-        "lcid": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/lcid/-/lcid-2.0.0.tgz",
-          "integrity": "sha512-avPEb8P8EGnwXKClwsNUgryVjllcRqtMYa49NTsbQagYuT1DcXnl1915oxWjoyGrXR6zH/Y0Zc96xWsPcoDKeA==",
-          "dev": true,
-          "requires": {
-            "invert-kv": "^2.0.0"
-          }
-        },
         "locate-path": {
           "version": "3.0.0",
           "resolved": "https://registry.npmjs.org/locate-path/-/locate-path-3.0.0.tgz",
@@ -13903,17 +13947,6 @@
             "path-exists": "^3.0.0"
           }
         },
-        "os-locale": {
-          "version": "3.1.0",
-          "resolved": "https://registry.npmjs.org/os-locale/-/os-locale-3.1.0.tgz",
-          "integrity": "sha512-Z8l3R4wYWM40/52Z+S265okfFj8Kt2cC2MKY+xNi3kFs+XGI7WXu/I309QQQYbRW4ijiZ+yxs9pqEhJh0DqW3Q==",
-          "dev": true,
-          "requires": {
-            "execa": "^1.0.0",
-            "lcid": "^2.0.0",
-            "mem": "^4.0.0"
-          }
-        },
         "p-limit": {
           "version": "2.2.0",
           "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.2.0.tgz",
@@ -13938,19 +13971,10 @@
           "integrity": "sha512-R4nPAVTAU0B9D35/Gk3uJf/7XYbQcyohSKdvAxIRSNghFl4e71hVoGnBNQz9cWaXxO2I10KTC+3jMdvvoKw6dQ==",
           "dev": true
         },
-        "strip-ansi": {
-          "version": "4.0.0",
-          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
-          "integrity": "sha1-qEeQIusaw2iocTibY1JixQXuNo8=",
-          "dev": true,
-          "requires": {
-            "ansi-regex": "^3.0.0"
-          }
-        },
-        "which-module": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/which-module/-/which-module-2.0.0.tgz",
-          "integrity": "sha1-2e8H3Od7mQK4o6j6SzHD4/fm6Ho=",
+        "require-main-filename": {
+          "version": "1.0.1",
+          "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-1.0.1.tgz",
+          "integrity": "sha1-l/cXtp1IeE9fUmpsWqj/3aBVpNE=",
           "dev": true
         },
         "yargs": {
diff --git a/modules/web-console/pom.xml b/modules/web-console/pom.xml
index a78cc6b..1dc4f46 100644
--- a/modules/web-console/pom.xml
+++ b/modules/web-console/pom.xml
@@ -34,7 +34,7 @@
     <url>http://ignite.apache.org</url>
 
     <properties>
-        <node.version>v8.11.2</node.version>
+        <node.version>v10.15.2</node.version>
         <docker.registry.host>docker.io</docker.registry.host>
         <docker.repository>apacheignite</docker.repository>
         <docker.backend.image>web-console-backend</docker.backend.image>
diff --git a/pom.xml b/pom.xml
index d52098e..50de0d3 100644
--- a/pom.xml
+++ b/pom.xml
@@ -396,15 +396,15 @@
                                             <include name="**/*.sh" />
                                         </fixcrlf>
 
-                                        <zip destfile="${basedir}/target/bin/${ignite.edition}-${project.version}-bin.zip" encoding="UTF-8">
-                                            <zipfileset dir="${basedir}/target/release-package-${ignite.edition}" prefix="${ignite.edition}-${project.version}-bin" filemode="755">
+                                        <zip destfile="${basedir}/target/bin/${ignite.edition}-${project.version}.zip" encoding="UTF-8">
+                                            <zipfileset dir="${basedir}/target/release-package-${ignite.edition}" prefix="${ignite.edition}-${project.version}" filemode="755">
                                                 <include name="**/*.sh" />
                                                 <include name="**/configure" />
                                                 <include name="**/install-sh" />
                                                 <include name="**/compile" />
                                                 <include name="**/missing" />
                                             </zipfileset>
-                                            <zipfileset dir="${basedir}/target/release-package-${ignite.edition}" prefix="${ignite.edition}-${project.version}-bin">
+                                            <zipfileset dir="${basedir}/target/release-package-${ignite.edition}" prefix="${ignite.edition}-${project.version}">
                                                 <exclude name="**/*.sh" />
                                                 <exclude name="**/configure" />
                                                 <exclude name="**/install-sh" />


[ignite] 01/17: GG-17388 Fixed flaky test IgnitePdsStartWIthEmptyArchive

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit d074c3fc9d1b737b8115d47a3c0e958b3312db52
Author: Slava Koptilin <sl...@gmail.com>
AuthorDate: Fri Apr 26 13:06:14 2019 +0300

    GG-17388 Fixed flaky test IgnitePdsStartWIthEmptyArchive
---
 .../db/IgnitePdsStartWIthEmptyArchive.java         | 95 ++++++++++++++--------
 1 file changed, 60 insertions(+), 35 deletions(-)

diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsStartWIthEmptyArchive.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsStartWIthEmptyArchive.java
index b9a883e..f96233d 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsStartWIthEmptyArchive.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsStartWIthEmptyArchive.java
@@ -18,20 +18,26 @@ package org.apache.ignite.internal.processors.cache.persistence.db;
 
 import java.io.File;
 import java.util.Arrays;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.concurrent.ConcurrentHashMap;
 import org.apache.ignite.IgniteDataStreamer;
-import org.apache.ignite.IgniteException;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.DataRegionConfiguration;
 import org.apache.ignite.configuration.DataStorageConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.events.Event;
 import org.apache.ignite.events.WalSegmentArchivedEvent;
 import org.apache.ignite.internal.IgniteEx;
 import org.apache.ignite.internal.processors.cache.persistence.wal.FileWriteAheadLogManager;
 import org.apache.ignite.internal.processors.cache.persistence.wal.aware.SegmentAware;
 import org.apache.ignite.internal.processors.cache.persistence.wal.filehandle.FileWriteHandle;
-import org.apache.ignite.internal.util.future.CountDownFuture;
+import org.apache.ignite.internal.util.lang.GridAbsPredicate;
 import org.apache.ignite.internal.util.typedef.internal.U;
+import org.apache.ignite.lang.IgnitePredicate;
+import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.junit.After;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
@@ -43,6 +49,9 @@ import static org.apache.ignite.internal.processors.cache.persistence.wal.FileWr
  *
  */
 public class IgnitePdsStartWIthEmptyArchive extends GridCommonAbstractTest {
+    /** Mapping of WAL segment idx to WalSegmentArchivedEvent. */
+    private final Map<Long, WalSegmentArchivedEvent> evts = new ConcurrentHashMap<>();
+
     /** {@inheritDoc} */
     @Override protected IgniteConfiguration getConfiguration(String igniteInstanceName) throws Exception {
         IgniteConfiguration cfg = super.getConfiguration(igniteInstanceName);
@@ -63,9 +72,27 @@ public class IgnitePdsStartWIthEmptyArchive extends GridCommonAbstractTest {
                 )
         );
 
+        Map<IgnitePredicate<? extends Event>, int[]> lsnrs = new HashMap<>();
+
+        lsnrs.put((e) -> {
+            WalSegmentArchivedEvent archComplEvt = (WalSegmentArchivedEvent)e;
+
+            log.info("EVT_WAL_SEGMENT_ARCHIVED: " + archComplEvt.getAbsWalSegmentIdx());
+
+            evts.put(archComplEvt.getAbsWalSegmentIdx(), archComplEvt);
+
+            return true;
+        }, new int[] {EVT_WAL_SEGMENT_ARCHIVED});
+
+        cfg.setLocalEventListeners(lsnrs);
+
         return cfg;
     }
 
+    /**
+     * Executes initial steps before test execution.
+     * @throws Exception If failed.
+     */
     @Before
     public void before() throws Exception {
         stopAllGrids();
@@ -73,6 +100,19 @@ public class IgnitePdsStartWIthEmptyArchive extends GridCommonAbstractTest {
         cleanPersistenceDir();
     }
 
+    /**
+     * Stops all nodes and cleans work dir after a test.
+     */
+    @After
+    public void cleanup() throws Exception {
+        stopAllGrids();
+
+        cleanPersistenceDir();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
     @Test
     public void test() throws Exception {
         IgniteEx ig = startGrid(0);
@@ -85,9 +125,8 @@ public class IgnitePdsStartWIthEmptyArchive extends GridCommonAbstractTest {
         try (IgniteDataStreamer<Integer, byte[]> st = ig.dataStreamer(DEFAULT_CACHE_NAME)) {
             int entries = 1000;
 
-            for (int i = 0; i < entries; i++) {
+            for (int i = 0; i < entries; i++)
                 st.addData(i, new byte[1024 * 1024]);
-            }
         }
 
         File archiveDir = U.field(walMgr, "walArchiveDir");
@@ -96,7 +135,7 @@ public class IgnitePdsStartWIthEmptyArchive extends GridCommonAbstractTest {
 
         SegmentAware beforeSaw = U.field(walMgr, "segmentAware");
 
-        long beforeLastArchivedAbsoluteIndex = beforeSaw.lastArchivedAbsoluteIndex();
+        long beforeLastArchivedAbsoluteIdx = beforeSaw.lastArchivedAbsoluteIndex();
 
         FileWriteHandle fhBefore = U.field(walMgr, "currHnd");
 
@@ -114,6 +153,8 @@ public class IgnitePdsStartWIthEmptyArchive extends GridCommonAbstractTest {
 
         Assert.assertEquals(0, archiveDir.listFiles().length);
 
+        evts.clear();
+
         // Restart grid again after archive was removed.
         ig = startGrid(0);
 
@@ -126,10 +167,10 @@ public class IgnitePdsStartWIthEmptyArchive extends GridCommonAbstractTest {
         int segments = ig.configuration().getDataStorageConfiguration().getWalSegments();
 
         Assert.assertTrue(
-            "lastArchivedBeforeIdx=" + beforeLastArchivedAbsoluteIndex +
+            "lastArchivedBeforeIdx=" + beforeLastArchivedAbsoluteIdx +
                 ", lastArchivedAfterIdx=" + afterLastArchivedAbsoluteIndex + ",  segments=" + segments,
             afterLastArchivedAbsoluteIndex >=
-            (beforeLastArchivedAbsoluteIndex - segments));
+            (beforeLastArchivedAbsoluteIdx - segments));
 
         ig.cluster().active(true);
 
@@ -140,38 +181,22 @@ public class IgnitePdsStartWIthEmptyArchive extends GridCommonAbstractTest {
         long idxAfter = fhAfter.getSegmentId();
 
         Assert.assertEquals(idxBefore, idxAfter);
-        Assert.assertTrue(idxAfter >= beforeLastArchivedAbsoluteIndex);
+        Assert.assertTrue(idxAfter >= beforeLastArchivedAbsoluteIdx);
 
-        // Future for await all current available semgment will be archived.
-        CountDownFuture awaitAchviedSegmentsLatch = new CountDownFuture(
-            // One is a last archived, secod is a current write segment.
-            (int)(idxAfter - afterLastArchivedAbsoluteIndex - 2)
-        );
-
-        log.info("currentIdx=" + idxAfter + ", lastArchivedBeforeIdx=" + beforeLastArchivedAbsoluteIndex +
+        log.info("currentIdx=" + idxAfter + ", lastArchivedBeforeIdx=" + beforeLastArchivedAbsoluteIdx +
             ", lastArchivedAfteridx=" + afterLastArchivedAbsoluteIndex + ",  segments=" + segments);
 
-        ig.events().localListen(e -> {
-            WalSegmentArchivedEvent archComplEvt = (WalSegmentArchivedEvent)e;
-
-            log.info("EVT_WAL_SEGMENT_ARCHIVED:" + archComplEvt.getAbsWalSegmentIdx());
-
-            if (archComplEvt.getAbsWalSegmentIdx() > afterLastArchivedAbsoluteIndex){
-                awaitAchviedSegmentsLatch.onDone();
-
-                return true;
-            }
+        // One is a last archived, secod is a current write segment.
+        final long awaitAchviedSegments = idxAfter - afterLastArchivedAbsoluteIndex - 2;
 
-            if (archComplEvt.getAbsWalSegmentIdx() < afterLastArchivedAbsoluteIndex){
-                awaitAchviedSegmentsLatch.onDone(new IgniteException("Unexected segment for archivation. idx="
-                    + archComplEvt.getAbsWalSegmentIdx()));
-
-                return false;
-            }
-
-            return true;
-        }, EVT_WAL_SEGMENT_ARCHIVED);
+        // Await all current available semgment will be archived.
+        assertTrue(GridTestUtils.waitForCondition(
+            new GridAbsPredicate() {
+                @Override public boolean apply() {
+                    long cut = evts.keySet().stream().filter(e -> e > afterLastArchivedAbsoluteIndex).count();
 
-        awaitAchviedSegmentsLatch.get();
+                    return cut >= awaitAchviedSegments;
+                }
+            }, 10_000));
     }
 }


[ignite] 06/17: GG-17344 Idle Verify --cache-filter ALL should include system caches.

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 85643a8babca72c334291ecaaaf236a8c95b1e56
Author: Ilya Kasnacheev <il...@gmail.com>
AuthorDate: Fri Apr 26 14:39:25 2019 +0300

    GG-17344 Idle Verify --cache-filter ALL should include system caches.
    
    Also adds USER and DEFAULT values, improves help messages.
---
 .../internal/commandline/CommandHandler.java       | 22 ++++++++----
 .../internal/commandline/cache/CacheArguments.java |  2 +-
 .../cache/verify/IdleVerifyResultV2.java           |  3 +-
 .../verify/VerifyBackupPartitionsDumpTask.java     | 26 +++++++++++---
 .../cache/verify/VerifyBackupPartitionsTaskV2.java | 36 +++++--------------
 .../internal/visor/verify/CacheFilterEnum.java     | 12 +++++--
 .../visor/verify/VisorIdleVerifyDumpTaskArg.java   |  2 +-
 .../apache/ignite/util/GridCommandHandlerTest.java | 42 ++++++++++++++++++----
 8 files changed, 93 insertions(+), 52 deletions(-)

diff --git a/modules/core/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java
index 2d0fcec..a113141 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java
@@ -180,6 +180,11 @@ import static org.apache.ignite.internal.commandline.cache.argument.ListCommandA
 import static org.apache.ignite.internal.commandline.cache.argument.ListCommandArg.SEQUENCE;
 import static org.apache.ignite.internal.commandline.cache.argument.ValidateIndexesCommandArg.CHECK_FIRST;
 import static org.apache.ignite.internal.commandline.cache.argument.ValidateIndexesCommandArg.CHECK_THROUGH;
+import static org.apache.ignite.internal.visor.verify.CacheFilterEnum.ALL;
+import static org.apache.ignite.internal.visor.verify.CacheFilterEnum.NOT_PERSISTENT;
+import static org.apache.ignite.internal.visor.verify.CacheFilterEnum.PERSISTENT;
+import static org.apache.ignite.internal.visor.verify.CacheFilterEnum.SYSTEM;
+import static org.apache.ignite.internal.visor.verify.CacheFilterEnum.USER;
 import static org.apache.ignite.internal.visor.verify.VisorViewCacheCmd.CACHES;
 import static org.apache.ignite.internal.visor.verify.VisorViewCacheCmd.GROUPS;
 import static org.apache.ignite.internal.visor.verify.VisorViewCacheCmd.SEQ;
@@ -862,8 +867,8 @@ public class CommandHandler {
 
         usageCache(LIST, "regexPattern", op(or(GROUP, SEQUENCE)), OP_NODE_ID, op(CONFIG), op(OUTPUT_FORMAT, MULTI_LINE));
         usageCache(CONTENTION, "minQueueSize", OP_NODE_ID, op("maxPrint"));
-        usageCache(IDLE_VERIFY, op(DUMP), op(SKIP_ZEROS), op(CHECK_CRC),
-            op(EXCLUDE_CACHES, CACHES), op(CACHE_FILTER, or(CacheFilterEnum.values())), op(CACHES));
+        usageCache(IDLE_VERIFY, op(DUMP), op(SKIP_ZEROS), op(CHECK_CRC), op(EXCLUDE_CACHES, CACHES),
+            op(CACHE_FILTER, or(ALL, USER, SYSTEM, PERSISTENT, NOT_PERSISTENT)), op(CACHES));
         usageCache(VALIDATE_INDEXES, op(CACHES), OP_NODE_ID, op(or(CHECK_FIRST + " N", CHECK_THROUGH + " K")));
         usageCache(DISTRIBUTION, or(NODE_ID, NULL), op(CACHES), op(USER_ATTRIBUTES, "attrName1,...,attrNameN"));
         usageCache(RESET_LOST_PARTITIONS, CACHES);
@@ -1927,11 +1932,14 @@ public class CommandHandler {
                 return "Show the keys that are point of contention for multiple transactions.";
 
             case IDLE_VERIFY:
-                return "Verify counters and hash sums of primary and backup partitions for the specified caches/cache groups on an idle cluster and print out the differences, if any. " +
-                    "Cache filtering options configure the set of caches that will be processed by " + IDLE_VERIFY + " command. " +
-                    "Default value for the set of cache names (or cache group names) is all cache groups. Default value for " + EXCLUDE_CACHES + " is empty set. " +
-                    "Default value for " + CACHE_FILTER + " is no filtering. Therefore, the set of all caches is sequently filtered by cache name " +
-                    "regexps, by cache type and after all by exclude regexps.";
+                return "Verify counters and hash sums of primary and backup partitions for the specified caches/cache " +
+                    "groups on an idle cluster and print out the differences, if any. When no parameters are specified, " +
+                    "all user caches are verified. Cache filtering options configure the set of caches that will be " +
+                    "processed by " + IDLE_VERIFY + " command. If cache names are specified, in form of regular " +
+                    "expressions, only matching caches will be verified. Caches matched by regexes specified after " +
+                    EXCLUDE_CACHES + " parameter will be excluded from verification. Using parameter " + CACHE_FILTER +
+                    " you can verify: only " + USER + " caches, only user " + PERSISTENT + " caches, only user " +
+                    NOT_PERSISTENT + " caches, only " + SYSTEM + " caches, or " + ALL + " of the above.";
 
             case VALIDATE_INDEXES:
                 return "Validate indexes on an idle cluster and print out the keys that are missing in the indexes.";
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/commandline/cache/CacheArguments.java b/modules/core/src/main/java/org/apache/ignite/internal/commandline/cache/CacheArguments.java
index d2190d1..7fbf419 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/commandline/cache/CacheArguments.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/commandline/cache/CacheArguments.java
@@ -75,7 +75,7 @@ public class CacheArguments {
     private boolean fullConfig;
 
     /** Cache filter. */
-    private CacheFilterEnum cacheFilterEnum = CacheFilterEnum.ALL;
+    private CacheFilterEnum cacheFilterEnum = CacheFilterEnum.DEFAULT;
 
     /** Check CRC sum on idle verify. */
     private boolean idleCheckCrc;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/IdleVerifyResultV2.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/IdleVerifyResultV2.java
index 3dc5ac3..c583a2f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/IdleVerifyResultV2.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/IdleVerifyResultV2.java
@@ -189,13 +189,14 @@ public class IdleVerifyResultV2 extends VisorDataTransferObject {
     private void print(Consumer<String> printer, boolean printExceptionMessages) {
         boolean noMatchingCaches = false;
 
-        for (Exception e : exceptions.values())
+        for (Exception e : exceptions.values()) {
             if (e instanceof NoMatchingCachesException) {
                 noMatchingCaches = true;
                 succeeded = false;
 
                 break;
             }
+        }
 
         if (succeeded) {
             if (!F.isEmpty(exceptions)) {
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/VerifyBackupPartitionsDumpTask.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/VerifyBackupPartitionsDumpTask.java
index e61b1d2..35a7c717 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/VerifyBackupPartitionsDumpTask.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/VerifyBackupPartitionsDumpTask.java
@@ -37,6 +37,7 @@ import org.apache.ignite.compute.ComputeJobResultPolicy;
 import org.apache.ignite.compute.ComputeTaskAdapter;
 import org.apache.ignite.internal.processors.task.GridInternal;
 import org.apache.ignite.internal.util.typedef.F;
+import org.apache.ignite.internal.visor.verify.CacheFilterEnum;
 import org.apache.ignite.internal.visor.verify.VisorIdleVerifyDumpTaskArg;
 import org.apache.ignite.internal.visor.verify.VisorIdleVerifyTaskArg;
 import org.apache.ignite.resources.IgniteInstanceResource;
@@ -202,13 +203,30 @@ public class VerifyBackupPartitionsDumpTask extends ComputeTaskAdapter<VisorIdle
         int skippedRecords,
         PrintWriter writer
     ) {
-        if (!F.isEmpty(conflictRes.exceptions())) {
-            int size = conflictRes.exceptions().size();
+        Map<ClusterNode, Exception> exceptions = conflictRes.exceptions();
+
+        if (!F.isEmpty(exceptions)) {
+            boolean noMatchingCaches = false;
+
+            for (Exception e : exceptions.values()) {
+                if (e instanceof NoMatchingCachesException) {
+                    noMatchingCaches = true;
+
+                    break;
+                }
+            }
+
+            int size = exceptions.size();
 
             writer.write("idle_verify failed on " + size + " node" + (size == 1 ? "" : "s") + ".\n");
+
+            if (noMatchingCaches)
+                writer.write("There are no caches matching given filter options.");
         }
 
-        writer.write("idle_verify check has finished, found " + partitions.size() + " partitions\n");
+        if (!partitions.isEmpty())
+            writer.write("idle_verify check has finished, found " + partitions.size() + " partitions\n");
+
         writer.write("idle_verify task was executed with the following args: " + taskArgsAsCmd() + "\n");
 
         if (skippedRecords > 0)
@@ -244,7 +262,7 @@ public class VerifyBackupPartitionsDumpTask extends ComputeTaskAdapter<VisorIdle
             }
         }
 
-        if (taskArg.getCacheFilterEnum() != null) {
+        if (taskArg.getCacheFilterEnum() != null && taskArg.getCacheFilterEnum() != CacheFilterEnum.DEFAULT) {
             result.append(CACHE_FILTER);
             result.append(" ");
             result.append(taskArg.getCacheFilterEnum());
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/VerifyBackupPartitionsTaskV2.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/VerifyBackupPartitionsTaskV2.java
index 945d8ef..ce2539f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/VerifyBackupPartitionsTaskV2.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/verify/VerifyBackupPartitionsTaskV2.java
@@ -61,7 +61,6 @@ import org.apache.ignite.internal.util.lang.GridIterator;
 import org.apache.ignite.internal.util.typedef.F;
 import org.apache.ignite.internal.util.typedef.internal.SB;
 import org.apache.ignite.internal.util.typedef.internal.U;
-import org.apache.ignite.internal.visor.verify.CacheFilterEnum;
 import org.apache.ignite.internal.visor.verify.VisorIdleVerifyDumpTaskArg;
 import org.apache.ignite.internal.visor.verify.VisorIdleVerifyTaskArg;
 import org.apache.ignite.lang.IgniteInClosure;
@@ -439,19 +438,7 @@ public class VerifyBackupPartitionsTaskV2 extends ComputeTaskAdapter<VisorIdleVe
          * @param cachesToFilter cache groups to filter
          */
         private void filterByCacheFilter(Set<CacheGroupContext> cachesToFilter) {
-            if (onlySpecificCaches())
-                cachesToFilter.removeIf(grp -> !doesGrpMatchFilter(grp));
-
-            boolean excludeSysCaches;
-
-            if (arg instanceof VisorIdleVerifyDumpTaskArg) {
-                CacheFilterEnum filter = ((VisorIdleVerifyDumpTaskArg) arg).getCacheFilterEnum();
-
-                excludeSysCaches = !(filter == CacheFilterEnum.SYSTEM);
-            } else
-                excludeSysCaches = true;
-
-            cachesToFilter.removeIf(grp -> (grp.systemCache() && excludeSysCaches) || grp.isLocal());
+            cachesToFilter.removeIf(grp -> !doesGrpMatchFilter(grp));
         }
 
         /**
@@ -460,7 +447,7 @@ public class VerifyBackupPartitionsTaskV2 extends ComputeTaskAdapter<VisorIdleVe
          * @param cachesToFilter cache groups to filter
          */
         private void filterByCacheNames(Set<CacheGroupContext> cachesToFilter) {
-            if (arg.getCaches() != null && !arg.getCaches().isEmpty()) {
+            if (!F.isEmpty(arg.getCaches())) {
                 Set<Pattern> cacheNamesPatterns = new HashSet<>();
 
                 for (String cacheNameRegexp : arg.getCaches())
@@ -509,19 +496,6 @@ public class VerifyBackupPartitionsTaskV2 extends ComputeTaskAdapter<VisorIdleVe
         }
 
         /**
-         * @return True if validates only specific caches, else false.
-         */
-        private boolean onlySpecificCaches() {
-            if (arg instanceof VisorIdleVerifyDumpTaskArg) {
-                VisorIdleVerifyDumpTaskArg vdta = (VisorIdleVerifyDumpTaskArg)arg;
-
-                return vdta.getCacheFilterEnum() != CacheFilterEnum.ALL;
-            }
-
-            return false;
-        }
-
-        /**
          * @param desc Cache descriptor.
          */
         private boolean isCacheMatchFilter(DynamicCacheDescriptor desc) {
@@ -533,6 +507,12 @@ public class VerifyBackupPartitionsTaskV2 extends ComputeTaskAdapter<VisorIdleVe
                 VisorIdleVerifyDumpTaskArg vdta = (VisorIdleVerifyDumpTaskArg)arg;
 
                 switch (vdta.getCacheFilterEnum()) {
+                    case DEFAULT:
+                        return desc.cacheType().userCache() || !F.isEmpty(arg.getCaches());
+
+                    case USER:
+                        return desc.cacheType().userCache();
+
                     case SYSTEM:
                         return !desc.cacheType().userCache();
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/verify/CacheFilterEnum.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/verify/CacheFilterEnum.java
index ed221d0..52e2df1 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/verify/CacheFilterEnum.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/verify/CacheFilterEnum.java
@@ -24,8 +24,8 @@ import org.jetbrains.annotations.Nullable;
  * @see org.apache.ignite.internal.processors.cache.verify.VerifyBackupPartitionsTaskV2
  */
 public enum CacheFilterEnum {
-    /** All. */
-    ALL,
+    /** Default - user only, or all caches specified by name. */
+    DEFAULT,
 
     /** System. */
     SYSTEM,
@@ -34,7 +34,13 @@ public enum CacheFilterEnum {
     PERSISTENT,
 
     /** Not persistent. */
-    NOT_PERSISTENT;
+    NOT_PERSISTENT,
+
+    /** User. */
+    USER,
+
+    /** All. */
+    ALL;
 
     /** Enumerated values. */
     private static final CacheFilterEnum[] VALS = values();
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/verify/VisorIdleVerifyDumpTaskArg.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/verify/VisorIdleVerifyDumpTaskArg.java
index a0f99e9..e2ae6bb 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/verify/VisorIdleVerifyDumpTaskArg.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/verify/VisorIdleVerifyDumpTaskArg.java
@@ -115,7 +115,7 @@ public class VisorIdleVerifyDumpTaskArg extends VisorIdleVerifyTaskArg {
             if (protoVer >= V2)
                 cacheFilterEnum = CacheFilterEnum.fromOrdinal(in.readByte());
             else
-                cacheFilterEnum = CacheFilterEnum.ALL;
+                cacheFilterEnum = CacheFilterEnum.DEFAULT;
 
             if (protoVer >= V2)
                 excludeCaches(U.readSet(in));
diff --git a/modules/core/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java b/modules/core/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java
index 1d309d2..59bf8fc 100644
--- a/modules/core/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java
@@ -1347,6 +1347,34 @@ public class GridCommandHandlerTest extends GridCommonAbstractTest {
     }
 
     /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testCacheIdleVerifyNodeFilter() throws Exception {
+        IgniteEx ignite = startGrids(3);
+
+        ignite.cluster().active(true);
+
+        UUID lastNodeId = ignite.localNode().id();
+
+        ignite.createCache(new CacheConfiguration<>(DEFAULT_CACHE_NAME)
+            .setAffinity(new RendezvousAffinityFunction(false, 32))
+            .setNodeFilter(node -> !node.id().equals(lastNodeId))
+            .setBackups(1));
+
+        try (IgniteDataStreamer streamer = ignite.dataStreamer(DEFAULT_CACHE_NAME)) {
+            for (int i = 0; i < 100; i++)
+                streamer.addData(i, i);
+        }
+
+        injectTestSystemOut();
+
+        assertEquals(EXIT_CODE_OK, execute("--cache", "idle_verify", DEFAULT_CACHE_NAME));
+
+        assertContains(testOut.toString(), "no conflicts have been found");
+    }
+
+    /**
      * Tests that both update counter and hash conflicts are detected.
      *
      * @throws Exception If failed.
@@ -1529,13 +1557,13 @@ public class GridCommandHandlerTest extends GridCommonAbstractTest {
 
         testCacheIdleVerifyMultipleCacheFilterOptionsCommon(
             true,
-            "idle_verify check has finished",
+            "idle_verify check has finished, found 100 partitions",
             "idle_verify task was executed with the following args: --cache-filter SYSTEM --exclude-caches wrong.* ",
             "--cache", "idle_verify", "--dump", "--cache-filter", "SYSTEM", "--exclude-caches", "wrong.*"
         );
         testCacheIdleVerifyMultipleCacheFilterOptionsCommon(
             true,
-            "idle_verify check has finished, found 96 partitions",
+            "idle_verify check has finished, found 196 partitions",
             null,
             "--cache", "idle_verify", "--dump", ".*", "--exclude-caches", "wrong.*"
         );
@@ -1555,13 +1583,13 @@ public class GridCommandHandlerTest extends GridCommonAbstractTest {
             true,
             "idle_verify check has finished, found 160 partitions",
             null,
-            "--cache", "idle_verify", "--dump", "shared.*,wrong.*", "--cache-filter", "ALL"
+            "--cache", "idle_verify", "--dump", "shared.*,wrong.*", "--cache-filter", "USER"
         );
         testCacheIdleVerifyMultipleCacheFilterOptionsCommon(
             true,
-            "idle_verify check has finished, found 160 partitions",
+            "There are no caches matching given filter options.",
             null,
-            "--cache", "idle_verify", "--dump", "shared.*,wrong.*", "--cache-filter", "ALL"
+            "--cache", "idle_verify", "--dump", "shared.*,wrong.*", "--cache-filter", "SYSTEM"
         );
         testCacheIdleVerifyMultipleCacheFilterOptionsCommon(
             true,
@@ -1579,7 +1607,7 @@ public class GridCommandHandlerTest extends GridCommonAbstractTest {
             true,
             "idle_verify check has finished, no conflicts have been found.",
             null,
-            "--cache", "idle_verify", ".*", "--exclude-caches", "wrong-.*"
+            "--cache", "idle_verify", ".*", "--exclude-caches", "wrong-.*", "--cache-filter", "DEFAULT"
         );
         testCacheIdleVerifyMultipleCacheFilterOptionsCommon(
             true,
@@ -2088,7 +2116,7 @@ public class GridCommandHandlerTest extends GridCommonAbstractTest {
         if (fileNameMatcher.find()) {
             String dumpWithConflicts = new String(Files.readAllBytes(Paths.get(fileNameMatcher.group(1))));
 
-            assertTrue(dumpWithConflicts.contains("idle_verify check has finished, found 0 partitions"));
+            assertTrue(dumpWithConflicts.contains("There are no caches matching given filter options."));
         }
         else
             fail("Should be found dump with conflicts");


[ignite] 08/17: GG-17405 Fix of wrong commit.

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit c247d5b181c6c2ccdc638102befe51f946ba5016
Author: Andrey Novikov <an...@gridgain.com>
AuthorDate: Fri Apr 26 21:02:17 2019 +0700

    GG-17405 Fix of wrong commit.
---
 pom.xml | 6 +++---
 1 file changed, 3 insertions(+), 3 deletions(-)

diff --git a/pom.xml b/pom.xml
index 50de0d3..d52098e 100644
--- a/pom.xml
+++ b/pom.xml
@@ -396,15 +396,15 @@
                                             <include name="**/*.sh" />
                                         </fixcrlf>
 
-                                        <zip destfile="${basedir}/target/bin/${ignite.edition}-${project.version}.zip" encoding="UTF-8">
-                                            <zipfileset dir="${basedir}/target/release-package-${ignite.edition}" prefix="${ignite.edition}-${project.version}" filemode="755">
+                                        <zip destfile="${basedir}/target/bin/${ignite.edition}-${project.version}-bin.zip" encoding="UTF-8">
+                                            <zipfileset dir="${basedir}/target/release-package-${ignite.edition}" prefix="${ignite.edition}-${project.version}-bin" filemode="755">
                                                 <include name="**/*.sh" />
                                                 <include name="**/configure" />
                                                 <include name="**/install-sh" />
                                                 <include name="**/compile" />
                                                 <include name="**/missing" />
                                             </zipfileset>
-                                            <zipfileset dir="${basedir}/target/release-package-${ignite.edition}" prefix="${ignite.edition}-${project.version}">
+                                            <zipfileset dir="${basedir}/target/release-package-${ignite.edition}" prefix="${ignite.edition}-${project.version}-bin">
                                                 <exclude name="**/*.sh" />
                                                 <exclude name="**/configure" />
                                                 <exclude name="**/install-sh" />


[ignite] 12/17: GG-17480 Implement WAL page snapshot records compression - Fixes #6116.

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit b1a355a2b4df6082da4d93a11d9253eacd9af036
Author: Aleksey Plekhanov <pl...@gmail.com>
AuthorDate: Mon Apr 29 13:21:49 2019 +0300

    GG-17480 Implement WAL page snapshot records compression - Fixes #6116.
    
    Signed-off-by: Dmitriy Govorukhin <dm...@gmail.com>
    
    (cherry picked from commit 2ad6c85)
---
 modules/compress/pom.xml                           |  15 ++
 .../compress/CompressionProcessorImpl.java         | 100 +++++++---
 ...ionWithRealCpDisabledAndWalCompressionTest.java |  37 ++++
 .../wal/WalCompactionAndPageCompressionTest.java   |  35 ++++
 .../WalRecoveryWithPageCompressionAndTdeTest.java  |  51 ++++++
 .../db/wal/WalRecoveryWithPageCompressionTest.java |  36 ++++
 .../AbstractPageCompressionIntegrationTest.java    | 201 +++++++++++++++++++++
 .../DiskPageCompressionIntegrationTest.java        | 171 +-----------------
 .../WalPageCompressionIntegrationTest.java         | 101 +++++++++++
 .../testsuites/IgnitePdsCompressionTestSuite.java  |  12 ++
 .../ignite/configuration/CacheConfiguration.java   |   5 +-
 .../configuration/DataStorageConfiguration.java    |  53 ++++++
 .../ignite/configuration/DiskPageCompression.java  |   5 +
 .../internal/pagemem/wal/record/PageSnapshot.java  |  76 ++++++--
 .../processors/cache/CacheCompressionManager.java  |  10 +-
 .../GridCacheDatabaseSharedManager.java            |   9 +
 .../cache/persistence/file/FilePageStore.java      |   4 +
 .../cache/persistence/pagemem/PageMemoryImpl.java  |  11 +-
 .../cache/persistence/tree/io/PageIO.java          |  38 +++-
 .../persistence/wal/FileWriteAheadLogManager.java  |  43 +++++
 .../wal/serializer/RecordDataSerializer.java       |   3 +-
 .../wal/serializer/RecordDataV1Serializer.java     |  17 +-
 .../wal/serializer/RecordDataV2Serializer.java     |  17 +-
 .../wal/serializer/RecordV1Serializer.java         |   2 +-
 .../wal/serializer/RecordV2Serializer.java         |   3 +-
 .../processors/compress/CompressionProcessor.java  |  11 +-
 .../platform/utils/PlatformConfigurationUtils.java |  15 ++
 .../processors/cache/persistence/DummyPageIO.java  |   4 +
 ...CheckpointSimulationWithRealCpDisabledTest.java |  25 ++-
 .../persistence/db/wal/WalCompactionTest.java      |  26 ++-
 .../wal/memtracker/PageMemoryTracker.java          |   3 +-
 .../persistence/db/wal/IgniteWalRecoveryTest.java  |  71 ++++++--
 .../Config/full-config.xml                         |   3 +-
 .../IgniteConfigurationSerializerTest.cs           |   3 +
 .../Apache.Ignite.Core/Apache.Ignite.Core.csproj   |   1 +
 .../Configuration/DataStorageConfiguration.cs      |  22 ++-
 .../Configuration/DiskPageCompression.cs           |  50 +++++
 .../IgniteConfigurationSection.xsd                 |  20 ++
 38 files changed, 1049 insertions(+), 260 deletions(-)

diff --git a/modules/compress/pom.xml b/modules/compress/pom.xml
index a7f77de..bdcd924 100644
--- a/modules/compress/pom.xml
+++ b/modules/compress/pom.xml
@@ -42,6 +42,21 @@
         </dependency>
 
         <dependency>
+            <groupId>org.apache.ignite</groupId>
+            <artifactId>ignite-indexing</artifactId>
+            <type>test-jar</type>
+            <scope>test</scope>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.ignite</groupId>
+            <artifactId>ignite-indexing</artifactId>
+            <scope>test</scope>
+            <version>${project.version}</version>
+        </dependency>
+
+        <dependency>
             <groupId>com.github.jnr</groupId>
             <artifactId>jnr-posix</artifactId>
             <version>${jnr.posix.version}</version>
diff --git a/modules/compress/src/main/java/org/apache/ignite/internal/processors/compress/CompressionProcessorImpl.java b/modules/compress/src/main/java/org/apache/ignite/internal/processors/compress/CompressionProcessorImpl.java
index a89f67a..6d1b95f 100644
--- a/modules/compress/src/main/java/org/apache/ignite/internal/processors/compress/CompressionProcessorImpl.java
+++ b/modules/compress/src/main/java/org/apache/ignite/internal/processors/compress/CompressionProcessorImpl.java
@@ -27,8 +27,10 @@ import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.IgniteException;
 import org.apache.ignite.configuration.DiskPageCompression;
 import org.apache.ignite.internal.GridKernalContext;
+import org.apache.ignite.internal.pagemem.PageUtils;
 import org.apache.ignite.internal.processors.cache.persistence.tree.io.CompactablePageIO;
 import org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO;
+import org.apache.ignite.internal.util.GridUnsafe;
 import org.apache.ignite.internal.util.typedef.internal.U;
 import org.xerial.snappy.Snappy;
 
@@ -63,6 +65,11 @@ public class CompressionProcessorImpl extends CompressionProcessor {
     }
 
     /** {@inheritDoc} */
+    @Override public void checkPageCompressionSupported() throws IgniteCheckedException {
+        // No-op.
+    }
+
+    /** {@inheritDoc} */
     @Override public void checkPageCompressionSupported(Path storagePath, int pageSize) throws IgniteCheckedException {
         if (!U.isLinux())
             throw new IgniteCheckedException("Currently page compression is supported only for Linux.");
@@ -92,46 +99,74 @@ public class CompressionProcessorImpl extends CompressionProcessor {
         DiskPageCompression compression,
         int compressLevel
     ) throws IgniteCheckedException {
-        assert compression != null;
-        assert U.isPow2(pageSize): pageSize;
+        assert compression != null && compression != DiskPageCompression.DISABLED : compression;
         assert U.isPow2(blockSize): blockSize;
-        assert page.position() == 0 && page.limit() == pageSize;
+        assert page.position() == 0 && page.limit() >= pageSize;
 
-        PageIO io = PageIO.getPageIO(page);
+        int oldPageLimit = page.limit();
 
-        if (!(io instanceof CompactablePageIO))
-            return page;
+        try {
+            // Page size will be less than page limit when TDE is enabled. To make compaction and compression work
+            // correctly we need to set limit to real page size.
+            page.limit(pageSize);
 
-        ByteBuffer compactPage = compactBuf.get();
+            ByteBuffer compactPage = doCompactPage(page, pageSize);
 
-        // Drop the garbage from the page.
-        ((CompactablePageIO)io).compactPage(page, compactPage, pageSize);
-        page.clear();
+            int compactSize = compactPage.limit();
 
-        int compactSize = compactPage.limit();
+            assert compactSize <= pageSize : compactSize;
 
-        assert compactSize <= pageSize: compactSize;
+            // If no need to compress further or configured just to skip garbage.
+            if (compactSize < blockSize || compression == SKIP_GARBAGE)
+                return setCompactionInfo(compactPage, compactSize);
+
+            ByteBuffer compressedPage = doCompressPage(compression, compactPage, compactSize, compressLevel);
+
+            assert compressedPage.position() == 0;
+            int compressedSize = compressedPage.limit();
+
+            int freeCompactBlocks = (pageSize - compactSize) / blockSize;
+            int freeCompressedBlocks = (pageSize - compressedSize) / blockSize;
+
+            if (freeCompactBlocks >= freeCompressedBlocks) {
+                if (freeCompactBlocks == 0)
+                    return page; // No blocks will be released.
+
+                return setCompactionInfo(compactPage, compactSize);
+            }
 
-        // If no need to compress further or configured just to skip garbage.
-        if (compactSize < blockSize || compression == SKIP_GARBAGE)
-            return setCompactionInfo(compactPage, compactSize);
+            return setCompressionInfo(compressedPage, compression, compressedSize, compactSize);
+        }
+        finally {
+            page.limit(oldPageLimit);
+        }
+    }
 
-        ByteBuffer compressedPage = doCompressPage(compression, compactPage, compactSize, compressLevel);
+    /**
+     * @param page Page buffer.
+     * @param pageSize Page size.
+     * @return Compacted page buffer.
+     */
+    private ByteBuffer doCompactPage(ByteBuffer page, int pageSize) throws IgniteCheckedException {
+        PageIO io = PageIO.getPageIO(page);
 
-        assert compressedPage.position() == 0;
-        int compressedSize = compressedPage.limit();
+        ByteBuffer compactPage = compactBuf.get();
 
-        int freeCompactBlocks = (pageSize - compactSize) / blockSize;
-        int freeCompressedBlocks = (pageSize - compressedSize) / blockSize;
+        if (io instanceof CompactablePageIO) {
+            // Drop the garbage from the page.
+            ((CompactablePageIO)io).compactPage(page, compactPage, pageSize);
+        }
+        else {
+            // Direct buffer is required as output of this method.
+            if (page.isDirect())
+                return page;
 
-        if (freeCompactBlocks >= freeCompressedBlocks) {
-            if (freeCompactBlocks == 0)
-                return page; // No blocks will be released.
+            PageUtils.putBytes(GridUnsafe.bufferAddress(compactPage), 0, page.array());
 
-            return setCompactionInfo(compactPage, compactSize);
+            compactPage.limit(pageSize);
         }
 
-        return setCompressionInfo(compressedPage, compression, compressedSize, compactSize);
+        return compactPage;
     }
 
     /**
@@ -260,7 +295,7 @@ public class CompressionProcessorImpl extends CompressionProcessor {
      * @return Level.
      */
     private static byte getCompressionType(DiskPageCompression compression) {
-        if (compression == null)
+        if (compression == DiskPageCompression.DISABLED)
             return UNCOMPRESSED_PAGE;
 
         switch (compression) {
@@ -281,7 +316,7 @@ public class CompressionProcessorImpl extends CompressionProcessor {
 
     /** {@inheritDoc} */
     @Override public void decompressPage(ByteBuffer page, int pageSize) throws IgniteCheckedException {
-        assert page.capacity() == pageSize;
+        assert page.capacity() >= pageSize : "capacity=" + page.capacity() + ", pageSize=" + pageSize;
 
         byte compressType = PageIO.getCompressionType(page);
 
@@ -338,11 +373,16 @@ public class CompressionProcessorImpl extends CompressionProcessor {
             assert page.limit() == compactSize;
         }
 
-        CompactablePageIO io = PageIO.getPageIO(page);
+        PageIO io = PageIO.getPageIO(page);
 
-        io.restorePage(page, pageSize);
+        if (io instanceof CompactablePageIO)
+            ((CompactablePageIO)io).restorePage(page, pageSize);
+        else {
+            assert compactSize == pageSize
+                : "Wrong compacted page size [compactSize=" + compactSize + ", pageSize=" + pageSize + ']';
+        }
 
-        setCompressionInfo(page, null, 0, 0);
+        setCompressionInfo(page, DiskPageCompression.DISABLED, 0, 0);
     }
 
     /** */
diff --git a/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgnitePdsCheckpointSimulationWithRealCpDisabledAndWalCompressionTest.java b/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgnitePdsCheckpointSimulationWithRealCpDisabledAndWalCompressionTest.java
new file mode 100644
index 0000000..48416b4
--- /dev/null
+++ b/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgnitePdsCheckpointSimulationWithRealCpDisabledAndWalCompressionTest.java
@@ -0,0 +1,37 @@
+/*
+* Licensed to the Apache Software Foundation (ASF) under one or more
+* contributor license agreements.  See the NOTICE file distributed with
+* this work for additional information regarding copyright ownership.
+* The ASF licenses this file to You under the Apache License, Version 2.0
+* (the "License"); you may not use this file except in compliance with
+* the License.  You may obtain a copy of the License at
+*
+*      http://www.apache.org/licenses/LICENSE-2.0
+*
+* Unless required by applicable law or agreed to in writing, software
+* distributed under the License is distributed on an "AS IS" BASIS,
+* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+* See the License for the specific language governing permissions and
+* limitations under the License.
+*/
+
+package org.apache.ignite.internal.processors.cache.persistence.db.wal;
+
+import org.apache.ignite.configuration.DiskPageCompression;
+import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.internal.processors.cache.persistence.db.file.IgnitePdsCheckpointSimulationWithRealCpDisabledTest;
+
+/**
+ *
+ */
+public class IgnitePdsCheckpointSimulationWithRealCpDisabledAndWalCompressionTest
+    extends IgnitePdsCheckpointSimulationWithRealCpDisabledTest {
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration getConfiguration(String gridName) throws Exception {
+        IgniteConfiguration cfg = super.getConfiguration(gridName);
+
+        cfg.getDataStorageConfiguration().setWalPageCompression(DiskPageCompression.SNAPPY);
+
+        return cfg;
+    }
+}
diff --git a/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalCompactionAndPageCompressionTest.java b/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalCompactionAndPageCompressionTest.java
new file mode 100644
index 0000000..01e2040
--- /dev/null
+++ b/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalCompactionAndPageCompressionTest.java
@@ -0,0 +1,35 @@
+/*
+* Licensed to the Apache Software Foundation (ASF) under one or more
+* contributor license agreements.  See the NOTICE file distributed with
+* this work for additional information regarding copyright ownership.
+* The ASF licenses this file to You under the Apache License, Version 2.0
+* (the "License"); you may not use this file except in compliance with
+* the License.  You may obtain a copy of the License at
+*
+*      http://www.apache.org/licenses/LICENSE-2.0
+*
+* Unless required by applicable law or agreed to in writing, software
+* distributed under the License is distributed on an "AS IS" BASIS,
+* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+* See the License for the specific language governing permissions and
+* limitations under the License.
+*/
+
+package org.apache.ignite.internal.processors.cache.persistence.db.wal;
+
+import org.apache.ignite.configuration.DiskPageCompression;
+import org.apache.ignite.configuration.IgniteConfiguration;
+
+/**
+ *
+ */
+public class WalCompactionAndPageCompressionTest extends WalCompactionTest {
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration getConfiguration(String gridName) throws Exception {
+        IgniteConfiguration cfg = super.getConfiguration(gridName);
+
+        cfg.getDataStorageConfiguration().setWalPageCompression(DiskPageCompression.SNAPPY);
+
+        return cfg;
+    }
+}
diff --git a/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalRecoveryWithPageCompressionAndTdeTest.java b/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalRecoveryWithPageCompressionAndTdeTest.java
new file mode 100644
index 0000000..07c1312
--- /dev/null
+++ b/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalRecoveryWithPageCompressionAndTdeTest.java
@@ -0,0 +1,51 @@
+/*
+* Licensed to the Apache Software Foundation (ASF) under one or more
+* contributor license agreements.  See the NOTICE file distributed with
+* this work for additional information regarding copyright ownership.
+* The ASF licenses this file to You under the Apache License, Version 2.0
+* (the "License"); you may not use this file except in compliance with
+* the License.  You may obtain a copy of the License at
+*
+*      http://www.apache.org/licenses/LICENSE-2.0
+*
+* Unless required by applicable law or agreed to in writing, software
+* distributed under the License is distributed on an "AS IS" BASIS,
+* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+* See the License for the specific language governing permissions and
+* limitations under the License.
+*/
+
+package org.apache.ignite.internal.processors.cache.persistence.db.wal;
+
+import org.apache.ignite.configuration.CacheConfiguration;
+import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.internal.encryption.AbstractEncryptionTest;
+import org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi;
+
+/**
+ *
+ */
+public class WalRecoveryWithPageCompressionAndTdeTest extends WalRecoveryWithPageCompressionTest {
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration getConfiguration(String gridName) throws Exception {
+        IgniteConfiguration cfg = super.getConfiguration(gridName);
+
+        for (CacheConfiguration<?, ?> ccfg : cfg.getCacheConfiguration())
+            ccfg.setEncryptionEnabled(true);
+
+        KeystoreEncryptionSpi encSpi = new KeystoreEncryptionSpi();
+
+        encSpi.setKeyStorePath(AbstractEncryptionTest.KEYSTORE_PATH);
+        encSpi.setKeyStorePassword(AbstractEncryptionTest.KEYSTORE_PASSWORD.toCharArray());
+
+        cfg.setEncryptionSpi(encSpi);
+
+        return cfg;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void testWalRenameDirSimple() throws Exception {
+        // Ignore this test when TDE is enabled, since there is internal cache group id change without corresponding
+        // encryption keys change.
+    }
+}
diff --git a/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalRecoveryWithPageCompressionTest.java b/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalRecoveryWithPageCompressionTest.java
new file mode 100644
index 0000000..aaf4b25
--- /dev/null
+++ b/modules/compress/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalRecoveryWithPageCompressionTest.java
@@ -0,0 +1,36 @@
+/*
+* Licensed to the Apache Software Foundation (ASF) under one or more
+* contributor license agreements.  See the NOTICE file distributed with
+* this work for additional information regarding copyright ownership.
+* The ASF licenses this file to You under the Apache License, Version 2.0
+* (the "License"); you may not use this file except in compliance with
+* the License.  You may obtain a copy of the License at
+*
+*      http://www.apache.org/licenses/LICENSE-2.0
+*
+* Unless required by applicable law or agreed to in writing, software
+* distributed under the License is distributed on an "AS IS" BASIS,
+* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+* See the License for the specific language governing permissions and
+* limitations under the License.
+*/
+
+package org.apache.ignite.internal.processors.cache.persistence.db.wal;
+
+import org.apache.ignite.configuration.DiskPageCompression;
+import org.apache.ignite.testframework.junits.WithSystemProperty;
+
+import static org.apache.ignite.IgniteSystemProperties.IGNITE_DEFAULT_DISK_PAGE_COMPRESSION;
+
+/**
+ * WAL recovery test with WAL page compression enabled and PDS disk page compression disabled.
+ */
+@WithSystemProperty(key = IGNITE_DEFAULT_DISK_PAGE_COMPRESSION, value = "DISABLED")
+public class WalRecoveryWithPageCompressionTest extends IgniteWalRecoveryTest {
+    /** {@inheritDoc} */
+    @Override protected void beforeTest() throws Exception {
+        super.beforeTest();
+
+        walPageCompression = DiskPageCompression.ZSTD;
+    }
+}
diff --git a/modules/compress/src/test/java/org/apache/ignite/internal/processors/compress/AbstractPageCompressionIntegrationTest.java b/modules/compress/src/test/java/org/apache/ignite/internal/processors/compress/AbstractPageCompressionIntegrationTest.java
new file mode 100644
index 0000000..31d838d
--- /dev/null
+++ b/modules/compress/src/test/java/org/apache/ignite/internal/processors/compress/AbstractPageCompressionIntegrationTest.java
@@ -0,0 +1,201 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal.processors.compress;
+
+import java.io.Serializable;
+import java.util.UUID;
+import org.apache.ignite.cache.query.annotations.QuerySqlField;
+import org.apache.ignite.configuration.DiskPageCompression;
+import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.junit.Test;
+
+import static org.apache.ignite.configuration.DiskPageCompression.LZ4;
+import static org.apache.ignite.configuration.DiskPageCompression.SKIP_GARBAGE;
+import static org.apache.ignite.configuration.DiskPageCompression.SNAPPY;
+import static org.apache.ignite.configuration.DiskPageCompression.ZSTD;
+import static org.apache.ignite.internal.processors.compress.CompressionProcessor.LZ4_DEFAULT_LEVEL;
+import static org.apache.ignite.internal.processors.compress.CompressionProcessor.LZ4_MAX_LEVEL;
+import static org.apache.ignite.internal.processors.compress.CompressionProcessor.LZ4_MIN_LEVEL;
+import static org.apache.ignite.internal.processors.compress.CompressionProcessor.ZSTD_MAX_LEVEL;
+import static org.apache.ignite.internal.processors.compress.CompressionProcessor.ZSTD_MIN_LEVEL;
+
+/**
+ *
+ */
+public abstract class AbstractPageCompressionIntegrationTest extends GridCommonAbstractTest {
+    /** */
+    protected DiskPageCompression compression;
+
+    /** */
+    protected Integer compressionLevel;
+
+    /** {@inheritDoc} */
+    @Override protected void beforeTest() throws Exception {
+        compression = DiskPageCompression.DISABLED;
+        compressionLevel = null;
+
+        cleanPersistenceDir();
+    }
+
+    /** {@inheritDoc} */
+    @Override protected void afterTest() throws Exception {
+        stopAllGrids(true);
+
+        cleanPersistenceDir();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testPageCompression_Zstd_Max() throws Exception {
+        compression = ZSTD;
+        compressionLevel = ZSTD_MAX_LEVEL;
+
+        doTestPageCompression();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testPageCompression_Zstd_Default() throws Exception {
+        compression = ZSTD;
+        compressionLevel = null;
+
+        doTestPageCompression();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testPageCompression_Zstd_Min() throws Exception {
+        compression = ZSTD;
+        compressionLevel = ZSTD_MIN_LEVEL;
+
+        doTestPageCompression();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testPageCompression_Lz4_Max() throws Exception {
+        compression = LZ4;
+        compressionLevel = LZ4_MAX_LEVEL;
+
+        doTestPageCompression();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testPageCompression_Lz4_Default() throws Exception {
+        compression = LZ4;
+        compressionLevel = null;
+
+        doTestPageCompression();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testPageCompression_Lz4_Min() throws Exception {
+        assertEquals(LZ4_MIN_LEVEL, LZ4_DEFAULT_LEVEL);
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testPageCompression_SkipGarbage() throws Exception {
+        compression = SKIP_GARBAGE;
+
+        doTestPageCompression();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testPageCompression_Snappy() throws Exception {
+        compression = SNAPPY;
+
+        doTestPageCompression();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    protected abstract void doTestPageCompression() throws Exception;
+
+    /**
+     *
+     */
+    static class TestVal implements Serializable {
+        /** */
+        static final long serialVersionUID = 1L;
+
+        /** */
+        @QuerySqlField
+        String str;
+
+        /** */
+        int i;
+
+        /** */
+        @QuerySqlField
+        long x;
+
+        /** */
+        @QuerySqlField
+        UUID id;
+
+        TestVal(int i) {
+            this.str =  i + "bla bla bla!";
+            this.i = -i;
+            this.x = 0xffaabbccdd773311L + i;
+            this.id = new UUID(i,-i);
+        }
+
+        /** {@inheritDoc} */
+        @Override public boolean equals(Object o) {
+            if (this == o) return true;
+            if (o == null || getClass() != o.getClass()) return false;
+
+            TestVal testVal = (TestVal)o;
+
+            if (i != testVal.i) return false;
+            if (x != testVal.x) return false;
+            if (str != null ? !str.equals(testVal.str) : testVal.str != null) return false;
+            return id != null ? id.equals(testVal.id) : testVal.id == null;
+        }
+
+        /** {@inheritDoc} */
+        @Override public int hashCode() {
+            int result = str != null ? str.hashCode() : 0;
+            result = 31 * result + i;
+            result = 31 * result + (int)(x ^ (x >>> 32));
+            result = 31 * result + (id != null ? id.hashCode() : 0);
+            return result;
+        }
+    }
+}
diff --git a/modules/compress/src/test/java/org/apache/ignite/internal/processors/compress/DiskPageCompressionIntegrationTest.java b/modules/compress/src/test/java/org/apache/ignite/internal/processors/compress/DiskPageCompressionIntegrationTest.java
index 0158828..865ab22 100644
--- a/modules/compress/src/test/java/org/apache/ignite/internal/processors/compress/DiskPageCompressionIntegrationTest.java
+++ b/modules/compress/src/test/java/org/apache/ignite/internal/processors/compress/DiskPageCompressionIntegrationTest.java
@@ -18,21 +18,17 @@ package org.apache.ignite.internal.processors.compress;
 
 import java.io.File;
 import java.io.IOException;
-import java.io.Serializable;
 import java.nio.ByteBuffer;
 import java.nio.file.OpenOption;
 import java.util.Objects;
-import java.util.UUID;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteException;
 import org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction;
-import org.apache.ignite.cache.query.annotations.QuerySqlField;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.DataRegionConfiguration;
 import org.apache.ignite.configuration.DataStorageConfiguration;
-import org.apache.ignite.configuration.DiskPageCompression;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.internal.IgniteEx;
 import org.apache.ignite.internal.pagemem.store.PageStore;
@@ -46,47 +42,19 @@ import org.apache.ignite.internal.processors.cache.persistence.file.FilePageStor
 import org.apache.ignite.internal.processors.cache.persistence.file.RandomAccessFileIOFactory;
 import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.mxbean.CacheGroupMetricsMXBean;
-import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
-import org.junit.Test;
 
 import static org.apache.ignite.cache.CacheAtomicityMode.ATOMIC;
 import static org.apache.ignite.configuration.DataStorageConfiguration.MAX_PAGE_SIZE;
-import static org.apache.ignite.configuration.DiskPageCompression.LZ4;
-import static org.apache.ignite.configuration.DiskPageCompression.SKIP_GARBAGE;
-import static org.apache.ignite.configuration.DiskPageCompression.SNAPPY;
 import static org.apache.ignite.configuration.DiskPageCompression.ZSTD;
-import static org.apache.ignite.internal.processors.compress.CompressionProcessor.LZ4_DEFAULT_LEVEL;
-import static org.apache.ignite.internal.processors.compress.CompressionProcessor.LZ4_MAX_LEVEL;
-import static org.apache.ignite.internal.processors.compress.CompressionProcessor.LZ4_MIN_LEVEL;
-import static org.apache.ignite.internal.processors.compress.CompressionProcessor.ZSTD_MAX_LEVEL;
-import static org.apache.ignite.internal.processors.compress.CompressionProcessor.ZSTD_MIN_LEVEL;
 
 /**
  *
  */
-public class DiskPageCompressionIntegrationTest extends GridCommonAbstractTest {
-    /** */
-    private DiskPageCompression compression;
-
-    /** */
-    private Integer compressionLevel;
-
+public class DiskPageCompressionIntegrationTest extends AbstractPageCompressionIntegrationTest {
     /** */
     private FileIOFactory factory;
 
     /** {@inheritDoc} */
-    @Override protected void beforeTest() throws Exception {
-        compression = null;
-        compressionLevel = null;
-        cleanPersistenceDir();
-    }
-
-    /** {@inheritDoc} */
-    @Override protected void afterTest() throws Exception {
-        stopAllGrids(true);
-    }
-
-    /** {@inheritDoc} */
     @Override protected IgniteConfiguration getConfiguration(String igniteName) throws Exception {
         DataRegionConfiguration drCfg = new DataRegionConfiguration()
             .setPersistenceEnabled(true);
@@ -112,90 +80,8 @@ public class DiskPageCompressionIntegrationTest extends GridCommonAbstractTest {
     /**
      * @throws Exception If failed.
      */
-    @Test
-    public void testPageCompression_Zstd_Max() throws Exception {
-        compression = ZSTD;
-        compressionLevel = ZSTD_MAX_LEVEL;
-
-        doTestPageCompression();
-    }
-
-    /**
-     * @throws Exception If failed.
-     */
-    @Test
-    public void testPageCompression_Zstd_Default() throws Exception {
-        compression = ZSTD;
-        compressionLevel = null;
-
-        doTestPageCompression();
-    }
-
-    /**
-     * @throws Exception If failed.
-     */
-    @Test
-    public void testPageCompression_Zstd_Min() throws Exception {
-        compression = ZSTD;
-        compressionLevel = ZSTD_MIN_LEVEL;
-
-        doTestPageCompression();
-    }
-
-    /**
-     * @throws Exception If failed.
-     */
-    @Test
-    public void testPageCompression_Lz4_Max() throws Exception {
-        compression = LZ4;
-        compressionLevel = LZ4_MAX_LEVEL;
-
-        doTestPageCompression();
-    }
-
-    /**
-     * @throws Exception If failed.
-     */
-    @Test
-    public void testPageCompression_Lz4_Default() throws Exception {
-        compression = LZ4;
-        compressionLevel = null;
-
-        doTestPageCompression();
-    }
-
-    /**
-     * @throws Exception If failed.
-     */
-    @Test
-    public void testPageCompression_Lz4_Min() throws Exception {
-        assertEquals(LZ4_MIN_LEVEL, LZ4_DEFAULT_LEVEL);
-    }
-
-    /**
-     * @throws Exception If failed.
-     */
-    @Test
-    public void testPageCompression_SkipGarbage() throws Exception {
-        compression = SKIP_GARBAGE;
-
-        doTestPageCompression();
-    }
-
-    /**
-     * @throws Exception If failed.
-     */
-    @Test
-    public void testPageCompression_Snappy() throws Exception {
-        compression = SNAPPY;
-
-        doTestPageCompression();
-    }
-
-    /**
-     * @throws Exception If failed.
-     */
-    private void doTestPageCompression() throws Exception {
+    @Override
+    protected void doTestPageCompression() throws Exception {
         IgniteEx ignite = startGrid(0);
 
         ignite.cluster().active(true);
@@ -342,57 +228,6 @@ public class DiskPageCompressionIntegrationTest extends GridCommonAbstractTest {
 
     /**
      */
-    static class TestVal implements Serializable {
-        /** */
-        static final long serialVersionUID = 1L;
-
-        /** */
-        @QuerySqlField
-        String str;
-
-        /** */
-        int i;
-
-        /** */
-        @QuerySqlField
-        long x;
-
-        /** */
-        @QuerySqlField
-        UUID id;
-
-        TestVal(int i) {
-            this.str =  i + "bla bla bla!";
-            this.i = -i;
-            this.x = 0xffaabbccdd773311L + i;
-            this.id = new UUID(i,-i);
-        }
-
-        /** {@inheritDoc} */
-        @Override public boolean equals(Object o) {
-            if (this == o) return true;
-            if (o == null || getClass() != o.getClass()) return false;
-
-            TestVal testVal = (TestVal)o;
-
-            if (i != testVal.i) return false;
-            if (x != testVal.x) return false;
-            if (str != null ? !str.equals(testVal.str) : testVal.str != null) return false;
-            return id != null ? id.equals(testVal.id) : testVal.id == null;
-        }
-
-        /** {@inheritDoc} */
-        @Override public int hashCode() {
-            int result = str != null ? str.hashCode() : 0;
-            result = 31 * result + i;
-            result = 31 * result + (int)(x ^ (x >>> 32));
-            result = 31 * result + (id != null ? id.hashCode() : 0);
-            return result;
-        }
-    }
-
-    /**
-     */
     static class PunchFileIO extends FileIODecorator {
         /** */
         private ConcurrentMap<Long, Integer> holes = new ConcurrentHashMap<>();
diff --git a/modules/compress/src/test/java/org/apache/ignite/internal/processors/compress/WalPageCompressionIntegrationTest.java b/modules/compress/src/test/java/org/apache/ignite/internal/processors/compress/WalPageCompressionIntegrationTest.java
new file mode 100644
index 0000000..c16f9e4
--- /dev/null
+++ b/modules/compress/src/test/java/org/apache/ignite/internal/processors/compress/WalPageCompressionIntegrationTest.java
@@ -0,0 +1,101 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal.processors.compress;
+
+import org.apache.ignite.IgniteCache;
+import org.apache.ignite.configuration.CacheConfiguration;
+import org.apache.ignite.configuration.DataRegionConfiguration;
+import org.apache.ignite.configuration.DataStorageConfiguration;
+import org.apache.ignite.configuration.DiskPageCompression;
+import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.internal.IgniteEx;
+import org.apache.ignite.internal.pagemem.wal.record.CheckpointRecord;
+import org.apache.ignite.internal.processors.cache.persistence.wal.FileWALPointer;
+import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
+import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
+
+import static org.apache.ignite.cache.CacheAtomicityMode.ATOMIC;
+
+/**
+ *
+ */
+public class WalPageCompressionIntegrationTest extends AbstractPageCompressionIntegrationTest {
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration getConfiguration(String igniteName) throws Exception {
+        DataStorageConfiguration dsCfg = new DataStorageConfiguration()
+            .setDefaultDataRegionConfiguration(new DataRegionConfiguration().setPersistenceEnabled(true))
+            .setWalPageCompression(compression)
+            .setWalPageCompressionLevel(compressionLevel);
+
+        return super.getConfiguration(igniteName)
+            .setDataStorageConfiguration(dsCfg)
+            // Set new IP finder for each node to start independent clusters.
+            .setDiscoverySpi(new TcpDiscoverySpi().setIpFinder(new TcpDiscoveryVmIpFinder(true)));
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Override
+    protected void doTestPageCompression() throws Exception {
+        // Ignite instance with compressed WAL page records.
+        IgniteEx ignite0 = startGrid(0);
+
+        compression = DiskPageCompression.DISABLED;
+        compressionLevel = null;
+
+        // Reference ignite instance with uncompressed WAL page records.
+        IgniteEx ignite1 = startGrid(1);
+
+        ignite0.cluster().active(true);
+        ignite1.cluster().active(true);
+
+        String cacheName = "test";
+
+        CacheConfiguration<Integer, TestVal> ccfg = new CacheConfiguration<Integer, TestVal>()
+            .setName(cacheName)
+            .setBackups(0)
+            .setAtomicityMode(ATOMIC)
+            .setIndexedTypes(Integer.class, TestVal.class);
+
+        IgniteCache<Integer,TestVal> cache0 = ignite0.getOrCreateCache(ccfg);
+        IgniteCache<Integer,TestVal> cache1 = ignite1.getOrCreateCache(ccfg);
+
+        int cnt = 20_000;
+
+        for (int i = 0; i < cnt; i++) {
+            assertTrue(cache0.putIfAbsent(i, new TestVal(i)));
+            assertTrue(cache1.putIfAbsent(i, new TestVal(i)));
+        }
+
+        for (int i = 0; i < cnt; i += 2) {
+            assertEquals(new TestVal(i), cache0.getAndRemove(i));
+            assertEquals(new TestVal(i), cache1.getAndRemove(i));
+        }
+
+        // Write any WAL record to get current WAL pointers.
+        FileWALPointer ptr0 = (FileWALPointer)ignite0.context().cache().context().wal().log(new CheckpointRecord(null));
+        FileWALPointer ptr1 = (FileWALPointer)ignite1.context().cache().context().wal().log(new CheckpointRecord(null));
+
+        log.info("Compressed WAL pointer: " + ptr0);
+        log.info("Uncompressed WAL pointer: " + ptr1);
+
+        assertTrue("Compressed WAL must be smaller than uncompressed [ptr0=" + ptr0 + ", ptr1=" + ptr1 + ']',
+            ptr0.compareTo(ptr1) < 0);
+    }
+}
diff --git a/modules/compress/src/test/java/org/apache/ignite/testsuites/IgnitePdsCompressionTestSuite.java b/modules/compress/src/test/java/org/apache/ignite/testsuites/IgnitePdsCompressionTestSuite.java
index b38abc0..efbdd14 100644
--- a/modules/compress/src/test/java/org/apache/ignite/testsuites/IgnitePdsCompressionTestSuite.java
+++ b/modules/compress/src/test/java/org/apache/ignite/testsuites/IgnitePdsCompressionTestSuite.java
@@ -18,11 +18,16 @@ package org.apache.ignite.testsuites;
 
 import java.util.ArrayList;
 import java.util.List;
+import org.apache.ignite.internal.processors.cache.persistence.db.wal.IgnitePdsCheckpointSimulationWithRealCpDisabledAndWalCompressionTest;
+import org.apache.ignite.internal.processors.cache.persistence.db.wal.WalCompactionAndPageCompressionTest;
+import org.apache.ignite.internal.processors.cache.persistence.db.wal.WalRecoveryWithPageCompressionAndTdeTest;
+import org.apache.ignite.internal.processors.cache.persistence.db.wal.WalRecoveryWithPageCompressionTest;
 import org.apache.ignite.internal.processors.compress.CompressionConfigurationTest;
 import org.apache.ignite.internal.processors.compress.CompressionProcessorTest;
 import org.apache.ignite.internal.processors.compress.DiskPageCompressionIntegrationAsyncTest;
 import org.apache.ignite.internal.processors.compress.DiskPageCompressionIntegrationTest;
 import org.apache.ignite.internal.processors.compress.FileSystemUtilsTest;
+import org.apache.ignite.internal.processors.compress.WalPageCompressionIntegrationTest;
 import org.apache.ignite.testframework.junits.DynamicSuite;
 import org.junit.runner.RunWith;
 
@@ -45,6 +50,13 @@ public class IgnitePdsCompressionTestSuite {
         suite.add(DiskPageCompressionIntegrationTest.class);
         suite.add(DiskPageCompressionIntegrationAsyncTest.class);
 
+        // WAL page records compression.
+        suite.add(WalPageCompressionIntegrationTest.class);
+        suite.add(WalRecoveryWithPageCompressionTest.class);
+        suite.add(WalRecoveryWithPageCompressionAndTdeTest.class);
+        suite.add(IgnitePdsCheckpointSimulationWithRealCpDisabledAndWalCompressionTest.class);
+        suite.add(WalCompactionAndPageCompressionTest.class);
+
         enableCompressionByDefault();
         IgnitePdsTestSuite.addRealPageStoreTests(suite, null);
 
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
index 800b41c..1df064e 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
@@ -190,6 +190,9 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
     /** Default SQL on-heap cache size. */
     public static final int DFLT_SQL_ONHEAP_CACHE_MAX_SIZE = 0;
 
+    /** Default disk page compression algorithm. */
+    public static final DiskPageCompression DFLT_DISK_PAGE_COMPRESSION = DiskPageCompression.DISABLED;
+
     /** Cache name. */
     private String name;
 
@@ -2318,7 +2321,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @see #getDiskPageCompressionLevel
      */
     public DiskPageCompression getDiskPageCompression() {
-        return diskPageCompression;
+        return diskPageCompression == null ? DFLT_DISK_PAGE_COMPRESSION : diskPageCompression;
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/DataStorageConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/DataStorageConfiguration.java
index c2cb8bc..d10bda1 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/DataStorageConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/DataStorageConfiguration.java
@@ -166,6 +166,9 @@ public class DataStorageConfiguration implements Serializable {
     /** Default wal compaction level. */
     public static final int DFLT_WAL_COMPACTION_LEVEL = Deflater.BEST_SPEED;
 
+    /** Default compression algorithm for WAL page snapshot records. */
+    public static final DiskPageCompression DFLT_WAL_PAGE_COMPRESSION = DiskPageCompression.DISABLED;
+
     /** Initial size of a memory chunk reserved for system cache. */
     private long sysRegionInitSize = DFLT_SYS_REG_INIT_SIZE;
 
@@ -289,6 +292,12 @@ public class DataStorageConfiguration implements Serializable {
     /** Timeout for checkpoint read lock acquisition. */
     private Long checkpointReadLockTimeout;
 
+    /** Compression algorithm for WAL page snapshot records. */
+    private DiskPageCompression walPageCompression = DFLT_WAL_PAGE_COMPRESSION;
+
+    /** Compression level for WAL page snapshot records. */
+    private Integer walPageCompressionLevel;
+
     /**
      * Initial size of a data region reserved for system cache.
      *
@@ -1020,6 +1029,50 @@ public class DataStorageConfiguration implements Serializable {
         return this;
     }
 
+    /**
+     * Gets compression algorithm for WAL page snapshot records.
+     *
+     * @return Page compression algorithm.
+     */
+    public DiskPageCompression getWalPageCompression() {
+        return walPageCompression == null ? DFLT_WAL_PAGE_COMPRESSION : walPageCompression;
+    }
+
+    /**
+     * Sets compression algorithm for WAL page snapshot records.
+     *
+     * @param walPageCompression Page compression algorithm.
+     * @return {@code this} for chaining.
+     */
+    public DataStorageConfiguration setWalPageCompression(DiskPageCompression walPageCompression) {
+        this.walPageCompression = walPageCompression;
+
+        return this;
+    }
+
+    /**
+     * Gets {@link #getWalPageCompression algorithm} specific WAL page compression level.
+     *
+     * @return WAL page snapshots compression level or {@code null} for default.
+     */
+    public Integer getWalPageCompressionLevel() {
+        return walPageCompressionLevel;
+    }
+
+    /**
+     * Sets {@link #setWalPageCompression algorithm} specific page compression level.
+     *
+     * @param walPageCompressionLevel Disk page compression level or {@code null} to use default.
+     *      {@link DiskPageCompression#ZSTD Zstd}: from {@code -131072} to {@code 22} (default {@code 3}).
+     *      {@link DiskPageCompression#LZ4 LZ4}: from {@code 0} to {@code 17} (default {@code 0}).
+     * @return {@code this} for chaining.
+     */
+    public DataStorageConfiguration setWalPageCompressionLevel(Integer walPageCompressionLevel) {
+        this.walPageCompressionLevel = walPageCompressionLevel;
+
+        return this;
+    }
+
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(DataStorageConfiguration.class, this);
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/DiskPageCompression.java b/modules/core/src/main/java/org/apache/ignite/configuration/DiskPageCompression.java
index 5deda2f..29186f7 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/DiskPageCompression.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/DiskPageCompression.java
@@ -23,8 +23,13 @@ import org.jetbrains.annotations.Nullable;
  *
  * @see CacheConfiguration#setDiskPageCompression
  * @see CacheConfiguration#setDiskPageCompressionLevel
+ * @see DataStorageConfiguration#setWalPageCompression
+ * @see DataStorageConfiguration#setWalPageCompressionLevel
  */
 public enum DiskPageCompression {
+    /** Compression disabled. */
+    DISABLED,
+
     /** Retain only useful data from half-filled pages, but do not apply any compression. */
     SKIP_GARBAGE,
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/PageSnapshot.java b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/PageSnapshot.java
index 6ae2c92..feae9d9 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/PageSnapshot.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/PageSnapshot.java
@@ -28,16 +28,16 @@ import org.apache.ignite.internal.util.tostring.GridToStringExclude;
 /**
  *
  */
-public class PageSnapshot extends WALRecord implements WalRecordCacheGroupAware{
+public class PageSnapshot extends WALRecord implements WalRecordCacheGroupAware {
     /** */
     @GridToStringExclude
-    private byte[] pageData;
+    private ByteBuffer pageData;
 
     /** */
     private FullPageId fullPageId;
 
     /**
-     * PageSIze without encryption overhead.
+     * PageSize without encryption overhead.
      */
     private int realPageSize;
 
@@ -48,13 +48,16 @@ public class PageSnapshot extends WALRecord implements WalRecordCacheGroupAware{
      */
     public PageSnapshot(FullPageId fullId, byte[] arr, int realPageSize) {
         this.fullPageId = fullId;
-        this.pageData = arr;
+        this.pageData = ByteBuffer.wrap(arr).order(ByteOrder.nativeOrder());
         this.realPageSize = realPageSize;
     }
 
     /**
+     * This constructor doesn't actually create a page snapshot (copy), it creates a wrapper over page memory region.
+     * A created record should not be used after WAL manager writes it to log, since page content can be modified.
+     *
      * @param fullPageId Full page ID.
-     * @param ptr Pointer to copy from.
+     * @param ptr Pointer to wrap.
      * @param pageSize Page size.
      * @param realPageSize Page size without encryption overhead.
      */
@@ -62,9 +65,7 @@ public class PageSnapshot extends WALRecord implements WalRecordCacheGroupAware{
         this.fullPageId = fullPageId;
         this.realPageSize = realPageSize;
 
-        pageData = new byte[pageSize];
-
-        GridUnsafe.copyMemory(null, ptr, pageData, GridUnsafe.BYTE_ARR_OFF, pageSize);
+        pageData = GridUnsafe.wrapPointer(ptr, pageSize);
     }
 
     /** {@inheritDoc} */
@@ -76,6 +77,31 @@ public class PageSnapshot extends WALRecord implements WalRecordCacheGroupAware{
      * @return Snapshot of page data.
      */
     public byte[] pageData() {
+        if (!pageData.isDirect())
+            return pageData.array();
+
+        // In case of direct buffer copy buffer content to new array.
+        byte[] arr = new byte[pageData.limit()];
+
+        GridUnsafe.copyMemory(null, GridUnsafe.bufferAddress(pageData), arr, GridUnsafe.BYTE_ARR_OFF,
+            pageData.limit());
+
+        return arr;
+    }
+
+    /**
+     * @return Size of page data.
+     */
+    public int pageDataSize() {
+        return pageData.limit();
+    }
+
+    /**
+     * @return Page data byte buffer.
+     */
+    public ByteBuffer pageDataBuffer() {
+        pageData.rewind();
+
         return pageData;
     }
 
@@ -87,10 +113,26 @@ public class PageSnapshot extends WALRecord implements WalRecordCacheGroupAware{
     }
 
     /** {@inheritDoc} */
+    @Override public int groupId() {
+        return fullPageId.groupId();
+    }
+
+    /**
+     * @return PageSize without encryption overhead.
+     */
+    public int realPageSize() {
+        return realPageSize;
+    }
+
+    /** {@inheritDoc} */
     @Override public String toString() {
-        ByteBuffer buf = ByteBuffer.allocateDirect(pageData.length);
-        buf.order(ByteOrder.nativeOrder());
-        buf.put(pageData);
+        ByteBuffer buf = pageData;
+
+        if (!pageData.isDirect()) {
+            buf = ByteBuffer.allocateDirect(pageDataSize());
+            buf.order(ByteOrder.nativeOrder());
+            buf.put(pageData);
+        }
 
         long addr = GridUnsafe.bufferAddress(buf);
 
@@ -101,16 +143,12 @@ public class PageSnapshot extends WALRecord implements WalRecordCacheGroupAware{
                 + super.toString() + "]]";
         }
         catch (IgniteCheckedException ignored) {
-            return "Error during call'toString' of PageSnapshot [fullPageId=" + fullPageId() +
-                ", pageData = " + Arrays.toString(pageData) + ", super=" + super.toString() + "]";
+            return "Error during call 'toString' of PageSnapshot [fullPageId=" + fullPageId() +
+                ", pageData = " + Arrays.toString(pageData()) + ", super=" + super.toString() + "]";
         }
         finally {
-            GridUnsafe.cleanDirectBuffer(buf);
+            if (!pageData.isDirect())
+                GridUnsafe.cleanDirectBuffer(buf);
         }
     }
-
-    /** {@inheritDoc} */
-    @Override public int groupId() {
-        return fullPageId.groupId();
-    }
 }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheCompressionManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheCompressionManager.java
index a050cd0..cac0064 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheCompressionManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheCompressionManager.java
@@ -44,13 +44,19 @@ public class CacheCompressionManager extends GridCacheManagerAdapter {
 
     /** {@inheritDoc} */
     @Override protected void start0() throws IgniteCheckedException {
+        if (cctx.kernalContext().clientNode()) {
+            diskPageCompression = DiskPageCompression.DISABLED;
+
+            return;
+        }
+
         compressProc = cctx.kernalContext().compress();
 
         CacheConfiguration cfg = cctx.config();
 
         diskPageCompression = cctx.kernalContext().config().isClientMode() ? null : cfg.getDiskPageCompression();
 
-        if (diskPageCompression != null) {
+        if (diskPageCompression != DiskPageCompression.DISABLED) {
             if (!cctx.dataRegion().config().isPersistenceEnabled())
                 throw new IgniteCheckedException("Disk page compression makes sense only with enabled persistence.");
 
@@ -81,7 +87,7 @@ public class CacheCompressionManager extends GridCacheManagerAdapter {
      * @throws IgniteCheckedException If failed.
      */
     public ByteBuffer compressPage(ByteBuffer page, PageStore store) throws IgniteCheckedException {
-        if (diskPageCompression == null)
+        if (diskPageCompression == DiskPageCompression.DISABLED)
             return page;
 
         int blockSize = store.getBlockSize();
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheDatabaseSharedManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheDatabaseSharedManager.java
index d73b3da..a10877d 100755
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheDatabaseSharedManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheDatabaseSharedManager.java
@@ -151,6 +151,7 @@ import org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO;
 import org.apache.ignite.internal.processors.cache.persistence.tree.io.PagePartitionMetaIO;
 import org.apache.ignite.internal.processors.cache.persistence.wal.FileWALPointer;
 import org.apache.ignite.internal.processors.cache.persistence.wal.crc.IgniteDataIntegrityViolationException;
+import org.apache.ignite.internal.processors.compress.CompressionProcessor;
 import org.apache.ignite.internal.processors.port.GridPortRecord;
 import org.apache.ignite.internal.processors.query.GridQueryProcessor;
 import org.apache.ignite.internal.stat.IoStatisticsHolderNoOp;
@@ -2529,6 +2530,14 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
 
             try {
                 PageUtils.putBytes(pageAddr, 0, pageSnapshotRecord.pageData());
+
+                if (PageIO.getCompressionType(pageAddr) != CompressionProcessor.UNCOMPRESSED_PAGE) {
+                    int realPageSize = pageMem.realPageSize(pageSnapshotRecord.groupId());
+
+                    assert pageSnapshotRecord.pageDataSize() < realPageSize : pageSnapshotRecord.pageDataSize();
+
+                    cctx.kernalContext().compress().decompressPage(pageMem.pageBuffer(pageAddr), realPageSize);
+                }
             }
             finally {
                 pageMem.writeUnlock(grpId, pageId, page, null, true, true);
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStore.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStore.java
index ed7dd2f..23adeac 100755
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStore.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStore.java
@@ -346,6 +346,10 @@ public class FilePageStore implements PageStore {
             if (inited) {
                 long newSize = Math.max(pageSize, fileIO.size() - headerSize());
 
+                // In the case of compressed pages we can miss the tail of the page.
+                if (newSize % pageSize != 0)
+                    newSize += pageSize - newSize % pageSize;
+
                 long delta = newSize - allocated.getAndSet(newSize);
 
                 assert delta % pageSize == 0 : delta;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImpl.java
index ed2d344..da787fb 100755
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImpl.java
@@ -72,6 +72,7 @@ import org.apache.ignite.internal.processors.cache.persistence.tree.io.PageParti
 import org.apache.ignite.internal.processors.cache.persistence.tree.io.PagePartitionMetaIO;
 import org.apache.ignite.internal.processors.cache.persistence.tree.io.TrackingPageIO;
 import org.apache.ignite.internal.processors.cache.persistence.wal.crc.IgniteDataIntegrityViolationException;
+import org.apache.ignite.internal.processors.compress.CompressionProcessor;
 import org.apache.ignite.internal.processors.query.GridQueryRowCacheCleaner;
 import org.apache.ignite.internal.stat.IoStatisticsHolder;
 import org.apache.ignite.internal.stat.IoStatisticsHolderNoOp;
@@ -967,7 +968,7 @@ public class PageMemoryImpl implements PageMemoryEx {
 
                             if (snapshot.fullPageId().equals(fullId)) {
                                 if (tmpAddr == null) {
-                                    assert snapshot.pageData().length <= pageSize() : snapshot.pageData().length;
+                                    assert snapshot.pageDataSize() <= pageSize() : snapshot.pageDataSize();
 
                                     tmpAddr = GridUnsafe.allocateMemory(pageSize());
                                 }
@@ -976,6 +977,14 @@ public class PageMemoryImpl implements PageMemoryEx {
                                     curPage = wrapPointer(tmpAddr, pageSize());
 
                                 PageUtils.putBytes(tmpAddr, 0, snapshot.pageData());
+
+                                if (PageIO.getCompressionType(tmpAddr) != CompressionProcessor.UNCOMPRESSED_PAGE) {
+                                    int realPageSize = realPageSize(snapshot.groupId());
+
+                                    assert snapshot.pageDataSize() < realPageSize : snapshot.pageDataSize();
+
+                                    ctx.kernalContext().compress().decompressPage(curPage, realPageSize);
+                                }
                             }
 
                             break;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/PageIO.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/PageIO.java
index 0e66b77..ab660d2 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/PageIO.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/PageIO.java
@@ -405,6 +405,14 @@ public abstract class PageIO {
     }
 
     /**
+     * @param pageAddr Page address.
+     * @return Compression type.
+     */
+    public static byte getCompressionType(long pageAddr) {
+        return PageUtils.getByte(pageAddr, COMPRESSION_TYPE_OFF);
+    }
+
+    /**
      * @param page Page buffer.
      * @param compressedSize Compressed size.
      */
@@ -421,6 +429,14 @@ public abstract class PageIO {
     }
 
     /**
+     * @param pageAddr Page address.
+     * @return Compressed size.
+     */
+    public static short getCompressedSize(long pageAddr) {
+        return PageUtils.getShort(pageAddr, COMPRESSED_SIZE_OFF);
+    }
+
+    /**
      * @param page Page buffer.
      * @param compactedSize Compacted size.
      */
@@ -438,6 +454,14 @@ public abstract class PageIO {
 
     /**
      * @param pageAddr Page address.
+     * @return Compacted size.
+     */
+    public static short getCompactedSize(long pageAddr) {
+        return PageUtils.getShort(pageAddr, COMPACTED_SIZE_OFF);
+    }
+
+    /**
+     * @param pageAddr Page address.
      * @return Checksum.
      */
     public static int getCrc(long pageAddr) {
@@ -839,9 +863,8 @@ public abstract class PageIO {
         assert pageSize <= out.remaining();
         assert pageSize == page.remaining();
 
-        page.mark();
-        out.put(page).flip();
-        page.reset();
+        PageHandler.copyMemory(page, 0, out, 0, pageSize);
+        out.limit(pageSize);
     }
 
     /**
@@ -857,7 +880,14 @@ public abstract class PageIO {
             .a(",\n\t").a(PageIdUtils.toDetailString(getPageId(addr)))
             .a("\n],\n");
 
-        io.printPage(addr, pageSize, sb);
+        if (getCompressionType(addr) != 0) {
+            sb.a("CompressedPage[\n\tcompressionType=").a(getCompressionType(addr))
+                .a(",\n\tcompressedSize=").a(getCompressedSize(addr))
+                .a(",\n\tcompactedSize=").a(getCompactedSize(addr))
+                .a("\n]");
+        }
+        else
+            io.printPage(addr, pageSize, sb);
 
         return sb.toString();
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/FileWriteAheadLogManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/FileWriteAheadLogManager.java
index 0e45c26..7bf2e10 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/FileWriteAheadLogManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/FileWriteAheadLogManager.java
@@ -55,6 +55,7 @@ import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.IgniteLogger;
 import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.configuration.DataStorageConfiguration;
+import org.apache.ignite.configuration.DiskPageCompression;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.configuration.WALMode;
 import org.apache.ignite.events.WalSegmentArchivedEvent;
@@ -103,9 +104,11 @@ import org.apache.ignite.internal.processors.cache.persistence.wal.serializer.Re
 import org.apache.ignite.internal.processors.cache.persistence.wal.serializer.RecordSerializerFactory;
 import org.apache.ignite.internal.processors.cache.persistence.wal.serializer.RecordSerializerFactoryImpl;
 import org.apache.ignite.internal.processors.cache.persistence.wal.serializer.RecordV1Serializer;
+import org.apache.ignite.internal.processors.compress.CompressionProcessor;
 import org.apache.ignite.internal.processors.failure.FailureProcessor;
 import org.apache.ignite.internal.processors.timeout.GridTimeoutObject;
 import org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor;
+import org.apache.ignite.internal.util.GridUnsafe;
 import org.apache.ignite.internal.util.future.GridFinishedFuture;
 import org.apache.ignite.internal.util.future.GridFutureAdapter;
 import org.apache.ignite.internal.util.io.GridFileUtils;
@@ -357,6 +360,12 @@ public class FileWriteAheadLogManager extends GridCacheSharedManagerAdapter impl
     /** Switch segment record offset. */
     private final AtomicLongArray switchSegmentRecordOffset;
 
+    /** Page snapshot records compression algorithm. */
+    private DiskPageCompression pageCompression;
+
+    /** Page snapshot records compression level. */
+    private int pageCompressionLevel;
+
     /**
      * @param ctx Kernal context.
      */
@@ -471,6 +480,21 @@ public class FileWriteAheadLogManager extends GridCacheSharedManagerAdapter impl
                 segmentRouter,
                 ioFactory
             );
+
+            pageCompression = dsCfg.getWalPageCompression();
+
+            if (pageCompression != DiskPageCompression.DISABLED) {
+                if (serializerVer < 2) {
+                    throw new IgniteCheckedException("WAL page snapshots compression not supported for serializerVer=" +
+                        serializerVer);
+                }
+
+                cctx.kernalContext().compress().checkPageCompressionSupported();
+
+                pageCompressionLevel = dsCfg.getWalPageCompressionLevel() != null ?
+                    CompressionProcessor.checkCompressionLevelBounds(dsCfg.getWalPageCompressionLevel(), pageCompression) :
+                    CompressionProcessor.getDefaultCompressionLevel(pageCompression);
+            }
         }
     }
 
@@ -769,6 +793,25 @@ public class FileWriteAheadLogManager extends GridCacheSharedManagerAdapter impl
         if (currWrHandle == null || (isDisable != null && isDisable.check()))
             return null;
 
+        // Do page snapshots compression if configured.
+        if (pageCompression != DiskPageCompression.DISABLED && rec instanceof PageSnapshot) {
+            PageSnapshot pageSnapshot = (PageSnapshot)rec;
+
+            int pageSize = pageSnapshot.realPageSize();
+
+            ByteBuffer pageData = pageSnapshot.pageDataBuffer();
+
+            ByteBuffer compressedPage = cctx.kernalContext().compress().compressPage(pageData, pageSize, 1,
+                pageCompression, pageCompressionLevel);
+
+            if (compressedPage != pageData) {
+                assert compressedPage.isDirect() : "Is direct buffer: " + compressedPage.isDirect();
+
+                rec = new PageSnapshot(pageSnapshot.fullPageId(), GridUnsafe.bufferAddress(compressedPage),
+                    compressedPage.limit(), pageSize);
+            }
+        }
+
         // Need to calculate record size first.
         rec.size(serializer.size(rec));
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataSerializer.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataSerializer.java
index e94be9f..e1d7c9f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataSerializer.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataSerializer.java
@@ -41,11 +41,12 @@ public interface RecordDataSerializer {
      *
      * @param type Record type.
      * @param in Buffer to read.
+     * @param size Record size (0 if unknown).
      * @return WAL record.
      * @throws IOException In case of I/O problems.
      * @throws IgniteCheckedException If it's unable to read record.
      */
-    WALRecord readRecord(WALRecord.RecordType type, ByteBufferBackedDataInput in) throws IOException, IgniteCheckedException;
+    WALRecord readRecord(WALRecord.RecordType type, ByteBufferBackedDataInput in, int size) throws IOException, IgniteCheckedException;
 
     /**
      * Writes record data to buffer {@code buf}.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV1Serializer.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV1Serializer.java
index c5ede10..dd6393f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV1Serializer.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV1Serializer.java
@@ -127,10 +127,10 @@ public class RecordDataV1Serializer implements RecordDataSerializer {
     protected final GridCacheSharedContext cctx;
 
     /** Size of page used for PageMemory regions. */
-    private final int pageSize;
+    protected final int pageSize;
 
     /** Size of page without encryption overhead. */
-    private final int realPageSize;
+    protected final int realPageSize;
 
     /** Cache object processor to reading {@link DataEntry DataEntries}. */
     protected final IgniteCacheObjectProcessor co;
@@ -184,7 +184,7 @@ public class RecordDataV1Serializer implements RecordDataSerializer {
     }
 
     /** {@inheritDoc} */
-    @Override public WALRecord readRecord(RecordType type, ByteBufferBackedDataInput in)
+    @Override public WALRecord readRecord(RecordType type, ByteBufferBackedDataInput in, int size)
         throws IOException, IgniteCheckedException {
         if (type == ENCRYPTED_RECORD) {
             if (encSpi == null) {
@@ -201,10 +201,10 @@ public class RecordDataV1Serializer implements RecordDataSerializer {
             if (clData.get1() == null)
                 return new EncryptedRecord(clData.get2(), clData.get3());
 
-            return readPlainRecord(clData.get3(), clData.get1(), true);
+            return readPlainRecord(clData.get3(), clData.get1(), true, clData.get1().buffer().capacity());
         }
 
-        return readPlainRecord(type, in, false);
+        return readPlainRecord(type, in, false, size);
     }
 
     /** {@inheritDoc} */
@@ -346,7 +346,7 @@ public class RecordDataV1Serializer implements RecordDataSerializer {
 
                 PageSnapshot pageRec = (PageSnapshot)record;
 
-                return pageRec.pageData().length + 12;
+                return pageRec.pageDataSize() + 12;
 
             case CHECKPOINT_RECORD:
                 CheckpointRecord cpRec = (CheckpointRecord)record;
@@ -532,12 +532,13 @@ public class RecordDataV1Serializer implements RecordDataSerializer {
      * @param type Record type.
      * @param in Input
      * @param encrypted Record was encrypted.
+     * @param recordSize Record size.
      * @return Deserialized record.
      * @throws IOException If failed.
      * @throws IgniteCheckedException If failed.
      */
     WALRecord readPlainRecord(RecordType type, ByteBufferBackedDataInput in,
-        boolean encrypted) throws IOException, IgniteCheckedException {
+        boolean encrypted, int recordSize) throws IOException, IgniteCheckedException {
         WALRecord res;
 
         switch (type) {
@@ -1160,7 +1161,7 @@ public class RecordDataV1Serializer implements RecordDataSerializer {
 
                 buf.putInt(snap.fullPageId().groupId());
                 buf.putLong(snap.fullPageId().pageId());
-                buf.put(snap.pageData());
+                buf.put(snap.pageDataBuffer());
 
                 break;
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV2Serializer.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV2Serializer.java
index 8533e73..52714c8 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV2Serializer.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV2Serializer.java
@@ -26,6 +26,7 @@ import java.util.List;
 import java.util.Map;
 import java.util.UUID;
 import org.apache.ignite.IgniteCheckedException;
+import org.apache.ignite.internal.pagemem.FullPageId;
 import org.apache.ignite.internal.pagemem.wal.record.CacheState;
 import org.apache.ignite.internal.pagemem.wal.record.CheckpointRecord;
 import org.apache.ignite.internal.pagemem.wal.record.ConsistentCutRecord;
@@ -36,6 +37,7 @@ import org.apache.ignite.internal.pagemem.wal.record.LazyMvccDataEntry;
 import org.apache.ignite.internal.pagemem.wal.record.MvccDataEntry;
 import org.apache.ignite.internal.pagemem.wal.record.MvccDataRecord;
 import org.apache.ignite.internal.pagemem.wal.record.MvccTxRecord;
+import org.apache.ignite.internal.pagemem.wal.record.PageSnapshot;
 import org.apache.ignite.internal.pagemem.wal.record.SnapshotRecord;
 import org.apache.ignite.internal.pagemem.wal.record.TxRecord;
 import org.apache.ignite.internal.pagemem.wal.record.WALRecord;
@@ -121,9 +123,20 @@ public class RecordDataV2Serializer extends RecordDataV1Serializer {
     @Override WALRecord readPlainRecord(
         RecordType type,
         ByteBufferBackedDataInput in,
-        boolean encrypted
+        boolean encrypted,
+        int recordSize
     ) throws IOException, IgniteCheckedException {
         switch (type) {
+            case PAGE_RECORD:
+                int cacheId = in.readInt();
+                long pageId = in.readLong();
+
+                byte[] arr = new byte[recordSize - 4 /* cacheId */ - 8 /* pageId */];
+
+                in.readFully(arr);
+
+                return new PageSnapshot(new FullPageId(pageId, cacheId), arr, encrypted ? realPageSize : pageSize);
+
             case CHECKPOINT_RECORD:
                 long msb = in.readLong();
                 long lsb = in.readLong();
@@ -200,7 +213,7 @@ public class RecordDataV2Serializer extends RecordDataV1Serializer {
                 return new ConsistentCutRecord();
 
             default:
-                return super.readPlainRecord(type, in, encrypted);
+                return super.readPlainRecord(type, in, encrypted, recordSize);
         }
     }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV1Serializer.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV1Serializer.java
index 288be5a..ec0ddc1 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV1Serializer.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV1Serializer.java
@@ -139,7 +139,7 @@ public class RecordV1Serializer implements RecordSerializer {
             if (recType == null)
                 throw new IOException("Unknown record type: " + recType);
 
-            final WALRecord rec = dataSerializer.readRecord(recType, in);
+            final WALRecord rec = dataSerializer.readRecord(recType, in, 0);
 
             rec.position(ptr);
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV2Serializer.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV2Serializer.java
index 872e47d..5a6db67 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV2Serializer.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV2Serializer.java
@@ -159,7 +159,8 @@ public class RecordV2Serializer implements RecordSerializer {
                 return new MarshalledRecord(recType, ptr, buf);
             }
             else {
-                WALRecord rec = dataSerializer.readRecord(recType, in);
+                WALRecord rec = dataSerializer.readRecord(recType, in, ptr.length() - REC_TYPE_SIZE -
+                    FILE_WAL_POINTER_SIZE - CRC_SIZE);
 
                 rec.position(ptr);
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/compress/CompressionProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/compress/CompressionProcessor.java
index 4f2227e..6c14d6c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/compress/CompressionProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/compress/CompressionProcessor.java
@@ -50,7 +50,7 @@ public class CompressionProcessor extends GridProcessorAdapter {
     public static final int ZSTD_DEFAULT_LEVEL = 3;
 
     /** */
-    protected static final byte UNCOMPRESSED_PAGE = 0;
+    public static final byte UNCOMPRESSED_PAGE = 0;
 
     /** */
     protected static final byte COMPACTED_PAGE = 1;
@@ -133,6 +133,15 @@ public class CompressionProcessor extends GridProcessorAdapter {
     }
 
     /**
+     * Checks weither page compression is supported.
+     *
+     * @throws IgniteCheckedException If compression is not supported.
+     */
+    public void checkPageCompressionSupported() throws IgniteCheckedException {
+        fail();
+    }
+
+    /**
      * @param storagePath Storage path.
      * @param pageSize Page size.
      * @throws IgniteCheckedException If compression is not supported.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformConfigurationUtils.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformConfigurationUtils.java
index 167571d..2f74ac9 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformConfigurationUtils.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformConfigurationUtils.java
@@ -60,6 +60,7 @@ import org.apache.ignite.configuration.ClientConnectorConfiguration;
 import org.apache.ignite.configuration.DataPageEvictionMode;
 import org.apache.ignite.configuration.DataRegionConfiguration;
 import org.apache.ignite.configuration.DataStorageConfiguration;
+import org.apache.ignite.configuration.DiskPageCompression;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.configuration.MemoryConfiguration;
 import org.apache.ignite.configuration.MemoryPolicyConfiguration;
@@ -1922,6 +1923,11 @@ public class PlatformConfigurationUtils {
         if (in.readBoolean())
             res.setCheckpointReadLockTimeout(in.readLong());
 
+        res.setWalPageCompression(DiskPageCompression.fromOrdinal(in.readInt()));
+
+        if (in.readBoolean())
+            res.setWalPageCompressionLevel(in.readInt());
+
         int cnt = in.readInt();
 
         if (cnt > 0) {
@@ -2058,6 +2064,15 @@ public class PlatformConfigurationUtils {
             else
                 w.writeBoolean(false);
 
+            w.writeInt(cfg.getWalPageCompression().ordinal());
+
+            if (cfg.getWalPageCompressionLevel() != null) {
+                w.writeBoolean(true);
+                w.writeInt(cfg.getWalPageCompressionLevel());
+            }
+            else
+                w.writeBoolean(false);
+
             if (cfg.getDataRegionConfigurations() != null) {
                 w.writeInt(cfg.getDataRegionConfigurations().length);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/DummyPageIO.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/DummyPageIO.java
index f0f1d8a..05ba134 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/DummyPageIO.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/DummyPageIO.java
@@ -19,6 +19,7 @@ package org.apache.ignite.internal.processors.cache.persistence;
 import java.nio.ByteBuffer;
 import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.internal.processors.cache.persistence.tree.io.CompactablePageIO;
+import org.apache.ignite.internal.processors.cache.persistence.tree.io.IOVersions;
 import org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO;
 import org.apache.ignite.internal.util.GridStringBuilder;
 
@@ -27,6 +28,9 @@ import org.apache.ignite.internal.util.GridStringBuilder;
  */
 public class DummyPageIO extends PageIO implements CompactablePageIO {
     /** */
+    public static final IOVersions<DummyPageIO> VERSIONS = new IOVersions<>(new DummyPageIO());
+
+    /** */
     public DummyPageIO() {
         super(2 * Short.MAX_VALUE, 1);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsCheckpointSimulationWithRealCpDisabledTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsCheckpointSimulationWithRealCpDisabledTest.java
index c44cbd0..5921c51 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsCheckpointSimulationWithRealCpDisabledTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsCheckpointSimulationWithRealCpDisabledTest.java
@@ -41,6 +41,7 @@ import org.apache.ignite.configuration.DataRegionConfiguration;
 import org.apache.ignite.configuration.DataStorageConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.configuration.WALMode;
+import org.apache.ignite.internal.GridKernalContext;
 import org.apache.ignite.internal.IgniteEx;
 import org.apache.ignite.internal.IgniteInternalFuture;
 import org.apache.ignite.internal.pagemem.FullPageId;
@@ -211,7 +212,7 @@ public class IgnitePdsCheckpointSimulationWithRealCpDisabledTest extends GridCom
 
         mem = shared.database().dataRegion(null).pageMemory();
 
-        verifyReads(res.get1(), mem, res.get2(), shared.wal());
+        verifyReads(ig.context(), res.get1(), mem, res.get2(), shared.wal());
     }
 
     /**
@@ -679,7 +680,7 @@ public class IgnitePdsCheckpointSimulationWithRealCpDisabledTest extends GridCom
             long pageAddr = mem.writeLock(fullId.groupId(), fullId.pageId(), page);
 
             try {
-                DataPageIO.VERSIONS.latest().initNewPage(pageAddr, fullId.pageId(), mem.realPageSize(fullId.groupId()));
+                DummyPageIO.VERSIONS.latest().initNewPage(pageAddr, fullId.pageId(), mem.realPageSize(fullId.groupId()));
 
                 ThreadLocalRandom rnd = ThreadLocalRandom.current();
 
@@ -700,6 +701,7 @@ public class IgnitePdsCheckpointSimulationWithRealCpDisabledTest extends GridCom
      * @param mem Memory.
      */
     private void verifyReads(
+        GridKernalContext ctx,
         Map<FullPageId, Integer> res,
         PageMemory mem,
         WALPointer start,
@@ -707,6 +709,8 @@ public class IgnitePdsCheckpointSimulationWithRealCpDisabledTest extends GridCom
     ) throws Exception {
         Map<FullPageId, byte[]> replay = new HashMap<>();
 
+        ByteBuffer buf = ByteBuffer.allocateDirect(mem.pageSize()).order(ByteOrder.nativeOrder());
+
         try (PartitionMetaStateRecordExcludeIterator it = new PartitionMetaStateRecordExcludeIterator(wal.replay(start))) {
             IgniteBiTuple<WALPointer, WALRecord> tup = it.next();
 
@@ -729,7 +733,22 @@ public class IgnitePdsCheckpointSimulationWithRealCpDisabledTest extends GridCom
                 else if (rec instanceof PageSnapshot) {
                     PageSnapshot page = (PageSnapshot)rec;
 
-                    replay.put(page.fullPageId(), page.pageData());
+                    int realPageSize = mem.realPageSize(page.groupId());
+
+                    byte[] pageData = page.pageData();
+
+                    if (page.pageDataSize() < realPageSize) {
+                        buf.clear();
+                        buf.put(pageData).flip();
+
+                        ctx.compress().decompressPage(buf, realPageSize);
+
+                        pageData = new byte[buf.limit()];
+
+                        buf.get(pageData);
+                    }
+
+                    replay.put(page.fullPageId(), pageData);
                 }
             }
         }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalCompactionTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalCompactionTest.java
index 729f9ac..427e80c 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalCompactionTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalCompactionTest.java
@@ -18,6 +18,7 @@ package org.apache.ignite.internal.processors.cache.persistence.db.wal;
 import java.io.File;
 import java.io.FilenameFilter;
 import java.io.RandomAccessFile;
+import java.nio.ByteBuffer;
 import java.util.Arrays;
 import java.util.Comparator;
 import org.apache.ignite.Ignite;
@@ -37,9 +38,11 @@ import org.apache.ignite.internal.pagemem.wal.IgniteWriteAheadLogManager;
 import org.apache.ignite.internal.pagemem.wal.record.CheckpointRecord;
 import org.apache.ignite.internal.pagemem.wal.record.PageSnapshot;
 import org.apache.ignite.internal.pagemem.wal.record.RolloverType;
+import org.apache.ignite.internal.processors.cache.persistence.DummyPageIO;
 import org.apache.ignite.internal.processors.cache.persistence.IgniteCacheDatabaseSharedManager;
 import org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager;
 import org.apache.ignite.internal.processors.cache.persistence.wal.FileDescriptor;
+import org.apache.ignite.internal.util.GridUnsafe;
 import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.junit.Test;
@@ -172,9 +175,11 @@ public class WalCompactionTest extends GridCommonAbstractTest {
             cache.put(i, val);
         }
 
+        byte[] dummyPage = dummyPage(pageSize);
+
         // Spam WAL to move all data records to compressible WAL zone.
         for (int i = 0; i < WAL_SEGMENT_SIZE / pageSize * 2; i++) {
-            ig.context().cache().context().wal().log(new PageSnapshot(new FullPageId(-1, -1), new byte[pageSize],
+            ig.context().cache().context().wal().log(new PageSnapshot(new FullPageId(-1, -1), dummyPage,
                 pageSize));
         }
 
@@ -479,9 +484,11 @@ public class WalCompactionTest extends GridCommonAbstractTest {
             cache.put(i, val);
         }
 
+        byte[] dummyPage = dummyPage(pageSize);
+
         // Spam WAL to move all data records to compressible WAL zone.
         for (int i = 0; i < WAL_SEGMENT_SIZE / pageSize * 2; i++) {
-            ig.context().cache().context().wal().log(new PageSnapshot(new FullPageId(-1, -1), new byte[pageSize],
+            ig.context().cache().context().wal().log(new PageSnapshot(new FullPageId(-1, -1), dummyPage,
                 pageSize));
         }
 
@@ -564,4 +571,19 @@ public class WalCompactionTest extends GridCommonAbstractTest {
 
         assertFalse(fail);
     }
+
+    /**
+     * @param pageSize Page size.
+     */
+    private static byte[] dummyPage(int pageSize) {
+        ByteBuffer pageBuf = ByteBuffer.allocateDirect(pageSize);
+
+        DummyPageIO.VERSIONS.latest().initNewPage(GridUnsafe.bufferAddress(pageBuf), -1, pageSize);
+
+        byte[] pageData = new byte[pageSize];
+
+        pageBuf.get(pageData);
+
+        return pageData;
+    }
 }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/memtracker/PageMemoryTracker.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/memtracker/PageMemoryTracker.java
index 560d707..b013d24 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/memtracker/PageMemoryTracker.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/memtracker/PageMemoryTracker.java
@@ -38,7 +38,6 @@ import org.apache.ignite.internal.mem.unsafe.UnsafeMemoryProvider;
 import org.apache.ignite.internal.pagemem.FullPageId;
 import org.apache.ignite.internal.pagemem.PageIdUtils;
 import org.apache.ignite.internal.pagemem.PageMemory;
-import org.apache.ignite.internal.pagemem.PageUtils;
 import org.apache.ignite.internal.pagemem.store.IgnitePageStoreManager;
 import org.apache.ignite.internal.pagemem.wal.IgniteWriteAheadLogManager;
 import org.apache.ignite.internal.pagemem.wal.WALPointer;
@@ -424,7 +423,7 @@ public class PageMemoryTracker implements IgnitePlugin {
             page.lock();
 
             try {
-                PageUtils.putBytes(page.address(), 0, snapshot.pageData());
+                GridUnsafe.copyMemory(GridUnsafe.bufferAddress(snapshot.pageDataBuffer()), page.address(), pageSize);
 
                 page.changeHistory().clear();
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalRecoveryTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalRecoveryTest.java
index 18df698..e1de9fd 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalRecoveryTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalRecoveryTest.java
@@ -54,6 +54,7 @@ import org.apache.ignite.configuration.BinaryConfiguration;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.DataRegionConfiguration;
 import org.apache.ignite.configuration.DataStorageConfiguration;
+import org.apache.ignite.configuration.DiskPageCompression;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.configuration.WALMode;
 import org.apache.ignite.internal.DiscoverySpiTestListener;
@@ -72,6 +73,7 @@ import org.apache.ignite.internal.pagemem.wal.record.PageSnapshot;
 import org.apache.ignite.internal.pagemem.wal.record.TxRecord;
 import org.apache.ignite.internal.pagemem.wal.record.WALRecord;
 import org.apache.ignite.internal.pagemem.wal.record.delta.PageDeltaRecord;
+import org.apache.ignite.internal.processors.cache.CacheGroupContext;
 import org.apache.ignite.internal.processors.cache.DynamicCacheDescriptor;
 import org.apache.ignite.internal.processors.cache.GridCacheSharedContext;
 import org.apache.ignite.internal.processors.cache.IgniteInternalCache;
@@ -82,6 +84,8 @@ import org.apache.ignite.internal.processors.cache.persistence.file.FilePageStor
 import org.apache.ignite.internal.processors.cache.persistence.filename.PdsConsistentIdProcessor;
 import org.apache.ignite.internal.processors.cache.persistence.metastorage.MetaStorage;
 import org.apache.ignite.internal.processors.cache.persistence.pagemem.PageMemoryEx;
+import org.apache.ignite.internal.processors.cache.persistence.tree.io.CompactablePageIO;
+import org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO;
 import org.apache.ignite.internal.processors.cache.persistence.tree.io.TrackingPageIO;
 import org.apache.ignite.internal.processors.cache.version.GridCacheVersion;
 import org.apache.ignite.internal.stat.IoStatisticsHolderNoOp;
@@ -162,7 +166,9 @@ public class IgniteWalRecoveryTest extends GridCommonAbstractTest {
 
     /** */
     private long checkpointFrequency = DFLT_CHECKPOINT_FREQ;
-    ;
+
+    /** WAL page snapshots records compression method. */
+    protected DiskPageCompression walPageCompression;
 
     /** {@inheritDoc} */
     @Override protected boolean isMultiJvm() {
@@ -213,6 +219,8 @@ public class IgniteWalRecoveryTest extends GridCommonAbstractTest {
 
         dbCfg.setWalSegments(walSegments);
 
+        dbCfg.setWalPageCompression(walPageCompression);
+
         dbCfg.setCheckpointFrequency(checkpointFrequency);
 
         cfg.setDataStorageConfiguration(dbCfg);
@@ -1357,6 +1365,8 @@ public class IgniteWalRecoveryTest extends GridCommonAbstractTest {
 
         ByteBuffer buf = ByteBuffer.allocateDirect(pageSize);
 
+        buf.order(ByteOrder.nativeOrder());
+
         // Now check that deltas can be correctly applied.
         try (WALIterator it = sharedCtx.wal().replay(ptr)) {
             while (it.hasNext()) {
@@ -1367,7 +1377,28 @@ public class IgniteWalRecoveryTest extends GridCommonAbstractTest {
                 if (rec instanceof PageSnapshot) {
                     PageSnapshot page = (PageSnapshot)rec;
 
-                    rolledPages.put(page.fullPageId(), page.pageData());
+                    CacheGroupContext gctx = sharedCtx.cache().cacheGroup(page.groupId());
+
+                    int realPageSize = gctx == null ? pageSize
+                        : gctx.dataRegion().pageMemory().realPageSize(page.groupId());
+
+                    byte[] pageData = page.pageData();
+
+                    if (pageData.length < realPageSize) {
+                        buf.clear();
+                        buf.put(pageData);
+                        buf.flip();
+
+                        sharedCtx.kernalContext().compress().decompressPage(buf, realPageSize);
+
+                        pageData = new byte[realPageSize];
+
+                        buf.position(0);
+
+                        buf.get(pageData);
+                    }
+
+                    rolledPages.put(page.fullPageId(), pageData);
                 }
                 else if (rec instanceof PageDeltaRecord) {
                     PageDeltaRecord delta = (PageDeltaRecord)rec;
@@ -1384,17 +1415,13 @@ public class IgniteWalRecoveryTest extends GridCommonAbstractTest {
 
                     assertNotNull("Missing page snapshot [page=" + fullId + ", delta=" + delta + ']', pageData);
 
-                    buf.order(ByteOrder.nativeOrder());
-
-                    buf.position(0);
+                    buf.clear();
                     buf.put(pageData);
-                    buf.position(0);
+                    buf.flip();
 
                     delta.applyDelta(sharedCtx.database().dataRegion(null).pageMemory(),
                         GridUnsafe.bufferAddress(buf));
 
-                    buf.position(0);
-
                     buf.get(pageData);
                 }
             }
@@ -1404,6 +1431,8 @@ public class IgniteWalRecoveryTest extends GridCommonAbstractTest {
 
         PageMemoryEx pageMem = (PageMemoryEx)db.dataRegion(null).pageMemory();
 
+        ByteBuffer bufWal = ByteBuffer.allocateDirect(pageSize);
+
         for (Map.Entry<FullPageId, byte[]> entry : rolledPages.entrySet()) {
             FullPageId fullId = entry.getKey();
 
@@ -1419,12 +1448,30 @@ public class IgniteWalRecoveryTest extends GridCommonAbstractTest {
                     try {
                         byte[] data = entry.getValue();
 
-                        for (int i = 0; i < data.length; i++) {
-                            if (fullId.pageId() == TrackingPageIO.VERSIONS.latest().trackingPageFor(fullId.pageId(), db.pageSize()))
-                                continue; // Skip tracking pages.
+                        if (fullId.pageId() == TrackingPageIO.VERSIONS.latest().trackingPageFor(fullId.pageId(), db.pageSize()))
+                            continue; // Skip tracking pages.
 
-                            assertEquals("page=" + fullId + ", pos=" + i, PageUtils.getByte(bufPtr, i), data[i]);
+                        // Compaction/restoring page can left some trash in unused space, so we need to compare
+                        // compacted pages in case of compaction is used.
+                        if (walPageCompression != null && PageIO.getPageIO(bufPtr) instanceof CompactablePageIO) {
+                            CompactablePageIO pageIO = PageIO.getPageIO(bufPtr);
+
+                            buf.clear();
+                            bufWal.clear();
+
+                            int realPageSize = data.length;
+
+                            pageIO.compactPage(GridUnsafe.wrapPointer(bufPtr, realPageSize), buf, realPageSize);
+                            pageIO.compactPage(ByteBuffer.wrap(data), bufWal, realPageSize);
+
+                            bufPtr = GridUnsafe.bufferAddress(buf);
+                            data = new byte[bufWal.limit()];
+                            bufWal.rewind();
+                            bufWal.get(data);
                         }
+
+                        for (int i = 0; i < data.length; i++)
+                            assertEquals("page=" + fullId + ", pos=" + i, PageUtils.getByte(bufPtr, i), data[i]);
                     }
                     finally {
                         pageMem.writeUnlock(fullId.groupId(), fullId.pageId(), page, null, false, true);
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/full-config.xml b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/full-config.xml
index 6c6d69e..bf6715f 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/full-config.xml
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Config/full-config.xml
@@ -149,7 +149,8 @@
                               walThreadLocalBufferSize="11"
                               walArchivePath="abc" walFlushFrequency="00:00:12" walFsyncDelayNanos="13" walHistorySize="14"
                               walMode="Background" walRecordIteratorBufferSize="15" walSegments="16" walSegmentSize="17"
-                              walPath="wal-store" writeThrottlingEnabled="true" walAutoArchiveAfterInactivity="00:00:18">
+                              walPath="wal-store" writeThrottlingEnabled="true" walAutoArchiveAfterInactivity="00:00:18"
+                              walPageCompression="Zstd">
         <dataRegionConfigurations>
             <dataRegionConfiguration emptyPagesPoolSize="1" evictionThreshold="2" initialSize="3" metricsEnabled="true"
                                      maxSize="4" name="reg2" pageEvictionMode="RandomLru" metricsRateTimeInterval="00:00:01"
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/IgniteConfigurationSerializerTest.cs b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/IgniteConfigurationSerializerTest.cs
index 0135e80..4961954 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/IgniteConfigurationSerializerTest.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/IgniteConfigurationSerializerTest.cs
@@ -323,6 +323,7 @@ namespace Apache.Ignite.Core.Tests
             Assert.AreEqual("wal-store", ds.WalPath);
             Assert.AreEqual(TimeSpan.FromSeconds(18), ds.WalAutoArchiveAfterInactivity);
             Assert.IsTrue(ds.WriteThrottlingEnabled);
+            Assert.AreEqual(DiskPageCompression.Zstd, ds.WalPageCompression);
 
             var dr = ds.DataRegionConfigurations.Single();
             Assert.AreEqual(1, dr.EmptyPagesPoolSize);
@@ -986,6 +987,8 @@ namespace Apache.Ignite.Core.Tests
                     ConcurrencyLevel = 1,
                     PageSize = 5 * 1024,
                     WalAutoArchiveAfterInactivity = TimeSpan.FromSeconds(19),
+                    WalPageCompression = DiskPageCompression.Lz4,
+                    WalPageCompressionLevel = 10,
                     DefaultDataRegionConfiguration = new DataRegionConfiguration
                     {
                         Name = "reg1",
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/Apache.Ignite.Core.csproj b/modules/platforms/dotnet/Apache.Ignite.Core/Apache.Ignite.Core.csproj
index ff96dc4..b99f2a8 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/Apache.Ignite.Core.csproj
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/Apache.Ignite.Core.csproj
@@ -63,6 +63,7 @@
     <Compile Include="Common\IgniteProductVersion.cs" />
     <Compile Include="Configuration\CheckpointWriteOrder.cs" />
     <Compile Include="Configuration\DataPageEvictionMode.cs" />
+    <Compile Include="Configuration\DiskPageCompression.cs" />
     <Compile Include="Configuration\DataRegionConfiguration.cs" />
     <Compile Include="Configuration\DataStorageConfiguration.cs" />
     <Compile Include="Cache\Configuration\MemoryPolicyConfiguration.cs" />
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/Configuration/DataStorageConfiguration.cs b/modules/platforms/dotnet/Apache.Ignite.Core/Configuration/DataStorageConfiguration.cs
index d5cfe85..2ca4108 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/Configuration/DataStorageConfiguration.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/Configuration/DataStorageConfiguration.cs
@@ -169,6 +169,11 @@ namespace Apache.Ignite.Core.Configuration
         public const long DefaultMaxWalArchiveSize = 1024 * 1024 * 1024;
 
         /// <summary>
+        /// Default value for <see cref="WalPageCompression"/>.
+        /// </summary>
+        public const DiskPageCompression DefaultWalPageCompression = DiskPageCompression.Disabled;
+
+        /// <summary>
         /// Initializes a new instance of the <see cref="DataStorageConfiguration"/> class.
         /// </summary>
         public DataStorageConfiguration()
@@ -196,6 +201,7 @@ namespace Apache.Ignite.Core.Configuration
             PageSize = DefaultPageSize;
             WalAutoArchiveAfterInactivity = DefaultWalAutoArchiveAfterInactivity;
             MaxWalArchiveSize = DefaultMaxWalArchiveSize;
+            WalPageCompression = DefaultWalPageCompression;
         }
 
         /// <summary>
@@ -236,6 +242,8 @@ namespace Apache.Ignite.Core.Configuration
             ConcurrencyLevel = reader.ReadInt();
             WalAutoArchiveAfterInactivity = reader.ReadLongAsTimespan();
             CheckpointReadLockTimeout = reader.ReadTimeSpanNullable();
+            WalPageCompression = (DiskPageCompression)reader.ReadInt();
+            WalPageCompressionLevel = reader.ReadIntNullable();
 
             var count = reader.ReadInt();
 
@@ -290,6 +298,8 @@ namespace Apache.Ignite.Core.Configuration
             writer.WriteInt(ConcurrencyLevel);
             writer.WriteTimeSpanAsLong(WalAutoArchiveAfterInactivity);
             writer.WriteTimeSpanAsLongNullable(CheckpointReadLockTimeout);
+            writer.WriteInt((int)WalPageCompression);
+            writer.WriteIntNullable(WalPageCompressionLevel);
 
             if (DataRegionConfigurations != null)
             {
@@ -498,6 +508,16 @@ namespace Apache.Ignite.Core.Configuration
         public TimeSpan? CheckpointReadLockTimeout { get; set; }
 
         /// <summary>
+        /// Gets or sets the compression algorithm for WAL page snapshot records.
+        /// </summary>
+        public DiskPageCompression WalPageCompression { get; set; }
+
+        /// <summary>
+        /// Gets or sets the compression level for WAL page snapshot records.
+        /// </summary>
+        public int? WalPageCompressionLevel { get; set; }
+
+        /// <summary>
         /// Gets or sets the data region configurations.
         /// </summary>
         [SuppressMessage("Microsoft.Usage", "CA2227:CollectionPropertiesShouldBeReadOnly")]
@@ -508,4 +528,4 @@ namespace Apache.Ignite.Core.Configuration
         /// </summary>
         public DataRegionConfiguration DefaultDataRegionConfiguration { get; set; }
     }
-}
\ No newline at end of file
+}
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/Configuration/DiskPageCompression.cs b/modules/platforms/dotnet/Apache.Ignite.Core/Configuration/DiskPageCompression.cs
new file mode 100644
index 0000000..133ecd1
--- /dev/null
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/Configuration/DiskPageCompression.cs
@@ -0,0 +1,50 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Apache.Ignite.Core.Configuration
+{
+    /// <summary>
+    /// Disk page compression options.
+    /// </summary>
+    public enum DiskPageCompression
+    {
+        /// <summary>
+        /// Compression disabled.
+        /// </summary>
+        Disabled,
+
+        /// <summary>
+        /// Retain only useful data from half-filled pages, but do not apply any compression.
+        /// </summary>
+        SkipGarbage,
+
+        /// <summary>
+        /// Zstd compression.
+        /// </summary>
+        Zstd,
+
+        /// <summary>
+        /// Lz4 compression.
+        /// </summary>
+        Lz4,
+
+        /// <summary>
+        /// Snappy compression.
+        /// </summary>
+        Snappy
+    }
+}
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/IgniteConfigurationSection.xsd b/modules/platforms/dotnet/Apache.Ignite.Core/IgniteConfigurationSection.xsd
index c23cf90..9179048 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/IgniteConfigurationSection.xsd
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/IgniteConfigurationSection.xsd
@@ -117,6 +117,16 @@
         </xs:restriction>
     </xs:simpleType>
 
+    <xs:simpleType name="diskPageCompression" final="restriction">
+        <xs:restriction base="xs:string">
+            <xs:enumeration value="Disabled" />
+            <xs:enumeration value="SkipGarbage" />
+            <xs:enumeration value="Zstd" />
+            <xs:enumeration value="Lz4" />
+            <xs:enumeration value="Snappy" />
+        </xs:restriction>
+    </xs:simpleType>
+
     <xs:element name="igniteConfiguration">
         <xs:annotation>
             <xs:documentation>Ignite configuration root.</xs:documentation>
@@ -1948,6 +1958,16 @@
                                 </xs:documentation>
                             </xs:annotation>
                         </xs:attribute>
+                        <xs:attribute name="walPageCompression" type="diskPageCompression">
+                            <xs:annotation>
+                                <xs:documentation>Compression algorithm for WAL page snapshot records.</xs:documentation>
+                            </xs:annotation>
+                        </xs:attribute>
+                        <xs:attribute name="walPageCompressionLevel" type="xs:int">
+                            <xs:annotation>
+                                <xs:documentation>Compression level for WAL page snapshot records.</xs:documentation>
+                            </xs:annotation>
+                        </xs:attribute>
                     </xs:complexType>
                 </xs:element>
                 <xs:element name="sslContextFactory" minOccurs="0">


[ignite] 16/17: GG-18539: Remove useless dependencies.

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 1aeed470a02cb2584a4020edcf97f856546beb31
Author: Andrey V. Mashenkov <an...@gmail.com>
AuthorDate: Tue Apr 30 12:59:53 2019 +0300

    GG-18539: Remove useless dependencies.
---
 modules/h2/pom.xml                                 |   35 +-
 .../h2/src/main/java/org/h2/fulltext/FullText.java | 1189 --------------------
 .../main/java/org/h2/fulltext/FullTextLucene.java  |  769 -------------
 .../java/org/h2/fulltext/FullTextSettings.java     |  282 -----
 .../src/main/java/org/h2/fulltext/IndexInfo.java   |   42 -
 .../h2/src/main/java/org/h2/fulltext/package.html  |   14 -
 .../main/java/org/h2/util/DbDriverActivator.java   |   52 -
 .../java/org/h2/util/OsgiDataSourceFactory.java    |  305 -----
 .../test/java/org/h2/samples/fullTextSearch.sql    |   59 -
 modules/h2/src/test/java/org/h2/test/TestAll.java  |    5 -
 .../src/test/java/org/h2/test/db/TestDeadlock.java |   36 -
 .../src/test/java/org/h2/test/db/TestFullText.java |  637 -----------
 .../test/java/org/h2/test/unit/TestRecovery.java   |   20 -
 13 files changed, 2 insertions(+), 3443 deletions(-)

diff --git a/modules/h2/pom.xml b/modules/h2/pom.xml
index 480e68a..5ba7a15 100644
--- a/modules/h2/pom.xml
+++ b/modules/h2/pom.xml
@@ -50,8 +50,6 @@
 
     <properties>
         <maven.compiler.source>1.7</maven.compiler.source>
-        <osgi.version>4.2.0</osgi.version>
-        <h2.lucene.version>5.5.5</h2.lucene.version>
         <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
     </properties>
 
@@ -63,39 +61,11 @@
             <version>3.1.0</version>
         </dependency>
         <dependency>
-            <groupId>org.apache.lucene</groupId>
-            <artifactId>lucene-core</artifactId>
-            <version>${h2.lucene.version}</version>
-            <scope>provided</scope>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.lucene</groupId>
-            <artifactId>lucene-analyzers-common</artifactId>
-            <version>${h2.lucene.version}</version>
-            <scope>provided</scope>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.lucene</groupId>
-            <artifactId>lucene-queryparser</artifactId>
-            <version>${h2.lucene.version}</version>
-            <scope>provided</scope>
-        </dependency>
-        <dependency>
             <groupId>org.slf4j</groupId>
             <artifactId>slf4j-api</artifactId>
             <version>${slf4j16.version}</version>
         </dependency>
         <dependency>
-            <groupId>org.osgi</groupId>
-            <artifactId>org.osgi.core</artifactId>
-            <version>${osgi.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.osgi</groupId>
-            <artifactId>org.osgi.enterprise</artifactId>
-            <version>${osgi.version}</version>
-        </dependency>
-        <dependency>
             <groupId>org.locationtech.jts</groupId>
             <artifactId>jts-core</artifactId>
             <version>1.15.0</version>
@@ -110,12 +80,12 @@
             <version>${slf4j16.version}</version>
             <scope>test</scope>
         </dependency>
-        <dependency>
+       <!-- <dependency>
             <groupId>org.postgresql</groupId>
             <artifactId>postgresql</artifactId>
             <version>42.2.5.jre7</version>
             <scope>test</scope>
-        </dependency>
+        </dependency>-->
         <dependency>
             <groupId>org.ow2.asm</groupId>
             <artifactId>asm</artifactId>
@@ -214,7 +184,6 @@
                         <h2.useThreadContextClassLoader>true</h2.useThreadContextClassLoader>
                         <h2.clientTraceDirectory>target/trace.db/</h2.clientTraceDirectory>
                         <h2.javaSystemCompiler>false</h2.javaSystemCompiler>
-                        <!--<java.io.tmpdir>./target/temp</java.io.tmpdir>-->
                     </systemPropertyVariables>
                     <additionalClasspathElements>
                         <additionalClasspathElement>${project.build.outputDirectory}</additionalClasspathElement>
diff --git a/modules/h2/src/main/java/org/h2/fulltext/FullText.java b/modules/h2/src/main/java/org/h2/fulltext/FullText.java
deleted file mode 100644
index a46c90a..0000000
--- a/modules/h2/src/main/java/org/h2/fulltext/FullText.java
+++ /dev/null
@@ -1,1189 +0,0 @@
-/*
- * Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
- * and the EPL 1.0 (http://h2database.com/html/license.html).
- * Initial Developer: H2 Group
- */
-package org.h2.fulltext;
-
-import java.io.IOException;
-import java.io.Reader;
-import java.io.StreamTokenizer;
-import java.sql.Clob;
-import java.sql.Connection;
-import java.sql.DatabaseMetaData;
-import java.sql.PreparedStatement;
-import java.sql.ResultSet;
-import java.sql.SQLException;
-import java.sql.Statement;
-import java.sql.Types;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Collections;
-import java.util.HashSet;
-import java.util.Set;
-import java.util.StringTokenizer;
-import java.util.UUID;
-
-import org.h2.api.Trigger;
-import org.h2.command.Parser;
-import org.h2.engine.Session;
-import org.h2.expression.Expression;
-import org.h2.expression.ExpressionColumn;
-import org.h2.expression.ValueExpression;
-import org.h2.expression.condition.Comparison;
-import org.h2.expression.condition.ConditionAndOr;
-import org.h2.jdbc.JdbcConnection;
-import org.h2.message.DbException;
-import org.h2.tools.SimpleResultSet;
-import org.h2.util.IOUtils;
-import org.h2.util.StringUtils;
-import org.h2.util.Utils;
-
-/**
- * This class implements the native full text search.
- * Most methods can be called using SQL statements as well.
- */
-public class FullText {
-
-    /**
-     * A column name of the result set returned by the searchData method.
-     */
-    private static final String FIELD_SCHEMA = "SCHEMA";
-
-    /**
-     * A column name of the result set returned by the searchData method.
-     */
-    private static final String FIELD_TABLE = "TABLE";
-
-    /**
-     * A column name of the result set returned by the searchData method.
-     */
-    private static final String FIELD_COLUMNS = "COLUMNS";
-
-    /**
-     * A column name of the result set returned by the searchData method.
-     */
-    private static final String FIELD_KEYS = "KEYS";
-
-    /**
-     * The hit score.
-     */
-    private static final String FIELD_SCORE = "SCORE";
-
-    private static final String TRIGGER_PREFIX = "FT_";
-    private static final String SCHEMA = "FT";
-    private static final String SELECT_MAP_BY_WORD_ID =
-            "SELECT ROWID FROM " + SCHEMA + ".MAP WHERE WORDID=?";
-    private static final String SELECT_ROW_BY_ID =
-            "SELECT KEY, INDEXID FROM " + SCHEMA + ".ROWS WHERE ID=?";
-
-    /**
-     * The column name of the result set returned by the search method.
-     */
-    private static final String FIELD_QUERY = "QUERY";
-
-    /**
-     * Initializes full text search functionality for this database. This adds
-     * the following Java functions to the database:
-     * <ul>
-     * <li>FT_CREATE_INDEX(schemaNameString, tableNameString,
-     * columnListString)</li>
-     * <li>FT_SEARCH(queryString, limitInt, offsetInt): result set</li>
-     * <li>FT_REINDEX()</li>
-     * <li>FT_DROP_ALL()</li>
-     * </ul>
-     * It also adds a schema FT to the database where bookkeeping information
-     * is stored. This function may be called from a Java application, or by
-     * using the SQL statements:
-     *
-     * <pre>
-     * CREATE ALIAS IF NOT EXISTS FT_INIT FOR
-     *      &quot;org.h2.fulltext.FullText.init&quot;;
-     * CALL FT_INIT();
-     * </pre>
-     *
-     * @param conn the connection
-     */
-    public static void init(Connection conn) throws SQLException {
-        Statement stat = conn.createStatement();
-        stat.execute("CREATE SCHEMA IF NOT EXISTS " + SCHEMA);
-        stat.execute("CREATE TABLE IF NOT EXISTS " + SCHEMA +
-                ".INDEXES(ID INT AUTO_INCREMENT PRIMARY KEY, " +
-                "SCHEMA VARCHAR, `TABLE` VARCHAR, COLUMNS VARCHAR, " +
-                "UNIQUE(SCHEMA, `TABLE`))");
-        stat.execute("CREATE TABLE IF NOT EXISTS " + SCHEMA +
-                ".WORDS(ID INT AUTO_INCREMENT PRIMARY KEY, " +
-                "NAME VARCHAR, UNIQUE(NAME))");
-        stat.execute("CREATE TABLE IF NOT EXISTS " + SCHEMA +
-                ".ROWS(ID IDENTITY, HASH INT, INDEXID INT, " +
-                "KEY VARCHAR, UNIQUE(HASH, INDEXID, KEY))");
-        stat.execute("CREATE TABLE IF NOT EXISTS " + SCHEMA +
-                ".MAP(ROWID INT, WORDID INT, PRIMARY KEY(WORDID, ROWID))");
-        stat.execute("CREATE TABLE IF NOT EXISTS " + SCHEMA +
-                ".IGNORELIST(LIST VARCHAR)");
-        stat.execute("CREATE TABLE IF NOT EXISTS " + SCHEMA +
-                ".SETTINGS(KEY VARCHAR PRIMARY KEY, VALUE VARCHAR)");
-        stat.execute("CREATE ALIAS IF NOT EXISTS FT_CREATE_INDEX FOR \"" +
-                FullText.class.getName() + ".createIndex\"");
-        stat.execute("CREATE ALIAS IF NOT EXISTS FT_DROP_INDEX FOR \"" +
-                FullText.class.getName() + ".dropIndex\"");
-        stat.execute("CREATE ALIAS IF NOT EXISTS FT_SEARCH FOR \"" +
-                FullText.class.getName() + ".search\"");
-        stat.execute("CREATE ALIAS IF NOT EXISTS FT_SEARCH_DATA FOR \"" +
-                FullText.class.getName() + ".searchData\"");
-        stat.execute("CREATE ALIAS IF NOT EXISTS FT_REINDEX FOR \"" +
-                FullText.class.getName() + ".reindex\"");
-        stat.execute("CREATE ALIAS IF NOT EXISTS FT_DROP_ALL FOR \"" +
-                FullText.class.getName() + ".dropAll\"");
-        FullTextSettings setting = FullTextSettings.getInstance(conn);
-        ResultSet rs = stat.executeQuery("SELECT * FROM " + SCHEMA +
-                ".IGNORELIST");
-        while (rs.next()) {
-            String commaSeparatedList = rs.getString(1);
-            setIgnoreList(setting, commaSeparatedList);
-        }
-        rs = stat.executeQuery("SELECT * FROM " + SCHEMA + ".SETTINGS");
-        while (rs.next()) {
-            String key = rs.getString(1);
-            if ("whitespaceChars".equals(key)) {
-                String value = rs.getString(2);
-                setting.setWhitespaceChars(value);
-            }
-        }
-        rs = stat.executeQuery("SELECT * FROM " + SCHEMA + ".WORDS");
-        while (rs.next()) {
-            String word = rs.getString("NAME");
-            int id = rs.getInt("ID");
-            word = setting.convertWord(word);
-            if (word != null) {
-                setting.addWord(word, id);
-            }
-        }
-        setting.setInitialized(true);
-    }
-
-    /**
-     * Create a new full text index for a table and column list. Each table may
-     * only have one index at any time.
-     *
-     * @param conn the connection
-     * @param schema the schema name of the table (case sensitive)
-     * @param table the table name (case sensitive)
-     * @param columnList the column list (null for all columns)
-     */
-    public static void createIndex(Connection conn, String schema,
-            String table, String columnList) throws SQLException {
-        init(conn);
-        PreparedStatement prep = conn.prepareStatement("INSERT INTO " + SCHEMA
-                + ".INDEXES(SCHEMA, `TABLE`, COLUMNS) VALUES(?, ?, ?)");
-        prep.setString(1, schema);
-        prep.setString(2, table);
-        prep.setString(3, columnList);
-        prep.execute();
-        createTrigger(conn, schema, table);
-        indexExistingRows(conn, schema, table);
-    }
-
-    /**
-     * Re-creates the full text index for this database. Calling this method is
-     * usually not needed, as the index is kept up-to-date automatically.
-     *
-     * @param conn the connection
-     */
-    public static void reindex(Connection conn) throws SQLException {
-        init(conn);
-        removeAllTriggers(conn, TRIGGER_PREFIX);
-        FullTextSettings setting = FullTextSettings.getInstance(conn);
-        setting.clearWordList();
-        Statement stat = conn.createStatement();
-        stat.execute("TRUNCATE TABLE " + SCHEMA + ".WORDS");
-        stat.execute("TRUNCATE TABLE " + SCHEMA + ".ROWS");
-        stat.execute("TRUNCATE TABLE " + SCHEMA + ".MAP");
-        ResultSet rs = stat.executeQuery("SELECT * FROM " + SCHEMA + ".INDEXES");
-        while (rs.next()) {
-            String schema = rs.getString("SCHEMA");
-            String table = rs.getString("TABLE");
-            createTrigger(conn, schema, table);
-            indexExistingRows(conn, schema, table);
-        }
-    }
-
-    /**
-     * Drop an existing full text index for a table. This method returns
-     * silently if no index for this table exists.
-     *
-     * @param conn the connection
-     * @param schema the schema name of the table (case sensitive)
-     * @param table the table name (case sensitive)
-     */
-    public static void dropIndex(Connection conn, String schema, String table)
-            throws SQLException {
-        init(conn);
-        PreparedStatement prep = conn.prepareStatement("SELECT ID FROM " + SCHEMA
-                + ".INDEXES WHERE SCHEMA=? AND `TABLE`=?");
-        prep.setString(1, schema);
-        prep.setString(2, table);
-        ResultSet rs = prep.executeQuery();
-        if (!rs.next()) {
-            return;
-        }
-        int indexId = rs.getInt(1);
-        prep = conn.prepareStatement("DELETE FROM " + SCHEMA
-                + ".INDEXES WHERE ID=?");
-        prep.setInt(1, indexId);
-        prep.execute();
-        createOrDropTrigger(conn, schema, table, false);
-        prep = conn.prepareStatement("DELETE FROM " + SCHEMA +
-                ".ROWS WHERE INDEXID=? AND ROWNUM<10000");
-        while (true) {
-            prep.setInt(1, indexId);
-            int deleted = prep.executeUpdate();
-            if (deleted == 0) {
-                break;
-            }
-        }
-        prep = conn.prepareStatement("DELETE FROM " + SCHEMA + ".MAP " +
-                "WHERE NOT EXISTS (SELECT * FROM " + SCHEMA +
-                ".ROWS R WHERE R.ID=ROWID) AND ROWID<10000");
-        while (true) {
-            int deleted = prep.executeUpdate();
-            if (deleted == 0) {
-                break;
-            }
-        }
-    }
-
-    /**
-     * Drops all full text indexes from the database.
-     *
-     * @param conn the connection
-     */
-    public static void dropAll(Connection conn) throws SQLException {
-        init(conn);
-        Statement stat = conn.createStatement();
-        stat.execute("DROP SCHEMA IF EXISTS " + SCHEMA + " CASCADE");
-        removeAllTriggers(conn, TRIGGER_PREFIX);
-        FullTextSettings setting = FullTextSettings.getInstance(conn);
-        setting.removeAllIndexes();
-        setting.clearIgnored();
-        setting.clearWordList();
-    }
-
-    /**
-     * Searches from the full text index for this database.
-     * The returned result set has the following column:
-     * <ul><li>QUERY (varchar): the query to use to get the data.
-     * The query does not include 'SELECT * FROM '. Example:
-     * PUBLIC.TEST WHERE ID = 1
-     * </li><li>SCORE (float) the relevance score. This value is always 1.0
-     * for the native fulltext search.
-     * </li></ul>
-     *
-     * @param conn the connection
-     * @param text the search query
-     * @param limit the maximum number of rows or 0 for no limit
-     * @param offset the offset or 0 for no offset
-     * @return the result set
-     */
-    public static ResultSet search(Connection conn, String text, int limit,
-            int offset) throws SQLException {
-        try {
-            return search(conn, text, limit, offset, false);
-        } catch (DbException e) {
-            throw DbException.toSQLException(e);
-        }
-    }
-
-    /**
-     * Searches from the full text index for this database. The result contains
-     * the primary key data as an array. The returned result set has the
-     * following columns:
-     * <ul>
-     * <li>SCHEMA (varchar): the schema name. Example: PUBLIC </li>
-     * <li>TABLE (varchar): the table name. Example: TEST </li>
-     * <li>COLUMNS (array of varchar): comma separated list of quoted column
-     * names. The column names are quoted if necessary. Example: (ID) </li>
-     * <li>KEYS (array of values): comma separated list of values. Example: (1)
-     * </li>
-     * <li>SCORE (float) the relevance score. This value is always 1.0
-     * for the native fulltext search.
-     * </li>
-     * </ul>
-     *
-     * @param conn the connection
-     * @param text the search query
-     * @param limit the maximum number of rows or 0 for no limit
-     * @param offset the offset or 0 for no offset
-     * @return the result set
-     */
-    public static ResultSet searchData(Connection conn, String text, int limit,
-            int offset) throws SQLException {
-        try {
-            return search(conn, text, limit, offset, true);
-        } catch (DbException e) {
-            throw DbException.toSQLException(e);
-        }
-    }
-
-    /**
-     * Change the ignore list. The ignore list is a comma separated list of
-     * common words that must not be indexed. The default ignore list is empty.
-     * If indexes already exist at the time this list is changed, reindex must
-     * be called.
-     *
-     * @param conn the connection
-     * @param commaSeparatedList the list
-     */
-    public static void setIgnoreList(Connection conn, String commaSeparatedList)
-            throws SQLException {
-        try {
-            init(conn);
-            FullTextSettings setting = FullTextSettings.getInstance(conn);
-            setIgnoreList(setting, commaSeparatedList);
-            Statement stat = conn.createStatement();
-            stat.execute("TRUNCATE TABLE " + SCHEMA + ".IGNORELIST");
-            PreparedStatement prep = conn.prepareStatement("INSERT INTO " +
-                    SCHEMA + ".IGNORELIST VALUES(?)");
-            prep.setString(1, commaSeparatedList);
-            prep.execute();
-        } catch (DbException e) {
-            throw DbException.toSQLException(e);
-        }
-    }
-
-    /**
-     * Change the whitespace characters. The whitespace characters are used to
-     * separate words. If indexes already exist at the time this list is
-     * changed, reindex must be called.
-     *
-     * @param conn the connection
-     * @param whitespaceChars the list of characters
-     */
-    public static void setWhitespaceChars(Connection conn,
-            String whitespaceChars) throws SQLException {
-        try {
-            init(conn);
-            FullTextSettings setting = FullTextSettings.getInstance(conn);
-            setting.setWhitespaceChars(whitespaceChars);
-            PreparedStatement prep = conn.prepareStatement("MERGE INTO " +
-                    SCHEMA + ".SETTINGS VALUES(?, ?)");
-            prep.setString(1, "whitespaceChars");
-            prep.setString(2, whitespaceChars);
-            prep.execute();
-        } catch (DbException e) {
-            throw DbException.toSQLException(e);
-        }
-    }
-
-    /**
-     * INTERNAL.
-     * Convert the object to a string.
-     *
-     * @param data the object
-     * @param type the SQL type
-     * @return the string
-     */
-    protected static String asString(Object data, int type) throws SQLException {
-        if (data == null) {
-            return "NULL";
-        }
-        switch (type) {
-        case Types.BIT:
-        case Types.BOOLEAN:
-        case Types.INTEGER:
-        case Types.BIGINT:
-        case Types.DECIMAL:
-        case Types.DOUBLE:
-        case Types.FLOAT:
-        case Types.NUMERIC:
-        case Types.REAL:
-        case Types.SMALLINT:
-        case Types.TINYINT:
-        case Types.DATE:
-        case Types.TIME:
-        case Types.TIMESTAMP:
-        case Types.LONGVARCHAR:
-        case Types.CHAR:
-        case Types.VARCHAR:
-            return data.toString();
-        case Types.CLOB:
-            try {
-                if (data instanceof Clob) {
-                    data = ((Clob) data).getCharacterStream();
-                }
-                return IOUtils.readStringAndClose((Reader) data, -1);
-            } catch (IOException e) {
-                throw DbException.toSQLException(e);
-            }
-        case Types.VARBINARY:
-        case Types.LONGVARBINARY:
-        case Types.BINARY:
-        case Types.JAVA_OBJECT:
-        case Types.OTHER:
-        case Types.BLOB:
-        case Types.STRUCT:
-        case Types.REF:
-        case Types.NULL:
-        case Types.ARRAY:
-        case Types.DATALINK:
-        case Types.DISTINCT:
-            throw throwException("Unsupported column data type: " + type);
-        default:
-            return "";
-        }
-    }
-
-    /**
-     * Create an empty search result and initialize the columns.
-     *
-     * @param data true if the result set should contain the primary key data as
-     *            an array.
-     * @return the empty result set
-     */
-    protected static SimpleResultSet createResultSet(boolean data) {
-        SimpleResultSet result = new SimpleResultSet();
-        if (data) {
-            result.addColumn(FullText.FIELD_SCHEMA, Types.VARCHAR, 0, 0);
-            result.addColumn(FullText.FIELD_TABLE, Types.VARCHAR, 0, 0);
-            result.addColumn(FullText.FIELD_COLUMNS, Types.ARRAY, 0, 0);
-            result.addColumn(FullText.FIELD_KEYS, Types.ARRAY, 0, 0);
-        } else {
-            result.addColumn(FullText.FIELD_QUERY, Types.VARCHAR, 0, 0);
-        }
-        result.addColumn(FullText.FIELD_SCORE, Types.FLOAT, 0, 0);
-        return result;
-    }
-
-    /**
-     * Parse a primary key condition into the primary key columns.
-     *
-     * @param conn the database connection
-     * @param key the primary key condition as a string
-     * @return an array containing the column name list and the data list
-     */
-    protected static Object[][] parseKey(Connection conn, String key) {
-        ArrayList<String> columns = Utils.newSmallArrayList();
-        ArrayList<String> data = Utils.newSmallArrayList();
-        JdbcConnection c = (JdbcConnection) conn;
-        Session session = (Session) c.getSession();
-        Parser p = new Parser(session);
-        Expression expr = p.parseExpression(key);
-        addColumnData(columns, data, expr);
-        Object[] col = columns.toArray();
-        Object[] dat = data.toArray();
-        Object[][] columnData = { col, dat };
-        return columnData;
-    }
-
-    /**
-     * INTERNAL.
-     * Convert an object to a String as used in a SQL statement.
-     *
-     * @param data the object
-     * @param type the SQL type
-     * @return the SQL String
-     */
-    protected static String quoteSQL(Object data, int type) throws SQLException {
-        if (data == null) {
-            return "NULL";
-        }
-        switch (type) {
-        case Types.BIT:
-        case Types.BOOLEAN:
-        case Types.INTEGER:
-        case Types.BIGINT:
-        case Types.DECIMAL:
-        case Types.DOUBLE:
-        case Types.FLOAT:
-        case Types.NUMERIC:
-        case Types.REAL:
-        case Types.SMALLINT:
-        case Types.TINYINT:
-            return data.toString();
-        case Types.DATE:
-        case Types.TIME:
-        case Types.TIMESTAMP:
-        case Types.LONGVARCHAR:
-        case Types.CHAR:
-        case Types.VARCHAR:
-            return quoteString(data.toString());
-        case Types.VARBINARY:
-        case Types.LONGVARBINARY:
-        case Types.BINARY:
-            if (data instanceof UUID) {
-                return "'" + data.toString() + "'";
-            }
-            byte[] bytes = (byte[]) data;
-            StringBuilder builder = new StringBuilder(bytes.length * 2 + 2).append('\'');
-            StringUtils.convertBytesToHex(builder, bytes).append('\'');
-            return builder.toString();
-        case Types.CLOB:
-        case Types.JAVA_OBJECT:
-        case Types.OTHER:
-        case Types.BLOB:
-        case Types.STRUCT:
-        case Types.REF:
-        case Types.NULL:
-        case Types.ARRAY:
-        case Types.DATALINK:
-        case Types.DISTINCT:
-            throw throwException("Unsupported key data type: " + type);
-        default:
-            return "";
-        }
-    }
-
-    /**
-     * Remove all triggers that start with the given prefix.
-     *
-     * @param conn the database connection
-     * @param prefix the prefix
-     */
-    protected static void removeAllTriggers(Connection conn, String prefix)
-            throws SQLException {
-        Statement stat = conn.createStatement();
-        ResultSet rs = stat.executeQuery("SELECT * FROM INFORMATION_SCHEMA.TRIGGERS");
-        Statement stat2 = conn.createStatement();
-        while (rs.next()) {
-            String schema = rs.getString("TRIGGER_SCHEMA");
-            String name = rs.getString("TRIGGER_NAME");
-            if (name.startsWith(prefix)) {
-                name = StringUtils.quoteIdentifier(schema) + "." +
-                        StringUtils.quoteIdentifier(name);
-                stat2.execute("DROP TRIGGER " + name);
-            }
-        }
-    }
-
-    /**
-     * Set the column indices of a set of keys.
-     *
-     * @param index the column indices (will be modified)
-     * @param keys the key list
-     * @param columns the column list
-     */
-    protected static void setColumns(int[] index, ArrayList<String> keys,
-            ArrayList<String> columns) throws SQLException {
-        for (int i = 0, keySize = keys.size(); i < keySize; i++) {
-            String key = keys.get(i);
-            int found = -1;
-            int columnsSize = columns.size();
-            for (int j = 0; found == -1 && j < columnsSize; j++) {
-                String column = columns.get(j);
-                if (column.equals(key)) {
-                    found = j;
-                }
-            }
-            if (found < 0) {
-                throw throwException("Column not found: " + key);
-            }
-            index[i] = found;
-        }
-    }
-
-    /**
-     * Do the search.
-     *
-     * @param conn the database connection
-     * @param text the query
-     * @param limit the limit
-     * @param offset the offset
-     * @param data whether the raw data should be returned
-     * @return the result set
-     */
-    protected static ResultSet search(Connection conn, String text, int limit,
-            int offset, boolean data) throws SQLException {
-        SimpleResultSet result = createResultSet(data);
-        if (conn.getMetaData().getURL().startsWith("jdbc:columnlist:")) {
-            // this is just to query the result set columns
-            return result;
-        }
-        if (text == null || StringUtils.isWhitespaceOrEmpty(text)) {
-            return result;
-        }
-        FullTextSettings setting = FullTextSettings.getInstance(conn);
-        if (!setting.isInitialized()) {
-            init(conn);
-        }
-        Set<String> words = new HashSet<>();
-        addWords(setting, words, text);
-        Set<Integer> rIds = null, lastRowIds;
-
-        PreparedStatement prepSelectMapByWordId = setting.prepare(conn,
-                SELECT_MAP_BY_WORD_ID);
-        for (String word : words) {
-            lastRowIds = rIds;
-            rIds = new HashSet<>();
-            Integer wId = setting.getWordId(word);
-            if (wId == null) {
-                continue;
-            }
-            prepSelectMapByWordId.setInt(1, wId);
-            ResultSet rs = prepSelectMapByWordId.executeQuery();
-            while (rs.next()) {
-                Integer rId = rs.getInt(1);
-                if (lastRowIds == null || lastRowIds.contains(rId)) {
-                    rIds.add(rId);
-                }
-            }
-        }
-        if (rIds == null || rIds.isEmpty()) {
-            return result;
-        }
-        PreparedStatement prepSelectRowById = setting.prepare(conn, SELECT_ROW_BY_ID);
-        int rowCount = 0;
-        for (int rowId : rIds) {
-            prepSelectRowById.setInt(1, rowId);
-            ResultSet rs = prepSelectRowById.executeQuery();
-            if (!rs.next()) {
-                continue;
-            }
-            if (offset > 0) {
-                offset--;
-            } else {
-                String key = rs.getString(1);
-                int indexId = rs.getInt(2);
-                IndexInfo index = setting.getIndexInfo(indexId);
-                if (data) {
-                    Object[][] columnData = parseKey(conn, key);
-                    result.addRow(
-                            index.schema,
-                            index.table,
-                            columnData[0],
-                            columnData[1],
-                            1.0);
-                } else {
-                    String query = StringUtils.quoteIdentifier(index.schema) +
-                        "." + StringUtils.quoteIdentifier(index.table) +
-                        " WHERE " + key;
-                    result.addRow(query, 1.0);
-                }
-                rowCount++;
-                if (limit > 0 && rowCount >= limit) {
-                    break;
-                }
-            }
-        }
-        return result;
-    }
-
-    private static void addColumnData(ArrayList<String> columns,
-            ArrayList<String> data, Expression expr) {
-        if (expr instanceof ConditionAndOr) {
-            ConditionAndOr and = (ConditionAndOr) expr;
-            addColumnData(columns, data, and.getSubexpression(0));
-            addColumnData(columns, data, and.getSubexpression(1));
-        } else {
-            Comparison comp = (Comparison) expr;
-            ExpressionColumn ec = (ExpressionColumn) comp.getSubexpression(0);
-            String columnName = ec.getColumnName();
-            columns.add(columnName);
-            if (expr.getSubexpressionCount() == 1) {
-                data.add(null);
-            } else {
-                ValueExpression ev = (ValueExpression) comp.getSubexpression(1);
-                data.add(ev.getValue(null).getString());
-            }
-        }
-    }
-
-    /**
-     * Add all words in the given text to the hash set.
-     *
-     * @param setting the fulltext settings
-     * @param set the hash set
-     * @param reader the reader
-     */
-    protected static void addWords(FullTextSettings setting,
-            Set<String> set, Reader reader) {
-        StreamTokenizer tokenizer = new StreamTokenizer(reader);
-        tokenizer.resetSyntax();
-        tokenizer.wordChars(' ' + 1, 255);
-        char[] whitespaceChars = setting.getWhitespaceChars().toCharArray();
-        for (char ch : whitespaceChars) {
-            tokenizer.whitespaceChars(ch, ch);
-        }
-        try {
-            while (true) {
-                int token = tokenizer.nextToken();
-                if (token == StreamTokenizer.TT_EOF) {
-                    break;
-                } else if (token == StreamTokenizer.TT_WORD) {
-                    String word = tokenizer.sval;
-                    word = setting.convertWord(word);
-                    if (word != null) {
-                        set.add(word);
-                    }
-                }
-            }
-        } catch (IOException e) {
-            throw DbException.convertIOException(e, "Tokenizer error");
-        }
-    }
-
-    /**
-     * Add all words in the given text to the hash set.
-     *
-     * @param setting the fulltext settings
-     * @param set the hash set
-     * @param text the text
-     */
-    protected static void addWords(FullTextSettings setting,
-            Set<String> set, String text) {
-        String whitespaceChars = setting.getWhitespaceChars();
-        StringTokenizer tokenizer = new StringTokenizer(text, whitespaceChars);
-        while (tokenizer.hasMoreTokens()) {
-            String word = tokenizer.nextToken();
-            word = setting.convertWord(word);
-            if (word != null) {
-                set.add(word);
-            }
-        }
-    }
-
-    /**
-     * Create the trigger.
-     *
-     * @param conn the database connection
-     * @param schema the schema name
-     * @param table the table name
-     */
-    private static void createTrigger(Connection conn, String schema,
-            String table) throws SQLException {
-        createOrDropTrigger(conn, schema, table, true);
-    }
-
-    private static void createOrDropTrigger(Connection conn,
-            String schema, String table, boolean create) throws SQLException {
-        try (Statement stat = conn.createStatement()) {
-            String trigger = StringUtils.quoteIdentifier(schema) + "."
-                    + StringUtils.quoteIdentifier(TRIGGER_PREFIX + table);
-            stat.execute("DROP TRIGGER IF EXISTS " + trigger);
-            if (create) {
-                boolean multiThread = FullTextTrigger.isMultiThread(conn);
-                StringBuilder buff = new StringBuilder(
-                        "CREATE TRIGGER IF NOT EXISTS ");
-                // unless multithread, trigger needs to be called on rollback as well,
-                // because we use the init connection do to changes in the index
-                // (not the user connection)
-                buff.append(trigger).
-                        append(" AFTER INSERT, UPDATE, DELETE");
-                if(!multiThread) {
-                    buff.append(", ROLLBACK");
-                }
-                buff.append(" ON ");
-                StringUtils.quoteIdentifier(buff, schema).
-                        append('.');
-                StringUtils.quoteIdentifier(buff, table).
-                        append(" FOR EACH ROW CALL \"").
-                        append(FullText.FullTextTrigger.class.getName()).
-                        append('"');
-                stat.execute(buff.toString());
-            }
-        }
-    }
-
-    /**
-     * Add the existing data to the index.
-     *
-     * @param conn the database connection
-     * @param schema the schema name
-     * @param table the table name
-     */
-    private static void indexExistingRows(Connection conn, String schema,
-            String table) throws SQLException {
-        FullText.FullTextTrigger existing = new FullText.FullTextTrigger();
-        existing.init(conn, schema, null, table, false, Trigger.INSERT);
-        String sql = "SELECT * FROM " + StringUtils.quoteIdentifier(schema)
-                + "." + StringUtils.quoteIdentifier(table);
-        ResultSet rs = conn.createStatement().executeQuery(sql);
-        int columnCount = rs.getMetaData().getColumnCount();
-        while (rs.next()) {
-            Object[] row = new Object[columnCount];
-            for (int i = 0; i < columnCount; i++) {
-                row[i] = rs.getObject(i + 1);
-            }
-            existing.fire(conn, null, row);
-        }
-    }
-
-    private static String quoteString(String data) {
-        if (data.indexOf('\'') < 0) {
-            return "'" + data + "'";
-        }
-        int len = data.length();
-        StringBuilder buff = new StringBuilder(len + 2);
-        buff.append('\'');
-        for (int i = 0; i < len; i++) {
-            char ch = data.charAt(i);
-            if (ch == '\'') {
-                buff.append(ch);
-            }
-            buff.append(ch);
-        }
-        buff.append('\'');
-        return buff.toString();
-    }
-
-    private static void setIgnoreList(FullTextSettings setting,
-            String commaSeparatedList) {
-        String[] list = StringUtils.arraySplit(commaSeparatedList, ',', true);
-        setting.addIgnored(Arrays.asList(list));
-    }
-
-    /**
-     * Check if a the indexed columns of a row probably have changed. It may
-     * return true even if the change was minimal (for example from 0.0 to
-     * 0.00).
-     *
-     * @param oldRow the old row
-     * @param newRow the new row
-     * @param indexColumns the indexed columns
-     * @return true if the indexed columns don't match
-     */
-    protected static boolean hasChanged(Object[] oldRow, Object[] newRow,
-            int[] indexColumns) {
-        for (int c : indexColumns) {
-            Object o = oldRow[c], n = newRow[c];
-            if (o == null) {
-                if (n != null) {
-                    return true;
-                }
-            } else if (!o.equals(n)) {
-                return true;
-            }
-        }
-        return false;
-    }
-
-    /**
-     * Trigger updates the index when a inserting, updating, or deleting a row.
-     */
-    public static final class FullTextTrigger implements Trigger {
-        private FullTextSettings          setting;
-        private IndexInfo                 index;
-        private int[]                     columnTypes;
-        private final PreparedStatement[] prepStatements = new PreparedStatement[SQL.length];
-        private boolean                   useOwnConnection;
-
-        private static final int INSERT_WORD = 0;
-        private static final int INSERT_ROW  = 1;
-        private static final int INSERT_MAP  = 2;
-        private static final int DELETE_ROW  = 3;
-        private static final int DELETE_MAP  = 4;
-        private static final int SELECT_ROW  = 5;
-
-        private static final String SQL[] = {
-            "MERGE INTO " + SCHEMA + ".WORDS(NAME) KEY(NAME) VALUES(?)",
-            "INSERT INTO " + SCHEMA + ".ROWS(HASH, INDEXID, KEY) VALUES(?, ?, ?)",
-            "INSERT INTO " + SCHEMA + ".MAP(ROWID, WORDID) VALUES(?, ?)",
-            "DELETE FROM " + SCHEMA + ".ROWS WHERE HASH=? AND INDEXID=? AND KEY=?",
-            "DELETE FROM " + SCHEMA + ".MAP WHERE ROWID=? AND WORDID=?",
-            "SELECT ID FROM " + SCHEMA + ".ROWS WHERE HASH=? AND INDEXID=? AND KEY=?"
-        };
-
-        /**
-         * INTERNAL
-         */
-        @Override
-        public void init(Connection conn, String schemaName, String triggerName,
-                String tableName, boolean before, int type) throws SQLException {
-            setting = FullTextSettings.getInstance(conn);
-            if (!setting.isInitialized()) {
-                FullText.init(conn);
-            }
-            ArrayList<String> keyList = Utils.newSmallArrayList();
-            DatabaseMetaData meta = conn.getMetaData();
-            ResultSet rs = meta.getColumns(null,
-                    StringUtils.escapeMetaDataPattern(schemaName),
-                    StringUtils.escapeMetaDataPattern(tableName),
-                    null);
-            ArrayList<String> columnList = Utils.newSmallArrayList();
-            while (rs.next()) {
-                columnList.add(rs.getString("COLUMN_NAME"));
-            }
-            columnTypes = new int[columnList.size()];
-            index = new IndexInfo();
-            index.schema = schemaName;
-            index.table = tableName;
-            index.columns = columnList.toArray(new String[0]);
-            rs = meta.getColumns(null,
-                    StringUtils.escapeMetaDataPattern(schemaName),
-                    StringUtils.escapeMetaDataPattern(tableName),
-                    null);
-            for (int i = 0; rs.next(); i++) {
-                columnTypes[i] = rs.getInt("DATA_TYPE");
-            }
-            if (keyList.isEmpty()) {
-                rs = meta.getPrimaryKeys(null,
-                        StringUtils.escapeMetaDataPattern(schemaName),
-                        tableName);
-                while (rs.next()) {
-                    keyList.add(rs.getString("COLUMN_NAME"));
-                }
-            }
-            if (keyList.isEmpty()) {
-                throw throwException("No primary key for table " + tableName);
-            }
-            ArrayList<String> indexList = Utils.newSmallArrayList();
-            PreparedStatement prep = conn.prepareStatement(
-                    "SELECT ID, COLUMNS FROM " + SCHEMA + ".INDEXES" +
-                    " WHERE SCHEMA=? AND `TABLE`=?");
-            prep.setString(1, schemaName);
-            prep.setString(2, tableName);
-            rs = prep.executeQuery();
-            if (rs.next()) {
-                index.id = rs.getInt(1);
-                String columns = rs.getString(2);
-                if (columns != null) {
-                    Collections.addAll(indexList, StringUtils.arraySplit(columns, ',', true));
-                }
-            }
-            if (indexList.isEmpty()) {
-                indexList.addAll(columnList);
-            }
-            index.keys = new int[keyList.size()];
-            setColumns(index.keys, keyList, columnList);
-            index.indexColumns = new int[indexList.size()];
-            setColumns(index.indexColumns, indexList, columnList);
-            setting.addIndexInfo(index);
-
-            useOwnConnection = isMultiThread(conn);
-            if(!useOwnConnection) {
-                for (int i = 0; i < SQL.length; i++) {
-                    prepStatements[i] = conn.prepareStatement(SQL[i],
-                            Statement.RETURN_GENERATED_KEYS);
-                }
-            }
-        }
-
-        /**
-         * Check whether the database is in multi-threaded mode.
-         *
-         * @param conn the connection
-         * @return true if the multi-threaded mode is used
-         */
-        static boolean isMultiThread(Connection conn)
-                throws SQLException {
-            try (Statement stat = conn.createStatement()) {
-                ResultSet rs = stat.executeQuery(
-                                "SELECT value FROM information_schema.settings" +
-                                " WHERE name = 'MULTI_THREADED'");
-                return rs.next() && !"0".equals(rs.getString(1));
-            }
-        }
-
-        /**
-         * INTERNAL
-         */
-        @Override
-        public void fire(Connection conn, Object[] oldRow, Object[] newRow)
-                throws SQLException {
-            if (oldRow != null) {
-                if (newRow != null) {
-                    // update
-                    if (hasChanged(oldRow, newRow, index.indexColumns)) {
-                        delete(conn, oldRow);
-                        insert(conn, newRow);
-                    }
-                } else {
-                    // delete
-                    delete(conn, oldRow);
-                }
-            } else if (newRow != null) {
-                // insert
-                insert(conn, newRow);
-            }
-        }
-
-        /**
-         * INTERNAL
-         */
-        @Override
-        public void close() {
-            setting.removeIndexInfo(index);
-        }
-
-        /**
-         * INTERNAL
-         */
-        @Override
-        public void remove() {
-            setting.removeIndexInfo(index);
-        }
-
-        /**
-         * Add a row to the index.
-         *
-         * @param conn to use
-         * @param row the row
-         */
-        protected void insert(Connection conn, Object[] row) throws SQLException {
-            PreparedStatement prepInsertRow = null;
-            PreparedStatement prepInsertMap = null;
-            try {
-                String key = getKey(row);
-                int hash = key.hashCode();
-                prepInsertRow = getStatement(conn, INSERT_ROW);
-                prepInsertRow.setInt(1, hash);
-                prepInsertRow.setInt(2, index.id);
-                prepInsertRow.setString(3, key);
-                prepInsertRow.execute();
-                ResultSet rs = prepInsertRow.getGeneratedKeys();
-                rs.next();
-                int rowId = rs.getInt(1);
-
-                prepInsertMap = getStatement(conn, INSERT_MAP);
-                prepInsertMap.setInt(1, rowId);
-                int[] wordIds = getWordIds(conn, row);
-                for (int id : wordIds) {
-                    prepInsertMap.setInt(2, id);
-                    prepInsertMap.execute();
-                }
-            } finally {
-                if (useOwnConnection) {
-                    IOUtils.closeSilently(prepInsertRow);
-                    IOUtils.closeSilently(prepInsertMap);
-                }
-            }
-        }
-
-        /**
-         * Delete a row from the index.
-         *
-         * @param conn to use
-         * @param row the row
-         */
-        protected void delete(Connection conn, Object[] row) throws SQLException {
-            PreparedStatement prepSelectRow = null;
-            PreparedStatement prepDeleteMap = null;
-            PreparedStatement prepDeleteRow = null;
-            try {
-                String key = getKey(row);
-                int hash = key.hashCode();
-                prepSelectRow = getStatement(conn, SELECT_ROW);
-                prepSelectRow.setInt(1, hash);
-                prepSelectRow.setInt(2, index.id);
-                prepSelectRow.setString(3, key);
-                ResultSet rs = prepSelectRow.executeQuery();
-                prepDeleteMap = getStatement(conn, DELETE_MAP);
-                prepDeleteRow = getStatement(conn, DELETE_ROW);
-                if (rs.next()) {
-                    int rowId = rs.getInt(1);
-                    prepDeleteMap.setInt(1, rowId);
-                    int[] wordIds = getWordIds(conn, row);
-                    for (int id : wordIds) {
-                        prepDeleteMap.setInt(2, id);
-                        prepDeleteMap.executeUpdate();
-                    }
-                    prepDeleteRow.setInt(1, hash);
-                    prepDeleteRow.setInt(2, index.id);
-                    prepDeleteRow.setString(3, key);
-                    prepDeleteRow.executeUpdate();
-                }
-            } finally {
-                if (useOwnConnection) {
-                    IOUtils.closeSilently(prepSelectRow);
-                    IOUtils.closeSilently(prepDeleteMap);
-                    IOUtils.closeSilently(prepDeleteRow);
-                }
-            }
-        }
-
-        private int[] getWordIds(Connection conn, Object[] row) throws SQLException {
-            HashSet<String> words = new HashSet<>();
-            for (int idx : index.indexColumns) {
-                int type = columnTypes[idx];
-                Object data = row[idx];
-                if (type == Types.CLOB && data != null) {
-                    Reader reader;
-                    if (data instanceof Reader) {
-                        reader = (Reader) data;
-                    } else {
-                        reader = ((Clob) data).getCharacterStream();
-                    }
-                    addWords(setting, words, reader);
-                } else {
-                    String string = asString(data, type);
-                    addWords(setting, words, string);
-                }
-            }
-            PreparedStatement prepInsertWord = null;
-            try {
-                prepInsertWord = getStatement(conn, INSERT_WORD);
-                int[] wordIds = new int[words.size()];
-                int i = 0;
-                for (String word : words) {
-                    int wordId;
-                    Integer wId;
-                    while((wId = setting.getWordId(word)) == null) {
-                        prepInsertWord.setString(1, word);
-                        prepInsertWord.execute();
-                        ResultSet rs = prepInsertWord.getGeneratedKeys();
-                        if (rs.next()) {
-                            wordId = rs.getInt(1);
-                            if (wordId != 0) {
-                                setting.addWord(word, wordId);
-                                wId = wordId;
-                                break;
-                            }
-                        }
-                    }
-                    wordIds[i++] = wId;
-                }
-                Arrays.sort(wordIds);
-                return wordIds;
-            } finally {
-                if (useOwnConnection) {
-                    IOUtils.closeSilently(prepInsertWord);
-                }
-            }
-        }
-
-        private String getKey(Object[] row) throws SQLException {
-            StringBuilder builder = new StringBuilder();
-            int[] keys = index.keys;
-            for (int i = 0, l = keys.length; i < l; i++) {
-                if (i > 0) {
-                    builder.append(" AND ");
-                }
-                int columnIndex = keys[i];
-                StringUtils.quoteIdentifier(builder, index.columns[columnIndex]);
-                Object o = row[columnIndex];
-                if (o == null) {
-                    builder.append(" IS NULL");
-                } else {
-                    builder.append('=').append(quoteSQL(o, columnTypes[columnIndex]));
-                }
-            }
-            return builder.toString();
-        }
-
-        private PreparedStatement getStatement(Connection conn, int index) throws SQLException {
-            return useOwnConnection ?
-                    conn.prepareStatement(SQL[index], Statement.RETURN_GENERATED_KEYS)
-                    : prepStatements[index];
-        }
-
-    }
-
-    /**
-     * INTERNAL
-     * Close all fulltext settings, freeing up memory.
-     */
-    public static void closeAll() {
-        FullTextSettings.closeAll();
-    }
-
-    /**
-     * Throw a SQLException with the given message.
-     *
-     * @param message the message
-     * @return never returns normally
-     * @throws SQLException the exception
-     */
-    protected static SQLException throwException(String message)
-            throws SQLException {
-        throw new SQLException(message, "FULLTEXT");
-    }
-}
diff --git a/modules/h2/src/main/java/org/h2/fulltext/FullTextLucene.java b/modules/h2/src/main/java/org/h2/fulltext/FullTextLucene.java
deleted file mode 100644
index 0dfeb96..0000000
--- a/modules/h2/src/main/java/org/h2/fulltext/FullTextLucene.java
+++ /dev/null
@@ -1,769 +0,0 @@
-/*
- * Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
- * and the EPL 1.0 (http://h2database.com/html/license.html).
- * Initial Developer: H2 Group
- */
-package org.h2.fulltext;
-
-import java.io.IOException;
-import java.nio.file.Paths;
-import java.sql.Connection;
-import java.sql.DatabaseMetaData;
-import java.sql.PreparedStatement;
-import java.sql.ResultSet;
-import java.sql.SQLException;
-import java.sql.Statement;
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.HashMap;
-
-import org.apache.lucene.analysis.Analyzer;
-import org.apache.lucene.analysis.standard.StandardAnalyzer;
-import org.apache.lucene.document.DateTools;
-import org.apache.lucene.document.Document;
-import org.apache.lucene.document.Field;
-import org.apache.lucene.document.FieldType;
-import org.apache.lucene.document.TextField;
-import org.apache.lucene.index.DirectoryReader;
-import org.apache.lucene.index.IndexFormatTooOldException;
-import org.apache.lucene.index.IndexReader;
-import org.apache.lucene.index.IndexWriter;
-import org.apache.lucene.index.IndexWriterConfig;
-import org.apache.lucene.index.Term;
-import org.apache.lucene.queryparser.flexible.standard.StandardQueryParser;
-import org.apache.lucene.search.IndexSearcher;
-import org.apache.lucene.search.Query;
-import org.apache.lucene.search.ScoreDoc;
-import org.apache.lucene.search.TopDocs;
-import org.apache.lucene.store.Directory;
-import org.apache.lucene.store.FSDirectory;
-import org.apache.lucene.store.RAMDirectory;
-import org.h2.api.ErrorCode;
-import org.h2.api.Trigger;
-import org.h2.command.Parser;
-import org.h2.engine.Session;
-import org.h2.expression.ExpressionColumn;
-import org.h2.jdbc.JdbcConnection;
-import org.h2.message.DbException;
-import org.h2.store.fs.FileUtils;
-import org.h2.tools.SimpleResultSet;
-import org.h2.util.StringUtils;
-import org.h2.util.Utils;
-
-/**
- * This class implements the full text search based on Apache Lucene.
- * Most methods can be called using SQL statements as well.
- */
-public class FullTextLucene extends FullText {
-
-    /**
-     * Whether the text content should be stored in the Lucene index.
-     */
-    protected static final boolean STORE_DOCUMENT_TEXT_IN_INDEX =
-            Utils.getProperty("h2.storeDocumentTextInIndex", false);
-
-    private static final HashMap<String, IndexAccess> INDEX_ACCESS = new HashMap<>();
-    private static final String TRIGGER_PREFIX = "FTL_";
-    private static final String SCHEMA = "FTL";
-    private static final String LUCENE_FIELD_DATA = "_DATA";
-    private static final String LUCENE_FIELD_QUERY = "_QUERY";
-    private static final String LUCENE_FIELD_MODIFIED = "_modified";
-    private static final String LUCENE_FIELD_COLUMN_PREFIX = "_";
-
-    /**
-     * The prefix for a in-memory path. This prefix is only used internally
-     * within this class and not related to the database URL.
-     */
-    private static final String IN_MEMORY_PREFIX = "mem:";
-
-    private static final java.lang.reflect.Field TOTAL_HITS;
-
-    static {
-        try {
-            TOTAL_HITS = TopDocs.class.getField("totalHits");
-        } catch (ReflectiveOperationException e) {
-            throw DbException.get(ErrorCode.GENERAL_ERROR_1, e,
-                    "Field org.apache.lucene.search.TopDocs.totalHits is not found");
-        }
-    }
-
-    /**
-     * Initializes full text search functionality for this database. This adds
-     * the following Java functions to the database:
-     * <ul>
-     * <li>FTL_CREATE_INDEX(schemaNameString, tableNameString,
-     * columnListString)</li>
-     * <li>FTL_SEARCH(queryString, limitInt, offsetInt): result set</li>
-     * <li>FTL_REINDEX()</li>
-     * <li>FTL_DROP_ALL()</li>
-     * </ul>
-     * It also adds a schema FTL to the database where bookkeeping information
-     * is stored. This function may be called from a Java application, or by
-     * using the SQL statements:
-     *
-     * <pre>
-     * CREATE ALIAS IF NOT EXISTS FTL_INIT FOR
-     *      &quot;org.h2.fulltext.FullTextLucene.init&quot;;
-     * CALL FTL_INIT();
-     * </pre>
-     *
-     * @param conn the connection
-     */
-    public static void init(Connection conn) throws SQLException {
-        try (Statement stat = conn.createStatement()) {
-            stat.execute("CREATE SCHEMA IF NOT EXISTS " + SCHEMA);
-            stat.execute("CREATE TABLE IF NOT EXISTS " + SCHEMA +
-                    ".INDEXES(SCHEMA VARCHAR, `TABLE` VARCHAR, " +
-                    "COLUMNS VARCHAR, PRIMARY KEY(SCHEMA, `TABLE`))");
-            stat.execute("CREATE ALIAS IF NOT EXISTS FTL_CREATE_INDEX FOR \"" +
-                    FullTextLucene.class.getName() + ".createIndex\"");
-            stat.execute("CREATE ALIAS IF NOT EXISTS FTL_DROP_INDEX FOR \"" +
-                    FullTextLucene.class.getName() + ".dropIndex\"");
-            stat.execute("CREATE ALIAS IF NOT EXISTS FTL_SEARCH FOR \"" +
-                    FullTextLucene.class.getName() + ".search\"");
-            stat.execute("CREATE ALIAS IF NOT EXISTS FTL_SEARCH_DATA FOR \"" +
-                    FullTextLucene.class.getName() + ".searchData\"");
-            stat.execute("CREATE ALIAS IF NOT EXISTS FTL_REINDEX FOR \"" +
-                    FullTextLucene.class.getName() + ".reindex\"");
-            stat.execute("CREATE ALIAS IF NOT EXISTS FTL_DROP_ALL FOR \"" +
-                    FullTextLucene.class.getName() + ".dropAll\"");
-        }
-    }
-
-    /**
-     * Create a new full text index for a table and column list. Each table may
-     * only have one index at any time.
-     *
-     * @param conn the connection
-     * @param schema the schema name of the table (case sensitive)
-     * @param table the table name (case sensitive)
-     * @param columnList the column list (null for all columns)
-     */
-    public static void createIndex(Connection conn, String schema,
-            String table, String columnList) throws SQLException {
-        init(conn);
-        PreparedStatement prep = conn.prepareStatement("INSERT INTO " + SCHEMA
-                + ".INDEXES(SCHEMA, `TABLE`, COLUMNS) VALUES(?, ?, ?)");
-        prep.setString(1, schema);
-        prep.setString(2, table);
-        prep.setString(3, columnList);
-        prep.execute();
-        createTrigger(conn, schema, table);
-        indexExistingRows(conn, schema, table);
-    }
-
-    /**
-     * Drop an existing full text index for a table. This method returns
-     * silently if no index for this table exists.
-     *
-     * @param conn the connection
-     * @param schema the schema name of the table (case sensitive)
-     * @param table the table name (case sensitive)
-     */
-    public static void dropIndex(Connection conn, String schema, String table)
-            throws SQLException {
-        init(conn);
-
-        PreparedStatement prep = conn.prepareStatement("DELETE FROM " + SCHEMA
-                + ".INDEXES WHERE SCHEMA=? AND `TABLE`=?");
-        prep.setString(1, schema);
-        prep.setString(2, table);
-        int rowCount = prep.executeUpdate();
-        if (rowCount != 0) {
-            reindex(conn);
-        }
-    }
-
-    /**
-     * Re-creates the full text index for this database. Calling this method is
-     * usually not needed, as the index is kept up-to-date automatically.
-     *
-     * @param conn the connection
-     */
-    public static void reindex(Connection conn) throws SQLException {
-        init(conn);
-        removeAllTriggers(conn, TRIGGER_PREFIX);
-        removeIndexFiles(conn);
-        Statement stat = conn.createStatement();
-        ResultSet rs = stat.executeQuery("SELECT * FROM " + SCHEMA + ".INDEXES");
-        while (rs.next()) {
-            String schema = rs.getString("SCHEMA");
-            String table = rs.getString("TABLE");
-            createTrigger(conn, schema, table);
-            indexExistingRows(conn, schema, table);
-        }
-    }
-
-    /**
-     * Drops all full text indexes from the database.
-     *
-     * @param conn the connection
-     */
-    public static void dropAll(Connection conn) throws SQLException {
-        Statement stat = conn.createStatement();
-        stat.execute("DROP SCHEMA IF EXISTS " + SCHEMA + " CASCADE");
-        removeAllTriggers(conn, TRIGGER_PREFIX);
-        removeIndexFiles(conn);
-    }
-
-    /**
-     * Searches from the full text index for this database.
-     * The returned result set has the following column:
-     * <ul><li>QUERY (varchar): the query to use to get the data.
-     * The query does not include 'SELECT * FROM '. Example:
-     * PUBLIC.TEST WHERE ID = 1
-     * </li><li>SCORE (float) the relevance score as returned by Lucene.
-     * </li></ul>
-     *
-     * @param conn the connection
-     * @param text the search query
-     * @param limit the maximum number of rows or 0 for no limit
-     * @param offset the offset or 0 for no offset
-     * @return the result set
-     */
-    public static ResultSet search(Connection conn, String text, int limit,
-            int offset) throws SQLException {
-        return search(conn, text, limit, offset, false);
-    }
-
-    /**
-     * Searches from the full text index for this database. The result contains
-     * the primary key data as an array. The returned result set has the
-     * following columns:
-     * <ul>
-     * <li>SCHEMA (varchar): the schema name. Example: PUBLIC</li>
-     * <li>TABLE (varchar): the table name. Example: TEST</li>
-     * <li>COLUMNS (array of varchar): comma separated list of quoted column
-     * names. The column names are quoted if necessary. Example: (ID)</li>
-     * <li>KEYS (array of values): comma separated list of values.
-     * Example: (1)</li>
-     * <li>SCORE (float) the relevance score as returned by Lucene.</li>
-     * </ul>
-     *
-     * @param conn the connection
-     * @param text the search query
-     * @param limit the maximum number of rows or 0 for no limit
-     * @param offset the offset or 0 for no offset
-     * @return the result set
-     */
-    public static ResultSet searchData(Connection conn, String text, int limit,
-            int offset) throws SQLException {
-        return search(conn, text, limit, offset, true);
-    }
-
-    /**
-     * Convert an exception to a fulltext exception.
-     *
-     * @param e the original exception
-     * @return the converted SQL exception
-     */
-    protected static SQLException convertException(Exception e) {
-        return new SQLException("Error while indexing document", "FULLTEXT", e);
-    }
-
-    /**
-     * Create the trigger.
-     *
-     * @param conn the database connection
-     * @param schema the schema name
-     * @param table the table name
-     */
-    private static void createTrigger(Connection conn, String schema,
-            String table) throws SQLException {
-        createOrDropTrigger(conn, schema, table, true);
-    }
-
-    private static void createOrDropTrigger(Connection conn,
-            String schema, String table, boolean create) throws SQLException {
-        Statement stat = conn.createStatement();
-        String trigger = StringUtils.quoteIdentifier(schema) + "." +
-                StringUtils.quoteIdentifier(TRIGGER_PREFIX + table);
-        stat.execute("DROP TRIGGER IF EXISTS " + trigger);
-        if (create) {
-            StringBuilder builder = new StringBuilder(
-                    "CREATE TRIGGER IF NOT EXISTS ");
-            // the trigger is also called on rollback because transaction
-            // rollback will not undo the changes in the Lucene index
-            builder.append(trigger).
-                append(" AFTER INSERT, UPDATE, DELETE, ROLLBACK ON ");
-            StringUtils.quoteIdentifier(builder, schema).
-                append('.');
-            StringUtils.quoteIdentifier(builder, table).
-                append(" FOR EACH ROW CALL \"").
-                append(FullTextLucene.FullTextTrigger.class.getName()).
-                append('\"');
-            stat.execute(builder.toString());
-        }
-    }
-
-    /**
-     * Get the index writer/searcher wrapper for the given connection.
-     *
-     * @param conn the connection
-     * @return the index access wrapper
-     */
-    protected static IndexAccess getIndexAccess(Connection conn)
-            throws SQLException {
-        String path = getIndexPath(conn);
-        synchronized (INDEX_ACCESS) {
-            IndexAccess access = INDEX_ACCESS.get(path);
-            while (access == null) {
-                try {
-                    Directory indexDir = path.startsWith(IN_MEMORY_PREFIX) ?
-                            new RAMDirectory() : FSDirectory.open(Paths.get(path));
-                    Analyzer analyzer = new StandardAnalyzer();
-                    IndexWriterConfig conf = new IndexWriterConfig(analyzer);
-                    conf.setOpenMode(IndexWriterConfig.OpenMode.CREATE_OR_APPEND);
-                    IndexWriter writer = new IndexWriter(indexDir, conf);
-                    //see http://wiki.apache.org/lucene-java/NearRealtimeSearch
-                    access = new IndexAccess(writer);
-                } catch (IndexFormatTooOldException e) {
-                    reindex(conn);
-                    continue;
-                } catch (IOException e) {
-                    throw convertException(e);
-                }
-                INDEX_ACCESS.put(path, access);
-                break;
-            }
-            return access;
-        }
-    }
-
-    /**
-     * Get the path of the Lucene index for this database.
-     *
-     * @param conn the database connection
-     * @return the path
-     */
-    protected static String getIndexPath(Connection conn) throws SQLException {
-        Statement stat = conn.createStatement();
-        ResultSet rs = stat.executeQuery("CALL DATABASE_PATH()");
-        rs.next();
-        String path = rs.getString(1);
-        if (path == null) {
-            return IN_MEMORY_PREFIX + conn.getCatalog();
-        }
-        int index = path.lastIndexOf(':');
-        // position 1 means a windows drive letter is used, ignore that
-        if (index > 1) {
-            path = path.substring(index + 1);
-        }
-        rs.close();
-        return path;
-    }
-
-    /**
-     * Add the existing data to the index.
-     *
-     * @param conn the database connection
-     * @param schema the schema name
-     * @param table the table name
-     */
-    private static void indexExistingRows(Connection conn, String schema,
-            String table) throws SQLException {
-        FullTextLucene.FullTextTrigger existing = new FullTextLucene.FullTextTrigger();
-        existing.init(conn, schema, null, table, false, Trigger.INSERT);
-        String sql = "SELECT * FROM " + StringUtils.quoteIdentifier(schema)
-                + "." + StringUtils.quoteIdentifier(table);
-        ResultSet rs = conn.createStatement().executeQuery(sql);
-        int columnCount = rs.getMetaData().getColumnCount();
-        while (rs.next()) {
-            Object[] row = new Object[columnCount];
-            for (int i = 0; i < columnCount; i++) {
-                row[i] = rs.getObject(i + 1);
-            }
-            existing.insert(row, false);
-        }
-        existing.commitIndex();
-    }
-
-    private static void removeIndexFiles(Connection conn) throws SQLException {
-        String path = getIndexPath(conn);
-        removeIndexAccess(path);
-        if (!path.startsWith(IN_MEMORY_PREFIX)) {
-            FileUtils.deleteRecursive(path, false);
-        }
-    }
-
-    /**
-     * Close the index writer and searcher and remove them from the index access
-     * set.
-     *
-     * @param indexPath the index path
-     */
-    protected static void removeIndexAccess(String indexPath)
-            throws SQLException {
-        synchronized (INDEX_ACCESS) {
-            try {
-                IndexAccess access = INDEX_ACCESS.remove(indexPath);
-                if(access != null) {
-                    access.close();
-                }
-            } catch (Exception e) {
-                throw convertException(e);
-            }
-        }
-    }
-
-    /**
-     * Do the search.
-     *
-     * @param conn the database connection
-     * @param text the query
-     * @param limit the limit
-     * @param offset the offset
-     * @param data whether the raw data should be returned
-     * @return the result set
-     */
-    protected static ResultSet search(Connection conn, String text,
-            int limit, int offset, boolean data) throws SQLException {
-        SimpleResultSet result = createResultSet(data);
-        if (conn.getMetaData().getURL().startsWith("jdbc:columnlist:")) {
-            // this is just to query the result set columns
-            return result;
-        }
-        if (text == null || StringUtils.isWhitespaceOrEmpty(text)) {
-            return result;
-        }
-        try {
-            IndexAccess access = getIndexAccess(conn);
-            // take a reference as the searcher may change
-            IndexSearcher searcher = access.getSearcher();
-            try {
-                // reuse the same analyzer; it's thread-safe;
-                // also allows subclasses to control the analyzer used.
-                Analyzer analyzer = access.writer.getAnalyzer();
-                StandardQueryParser parser = new StandardQueryParser(analyzer);
-                Query query = parser.parse(text, LUCENE_FIELD_DATA);
-                // Lucene insists on a hard limit and will not provide
-                // a total hits value. Take at least 100 which is
-                // an optimal limit for Lucene as any more
-                // will trigger writing results to disk.
-                int maxResults = (limit == 0 ? 100 : limit) + offset;
-                TopDocs docs = searcher.search(query, maxResults);
-                if (limit == 0) {
-                    // TopDocs.totalHits is long now
-                    // (https://issues.apache.org/jira/browse/LUCENE-7872)
-                    // but in this context it's safe to cast
-                    limit = (int) TOTAL_HITS.getLong(docs);
-                }
-                for (int i = 0, len = docs.scoreDocs.length; i < limit
-                        && i + offset < docs.totalHits
-                        && i + offset < len; i++) {
-                    ScoreDoc sd = docs.scoreDocs[i + offset];
-                    Document doc = searcher.doc(sd.doc);
-                    float score = sd.score;
-                    String q = doc.get(LUCENE_FIELD_QUERY);
-                    if (data) {
-                        int idx = q.indexOf(" WHERE ");
-                        JdbcConnection c = (JdbcConnection) conn;
-                        Session session = (Session) c.getSession();
-                        Parser p = new Parser(session);
-                        String tab = q.substring(0, idx);
-                        ExpressionColumn expr = (ExpressionColumn) p
-                                .parseExpression(tab);
-                        String schemaName = expr.getOriginalTableAliasName();
-                        String tableName = expr.getColumnName();
-                        q = q.substring(idx + " WHERE ".length());
-                        Object[][] columnData = parseKey(conn, q);
-                        result.addRow(schemaName, tableName, columnData[0],
-                                columnData[1], score);
-                    } else {
-                        result.addRow(q, score);
-                    }
-                }
-            } finally {
-                access.returnSearcher(searcher);
-            }
-        } catch (Exception e) {
-            throw convertException(e);
-        }
-        return result;
-    }
-
-    /**
-     * Trigger updates the index when a inserting, updating, or deleting a row.
-     */
-    public static final class FullTextTrigger implements Trigger {
-
-        private String schema;
-        private String table;
-        private int[] keys;
-        private int[] indexColumns;
-        private String[] columns;
-        private int[] columnTypes;
-        private String indexPath;
-        private IndexAccess indexAccess;
-
-        private final FieldType DOC_ID_FIELD_TYPE;
-
-        public FullTextTrigger() {
-            DOC_ID_FIELD_TYPE = new FieldType(TextField.TYPE_STORED);
-            DOC_ID_FIELD_TYPE.setTokenized(false);
-            DOC_ID_FIELD_TYPE.freeze();
-        }
-
-        /**
-         * INTERNAL
-         */
-        @Override
-        public void init(Connection conn, String schemaName, String triggerName,
-                String tableName, boolean before, int type) throws SQLException {
-            this.schema = schemaName;
-            this.table = tableName;
-            this.indexPath = getIndexPath(conn);
-            this.indexAccess = getIndexAccess(conn);
-            ArrayList<String> keyList = Utils.newSmallArrayList();
-            DatabaseMetaData meta = conn.getMetaData();
-            ResultSet rs = meta.getColumns(null,
-                    StringUtils.escapeMetaDataPattern(schemaName),
-                    StringUtils.escapeMetaDataPattern(tableName),
-                    null);
-            ArrayList<String> columnList = Utils.newSmallArrayList();
-            while (rs.next()) {
-                columnList.add(rs.getString("COLUMN_NAME"));
-            }
-            columnTypes = new int[columnList.size()];
-            columns = columnList.toArray(new String[0]);
-            rs = meta.getColumns(null,
-                    StringUtils.escapeMetaDataPattern(schemaName),
-                    StringUtils.escapeMetaDataPattern(tableName),
-                    null);
-            for (int i = 0; rs.next(); i++) {
-                columnTypes[i] = rs.getInt("DATA_TYPE");
-            }
-            if (keyList.isEmpty()) {
-                rs = meta.getPrimaryKeys(null,
-                        StringUtils.escapeMetaDataPattern(schemaName),
-                        tableName);
-                while (rs.next()) {
-                    keyList.add(rs.getString("COLUMN_NAME"));
-                }
-            }
-            if (keyList.isEmpty()) {
-                throw throwException("No primary key for table " + tableName);
-            }
-            ArrayList<String> indexList = Utils.newSmallArrayList();
-            PreparedStatement prep = conn.prepareStatement(
-                    "SELECT COLUMNS FROM " + SCHEMA
-                    + ".INDEXES WHERE SCHEMA=? AND `TABLE`=?");
-            prep.setString(1, schemaName);
-            prep.setString(2, tableName);
-            rs = prep.executeQuery();
-            if (rs.next()) {
-                String cols = rs.getString(1);
-                if (cols != null) {
-                    Collections.addAll(indexList,
-                            StringUtils.arraySplit(cols, ',', true));
-                }
-            }
-            if (indexList.isEmpty()) {
-                indexList.addAll(columnList);
-            }
-            keys = new int[keyList.size()];
-            setColumns(keys, keyList, columnList);
-            indexColumns = new int[indexList.size()];
-            setColumns(indexColumns, indexList, columnList);
-        }
-
-        /**
-         * INTERNAL
-         */
-        @Override
-        public void fire(Connection conn, Object[] oldRow, Object[] newRow)
-                throws SQLException {
-            if (oldRow != null) {
-                if (newRow != null) {
-                    // update
-                    if (hasChanged(oldRow, newRow, indexColumns)) {
-                        delete(oldRow, false);
-                        insert(newRow, true);
-                    }
-                } else {
-                    // delete
-                    delete(oldRow, true);
-                }
-            } else if (newRow != null) {
-                // insert
-                insert(newRow, true);
-            }
-        }
-
-        /**
-         * INTERNAL
-         */
-        @Override
-        public void close() throws SQLException {
-            removeIndexAccess(indexPath);
-        }
-
-        /**
-         * INTERNAL
-         */
-        @Override
-        public void remove() {
-            // ignore
-        }
-
-        /**
-         * Commit all changes to the Lucene index.
-         */
-        void commitIndex() throws SQLException {
-            try {
-                indexAccess.commit();
-            } catch (IOException e) {
-                throw convertException(e);
-            }
-        }
-
-        /**
-         * Add a row to the index.
-         *
-         * @param row the row
-         * @param commitIndex whether to commit the changes to the Lucene index
-         */
-        protected void insert(Object[] row, boolean commitIndex) throws SQLException {
-            String query = getQuery(row);
-            Document doc = new Document();
-            doc.add(new Field(LUCENE_FIELD_QUERY, query, DOC_ID_FIELD_TYPE));
-            long time = System.currentTimeMillis();
-            doc.add(new Field(LUCENE_FIELD_MODIFIED,
-                    DateTools.timeToString(time, DateTools.Resolution.SECOND),
-                    TextField.TYPE_STORED));
-            StringBuilder builder = new StringBuilder();
-            for (int i = 0, length = indexColumns.length; i < length; i++) {
-                int index = indexColumns[i];
-                String columnName = columns[index];
-                String data = asString(row[index], columnTypes[index]);
-                // column names that start with _
-                // must be escaped to avoid conflicts
-                // with internal field names (_DATA, _QUERY, _modified)
-                if (columnName.startsWith(LUCENE_FIELD_COLUMN_PREFIX)) {
-                    columnName = LUCENE_FIELD_COLUMN_PREFIX + columnName;
-                }
-                doc.add(new Field(columnName, data, TextField.TYPE_NOT_STORED));
-                if (i > 0) {
-                    builder.append(' ');
-                }
-                builder.append(data);
-            }
-            FieldType dataFieldType = STORE_DOCUMENT_TEXT_IN_INDEX ?
-                    TextField.TYPE_STORED : TextField.TYPE_NOT_STORED;
-            doc.add(new Field(LUCENE_FIELD_DATA, builder.toString(), dataFieldType));
-            try {
-                indexAccess.writer.addDocument(doc);
-                if (commitIndex) {
-                    commitIndex();
-                }
-            } catch (IOException e) {
-                throw convertException(e);
-            }
-        }
-
-        /**
-         * Delete a row from the index.
-         *
-         * @param row the row
-         * @param commitIndex whether to commit the changes to the Lucene index
-         */
-        protected void delete(Object[] row, boolean commitIndex) throws SQLException {
-            String query = getQuery(row);
-            try {
-                Term term = new Term(LUCENE_FIELD_QUERY, query);
-                indexAccess.writer.deleteDocuments(term);
-                if (commitIndex) {
-                    commitIndex();
-                }
-            } catch (IOException e) {
-                throw convertException(e);
-            }
-        }
-
-        private String getQuery(Object[] row) throws SQLException {
-            StringBuilder builder = new StringBuilder();
-            if (schema != null) {
-                StringUtils.quoteIdentifier(builder, schema).append('.');
-            }
-            StringUtils.quoteIdentifier(builder, table).append(" WHERE ");
-            for (int i = 0, length = keys.length; i < length; i++) {
-                if (i > 0) {
-                    builder.append(" AND ");
-                }
-                int columnIndex = keys[i];
-                StringUtils.quoteIdentifier(builder, columns[columnIndex]);
-                Object o = row[columnIndex];
-                if (o == null) {
-                    builder.append(" IS NULL");
-                } else {
-                    builder.append('=').append(FullText.quoteSQL(o, columnTypes[columnIndex]));
-                }
-            }
-            return builder.toString();
-        }
-    }
-
-    /**
-     * A wrapper for the Lucene writer and searcher.
-     */
-    private static final class IndexAccess {
-
-        /**
-         * The index writer.
-         */
-        final IndexWriter writer;
-
-        /**
-         * The index searcher.
-         */
-        private IndexSearcher searcher;
-
-        IndexAccess(IndexWriter writer) throws IOException {
-            this.writer = writer;
-            initializeSearcher();
-        }
-
-        /**
-         * Start using the searcher.
-         *
-         * @return the searcher
-         */
-        synchronized IndexSearcher getSearcher() throws IOException {
-            if (!searcher.getIndexReader().tryIncRef()) {
-                initializeSearcher();
-            }
-            return searcher;
-        }
-
-        private void initializeSearcher() throws IOException {
-            IndexReader reader = DirectoryReader.open(writer);
-            searcher = new IndexSearcher(reader);
-        }
-
-        /**
-         * Stop using the searcher.
-         *
-         * @param searcher the searcher
-         */
-        synchronized void returnSearcher(IndexSearcher searcher) throws IOException {
-            searcher.getIndexReader().decRef();
-        }
-
-        /**
-         * Commit the changes.
-         */
-        public synchronized void commit() throws IOException {
-            writer.commit();
-            returnSearcher(searcher);
-            searcher = new IndexSearcher(DirectoryReader.open(writer));
-        }
-
-        /**
-         * Close the index.
-         */
-        public synchronized void close() throws IOException {
-            searcher = null;
-            writer.close();
-        }
-    }
-}
diff --git a/modules/h2/src/main/java/org/h2/fulltext/FullTextSettings.java b/modules/h2/src/main/java/org/h2/fulltext/FullTextSettings.java
deleted file mode 100644
index 4d80a0d..0000000
--- a/modules/h2/src/main/java/org/h2/fulltext/FullTextSettings.java
+++ /dev/null
@@ -1,282 +0,0 @@
-/*
- * Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
- * and the EPL 1.0 (http://h2database.com/html/license.html).
- * Initial Developer: H2 Group
- */
-package org.h2.fulltext;
-
-import java.sql.Connection;
-import java.sql.PreparedStatement;
-import java.sql.ResultSet;
-import java.sql.SQLException;
-import java.sql.Statement;
-import java.util.HashMap;
-import java.util.HashSet;
-import java.util.Map;
-import java.util.Set;
-import java.util.concurrent.ConcurrentHashMap;
-
-import org.h2.util.SoftHashMap;
-
-/**
- * The global settings of a full text search.
- */
-final class FullTextSettings {
-
-    /**
-     * The settings of open indexes.
-     */
-    private static final Map<String, FullTextSettings> SETTINGS = new HashMap<>();
-
-    /**
-     * Whether this instance has been initialized.
-     */
-    private boolean initialized;
-
-    /**
-     * The set of words not to index (stop words).
-     */
-    private final Set<String> ignoreList = new HashSet<>();
-
-    /**
-     * The set of words / terms.
-     */
-    private final Map<String, Integer> words = new HashMap<>();
-
-    /**
-     * The set of indexes in this database.
-     */
-    private final ConcurrentHashMap<Integer, IndexInfo> indexes = new ConcurrentHashMap<>();
-
-    /**
-     * The prepared statement cache.
-     */
-    private final SoftHashMap<Connection,
-            SoftHashMap<String, PreparedStatement>> cache =
-            new SoftHashMap<>();
-
-    /**
-     * The whitespace characters.
-     */
-    private String whitespaceChars = " \t\n\r\f+\"*%&/()=?'!,.;:-_#@|^~`{}[]<>\\";
-
-    /**
-     * Create a new instance.
-     */
-    private FullTextSettings() {
-        // don't allow construction
-    }
-
-    /**
-     * Clear set of ignored words
-     */
-    public void clearIgnored() {
-        synchronized (ignoreList) {
-            ignoreList.clear();
-        }
-    }
-
-    /**
-     * Amend set of ignored words
-     * @param words to add
-     */
-    public void addIgnored(Iterable<String> words) {
-        synchronized (ignoreList) {
-            for (String word : words) {
-                word = normalizeWord(word);
-                ignoreList.add(word);
-            }
-        }
-    }
-
-    /**
-     * Clear set of searchable words
-     */
-    public void clearWordList() {
-        synchronized (words) {
-            words.clear();
-        }
-    }
-
-    /**
-     * Get id for a searchable word
-     * @param word to find id for
-     * @return Integer id or null if word is not found
-     */
-    public Integer getWordId(String word) {
-        synchronized (words) {
-            return words.get(word);
-        }
-    }
-
-    /**
-     * Register searchable word
-     * @param word to register
-     * @param id to register with
-     */
-    public void addWord(String word, Integer id) {
-        synchronized (words) {
-            if(!words.containsKey(word)) {
-                words.put(word, id);
-            }
-        }
-    }
-
-    /**
-     * Get the index information for the given index id.
-     *
-     * @param indexId the index id
-     * @return the index info
-     */
-    protected IndexInfo getIndexInfo(int indexId) {
-        return indexes.get(indexId);
-    }
-
-    /**
-     * Add an index.
-     *
-     * @param index the index
-     */
-    protected void addIndexInfo(IndexInfo index) {
-        indexes.put(index.id, index);
-    }
-
-    /**
-     * Convert a word to uppercase. This method returns null if the word is in
-     * the ignore list.
-     *
-     * @param word the word to convert and check
-     * @return the uppercase version of the word or null
-     */
-    protected String convertWord(String word) {
-        word = normalizeWord(word);
-        synchronized (ignoreList) {
-            if (ignoreList.contains(word)) {
-                return null;
-            }
-        }
-        return word;
-    }
-
-    /**
-     * Get or create the fulltext settings for this database.
-     *
-     * @param conn the connection
-     * @return the settings
-     */
-    protected static FullTextSettings getInstance(Connection conn)
-            throws SQLException {
-        String path = getIndexPath(conn);
-        FullTextSettings setting;
-        synchronized (SETTINGS) {
-            setting = SETTINGS.get(path);
-            if (setting == null) {
-                setting = new FullTextSettings();
-                SETTINGS.put(path, setting);
-            }
-        }
-        return setting;
-    }
-
-    /**
-     * Get the file system path.
-     *
-     * @param conn the connection
-     * @return the file system path
-     */
-    private static String getIndexPath(Connection conn) throws SQLException {
-        Statement stat = conn.createStatement();
-        ResultSet rs = stat.executeQuery(
-                "CALL IFNULL(DATABASE_PATH(), 'MEM:' || DATABASE())");
-        rs.next();
-        String path = rs.getString(1);
-        if ("MEM:UNNAMED".equals(path)) {
-            throw FullText.throwException(
-                    "Fulltext search for private (unnamed) " +
-                    "in-memory databases is not supported.");
-        }
-        rs.close();
-        return path;
-    }
-
-    /**
-     * Prepare a statement. The statement is cached in a soft reference cache.
-     *
-     * @param conn the connection
-     * @param sql the statement
-     * @return the prepared statement
-     */
-    protected synchronized PreparedStatement prepare(Connection conn, String sql)
-            throws SQLException {
-        SoftHashMap<String, PreparedStatement> c = cache.get(conn);
-        if (c == null) {
-            c = new SoftHashMap<>();
-            cache.put(conn, c);
-        }
-        PreparedStatement prep = c.get(sql);
-        if (prep != null && prep.getConnection().isClosed()) {
-            prep = null;
-        }
-        if (prep == null) {
-            prep = conn.prepareStatement(sql);
-            c.put(sql, prep);
-        }
-        return prep;
-    }
-
-    /**
-     * Remove all indexes from the settings.
-     */
-    protected void removeAllIndexes() {
-        indexes.clear();
-    }
-
-    /**
-     * Remove an index from the settings.
-     *
-     * @param index the index to remove
-     */
-    protected void removeIndexInfo(IndexInfo index) {
-        indexes.remove(index.id);
-    }
-
-    /**
-     * Set the initialized flag.
-     *
-     * @param b the new value
-     */
-    protected void setInitialized(boolean b) {
-        this.initialized = b;
-    }
-
-    /**
-     * Get the initialized flag.
-     *
-     * @return whether this instance is initialized
-     */
-    protected boolean isInitialized() {
-        return initialized;
-    }
-
-    /**
-     * Close all fulltext settings, freeing up memory.
-     */
-    protected static void closeAll() {
-        synchronized (SETTINGS) {
-            SETTINGS.clear();
-        }
-    }
-
-    protected void setWhitespaceChars(String whitespaceChars) {
-        this.whitespaceChars = whitespaceChars;
-    }
-
-    protected String getWhitespaceChars() {
-        return whitespaceChars;
-    }
-
-    private static String normalizeWord(String word) {
-        // TODO this is locale specific, document
-        return word.toUpperCase();
-    }
-}
diff --git a/modules/h2/src/main/java/org/h2/fulltext/IndexInfo.java b/modules/h2/src/main/java/org/h2/fulltext/IndexInfo.java
deleted file mode 100644
index e07bb1d..0000000
--- a/modules/h2/src/main/java/org/h2/fulltext/IndexInfo.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/*
- * Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
- * and the EPL 1.0 (http://h2database.com/html/license.html).
- * Initial Developer: H2 Group
- */
-package org.h2.fulltext;
-
-/**
- * The settings of one full text search index.
- */
-public class IndexInfo {
-
-    /**
-     * The index id.
-     */
-    protected int id;
-
-    /**
-     * The schema name.
-     */
-    protected String schema;
-
-    /**
-     * The table name.
-     */
-    protected String table;
-
-    /**
-     * The column indexes of the key columns.
-     */
-    protected int[] keys;
-
-    /**
-     * The column indexes of the index columns.
-     */
-    protected int[] indexColumns;
-
-    /**
-     * The column names.
-     */
-    protected String[] columns;
-}
diff --git a/modules/h2/src/main/java/org/h2/fulltext/package.html b/modules/h2/src/main/java/org/h2/fulltext/package.html
deleted file mode 100644
index c86c055..0000000
--- a/modules/h2/src/main/java/org/h2/fulltext/package.html
+++ /dev/null
@@ -1,14 +0,0 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Strict//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd">
-<!--
-Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
-and the EPL 1.0 (http://h2database.com/html/license.html).
-Initial Developer: H2 Group
--->
-<html xmlns="http://www.w3.org/1999/xhtml" lang="en" xml:lang="en">
-<head><meta http-equiv="Content-Type" content="text/html;charset=utf-8" /><title>
-Javadoc package documentation
-</title></head><body style="font: 9pt/130% Tahoma, Arial, Helvetica, sans-serif; font-weight: normal;"><p>
-
-The native full text search implementation, and the wrapper for the Lucene full text search implementation.
-
-</p></body></html>
\ No newline at end of file
diff --git a/modules/h2/src/main/java/org/h2/util/DbDriverActivator.java b/modules/h2/src/main/java/org/h2/util/DbDriverActivator.java
deleted file mode 100644
index 0236595..0000000
--- a/modules/h2/src/main/java/org/h2/util/DbDriverActivator.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/*
- * Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
- * and the EPL 1.0 (http://h2database.com/html/license.html).
- * Initial Developer: H2 Group
- */
-package org.h2.util;
-
-import org.osgi.framework.BundleActivator;
-import org.osgi.framework.BundleContext;
-
-/**
- * The driver activator loads the H2 driver when starting the bundle. The driver
- * is unloaded when stopping the bundle.
- */
-public class DbDriverActivator implements BundleActivator {
-
-    private static final String DATASOURCE_FACTORY_CLASS =
-            "org.osgi.service.jdbc.DataSourceFactory";
-
-    /**
-     * Start the bundle. If the 'org.osgi.service.jdbc.DataSourceFactory' class
-     * is available in the class path, this will load the database driver and
-     * register the DataSourceFactory service.
-     *
-     * @param bundleContext the bundle context
-     */
-    @Override
-    public void start(BundleContext bundleContext) {
-        org.h2.Driver driver = org.h2.Driver.load();
-        try {
-            JdbcUtils.loadUserClass(DATASOURCE_FACTORY_CLASS);
-        } catch (Exception e) {
-            // class not found - don't register
-            return;
-        }
-        // but don't ignore exceptions in this call
-        OsgiDataSourceFactory.registerService(bundleContext, driver);
-    }
-
-    /**
-     * Stop the bundle. This will unload the database driver. The
-     * DataSourceFactory service is implicitly un-registered by the OSGi
-     * framework.
-     *
-     * @param bundleContext the bundle context
-     */
-    @Override
-    public void stop(BundleContext bundleContext) {
-        org.h2.Driver.unload();
-    }
-
-}
diff --git a/modules/h2/src/main/java/org/h2/util/OsgiDataSourceFactory.java b/modules/h2/src/main/java/org/h2/util/OsgiDataSourceFactory.java
deleted file mode 100644
index 9b91d4b..0000000
--- a/modules/h2/src/main/java/org/h2/util/OsgiDataSourceFactory.java
+++ /dev/null
@@ -1,305 +0,0 @@
-/*
- * Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
- * and the EPL 1.0 (http://h2database.com/html/license.html).
- * Initial Developer: H2 Group
- */
-package org.h2.util;
-
-import java.sql.SQLException;
-import java.sql.SQLFeatureNotSupportedException;
-import java.util.Properties;
-import javax.sql.ConnectionPoolDataSource;
-import javax.sql.DataSource;
-import javax.sql.XADataSource;
-import org.h2.engine.Constants;
-import org.h2.jdbcx.JdbcDataSource;
-import org.osgi.framework.BundleContext;
-import org.osgi.service.jdbc.DataSourceFactory;
-
-/**
- * This class implements the OSGi DataSourceFactory interface for the H2 JDBC
- * driver. The following standard configuration properties are supported:
- * {@link #JDBC_USER}, {@link #JDBC_PASSWORD}, {@link #JDBC_DESCRIPTION},
- * {@link #JDBC_DATASOURCE_NAME}, {@link #JDBC_NETWORK_PROTOCOL},
- * {@link #JDBC_URL}, {@link #JDBC_SERVER_NAME}, {@link #JDBC_PORT_NUMBER}. The
- * following standard configuration properties are not supported:
- * {@link #JDBC_ROLE_NAME}, {@link #JDBC_DATABASE_NAME},
- * {@link #JDBC_INITIAL_POOL_SIZE}, {@link #JDBC_MAX_POOL_SIZE},
- * {@link #JDBC_MIN_POOL_SIZE}, {@link #JDBC_MAX_IDLE_TIME},
- * {@link #JDBC_MAX_STATEMENTS}, {@link #JDBC_PROPERTY_CYCLE}. Any other
- * property will be treated as a H2 specific option. If the {@link #JDBC_URL}
- * property is passed to any of the DataSource factories, the following
- * properties will be ignored: {@link #JDBC_DATASOURCE_NAME},
- * {@link #JDBC_NETWORK_PROTOCOL}, {@link #JDBC_SERVER_NAME},
- * {@link #JDBC_PORT_NUMBER}.
- *
- * @author Per Otterstrom
- */
-public class OsgiDataSourceFactory implements DataSourceFactory {
-    private final org.h2.Driver driver;
-
-    public OsgiDataSourceFactory(org.h2.Driver driver) {
-        this.driver = driver;
-    }
-
-    /**
-     * Creates a basic data source.
-     *
-     * @param properties the properties for the data source.
-     * @throws SQLException if unsupported properties are supplied, or if data
-     *             source can not be created.
-     * @return a new data source.
-     */
-    @Override
-    public DataSource createDataSource(Properties properties)
-            throws SQLException {
-        // Make copy of properties
-        Properties propertiesCopy = new Properties();
-        if (properties != null) {
-            propertiesCopy.putAll(properties);
-        }
-
-        // Verify that no unsupported standard options are used
-        rejectUnsupportedOptions(propertiesCopy);
-
-        // Standard pool properties in OSGi not applicable here
-        rejectPoolingOptions(propertiesCopy);
-
-        JdbcDataSource dataSource = new JdbcDataSource();
-
-        setupH2DataSource(dataSource, propertiesCopy);
-
-        return dataSource;
-    }
-
-    /**
-     * Creates a pooled data source.
-     *
-     * @param properties the properties for the data source.
-     * @throws SQLException if unsupported properties are supplied, or if data
-     *             source can not be created.
-     * @return a new data source.
-     */
-    @Override
-    public ConnectionPoolDataSource createConnectionPoolDataSource(
-            Properties properties) throws SQLException {
-        // Make copy of properties
-        Properties propertiesCopy = new Properties();
-        if (properties != null) {
-            propertiesCopy.putAll(properties);
-        }
-
-        // Verify that no unsupported standard options are used
-        rejectUnsupportedOptions(propertiesCopy);
-
-        // The integrated connection pool is H2 is not configurable
-        rejectPoolingOptions(propertiesCopy);
-
-        JdbcDataSource dataSource = new JdbcDataSource();
-
-        setupH2DataSource(dataSource, propertiesCopy);
-
-        return dataSource;
-    }
-
-    /**
-     * Creates a pooled XA data source.
-     *
-     * @param properties the properties for the data source.
-     * @throws SQLException if unsupported properties are supplied, or if data
-     *             source can not be created.
-     * @return a new data source.
-     */
-    @Override
-    public XADataSource createXADataSource(Properties properties)
-            throws SQLException {
-        // Make copy of properties
-        Properties propertiesCopy = new Properties();
-        if (properties != null) {
-            propertiesCopy.putAll(properties);
-        }
-
-        // Verify that no unsupported standard options are used
-        rejectUnsupportedOptions(propertiesCopy);
-
-        // The integrated connection pool is H2 is not configurable
-        rejectPoolingOptions(propertiesCopy);
-
-        JdbcDataSource dataSource = new JdbcDataSource();
-
-        setupH2DataSource(dataSource, propertiesCopy);
-
-        return dataSource;
-    }
-
-    /**
-     * Returns a driver. The H2 driver does not support any properties.
-     *
-     * @param properties must be null or empty list.
-     * @throws SQLException if any property is supplied.
-     * @return a driver.
-     */
-    @Override
-    public java.sql.Driver createDriver(Properties properties)
-            throws SQLException {
-        if (properties != null && !properties.isEmpty()) {
-            // No properties supported
-            throw new SQLException();
-        }
-        return driver;
-    }
-
-    /**
-     * Checker method that will throw if any unsupported standard OSGi options
-     * is present.
-     *
-     * @param p the properties to check
-     * @throws SQLFeatureNotSupportedException if unsupported properties are
-     *             present
-     */
-    private static void rejectUnsupportedOptions(Properties p)
-            throws SQLFeatureNotSupportedException {
-        // Unsupported standard properties in OSGi
-        if (p.containsKey(DataSourceFactory.JDBC_ROLE_NAME)) {
-            throw new SQLFeatureNotSupportedException("The " +
-                    DataSourceFactory.JDBC_ROLE_NAME +
-                    " property is not supported by H2");
-        }
-        if (p.containsKey(DataSourceFactory.JDBC_DATASOURCE_NAME)) {
-            throw new SQLFeatureNotSupportedException("The " +
-                    DataSourceFactory.JDBC_DATASOURCE_NAME +
-                    " property is not supported by H2");
-        }
-    }
-
-    /**
-     * Applies common OSGi properties to a H2 data source. Non standard
-     * properties will be applied as H2 options.
-     *
-     * @param dataSource the data source to configure
-     * @param p the properties to apply to the data source
-     */
-    private static void setupH2DataSource(JdbcDataSource dataSource,
-            Properties p) {
-        // Setting user and password
-        if (p.containsKey(DataSourceFactory.JDBC_USER)) {
-            dataSource.setUser((String) p.remove(DataSourceFactory.JDBC_USER));
-        }
-        if (p.containsKey(DataSourceFactory.JDBC_PASSWORD)) {
-            dataSource.setPassword((String) p
-                    .remove(DataSourceFactory.JDBC_PASSWORD));
-        }
-
-        // Setting description
-        if (p.containsKey(DataSourceFactory.JDBC_DESCRIPTION)) {
-            dataSource.setDescription((String) p
-                    .remove(DataSourceFactory.JDBC_DESCRIPTION));
-        }
-
-        // Setting URL
-        StringBuilder connectionUrl = new StringBuilder();
-        if (p.containsKey(DataSourceFactory.JDBC_URL)) {
-            // Use URL if specified
-            connectionUrl.append(p.remove(DataSourceFactory.JDBC_URL));
-            // Remove individual properties
-            p.remove(DataSourceFactory.JDBC_NETWORK_PROTOCOL);
-            p.remove(DataSourceFactory.JDBC_SERVER_NAME);
-            p.remove(DataSourceFactory.JDBC_PORT_NUMBER);
-            p.remove(DataSourceFactory.JDBC_DATABASE_NAME);
-        } else {
-            // Creating URL from individual properties
-            connectionUrl.append(Constants.START_URL);
-
-            // Set network protocol (tcp/ssl) or DB type (mem/file)
-            String protocol = "";
-            if (p.containsKey(DataSourceFactory.JDBC_NETWORK_PROTOCOL)) {
-                protocol = (String) p.remove(DataSourceFactory.JDBC_NETWORK_PROTOCOL);
-                connectionUrl.append(protocol).append(":");
-            }
-
-            // Host name and/or port
-            if (p.containsKey(DataSourceFactory.JDBC_SERVER_NAME)) {
-                connectionUrl.append("//").append(
-                        p.remove(DataSourceFactory.JDBC_SERVER_NAME));
-
-                if (p.containsKey(DataSourceFactory.JDBC_PORT_NUMBER)) {
-                    connectionUrl.append(":").append(
-                            p.remove(DataSourceFactory.JDBC_PORT_NUMBER));
-                }
-
-                connectionUrl.append("/");
-            } else if (p.containsKey(
-                    DataSourceFactory.JDBC_PORT_NUMBER)) {
-                // Assume local host if only port was set
-                connectionUrl
-                        .append("//localhost:")
-                        .append(p.remove(DataSourceFactory.JDBC_PORT_NUMBER))
-                        .append("/");
-            } else if (protocol.equals("tcp") || protocol.equals("ssl")) {
-                // Assume local host if network protocol is set, but no host or
-                // port is set
-                connectionUrl.append("//localhost/");
-            }
-
-            // DB path and name
-            if (p.containsKey(DataSourceFactory.JDBC_DATABASE_NAME)) {
-                connectionUrl.append(
-                        p.remove(DataSourceFactory.JDBC_DATABASE_NAME));
-            }
-        }
-
-        // Add remaining properties as options
-        for (Object option : p.keySet()) {
-            connectionUrl.append(";").append(option).append("=")
-                    .append(p.get(option));
-        }
-
-        if (connectionUrl.length() > Constants.START_URL.length()) {
-            dataSource.setURL(connectionUrl.toString());
-        }
-    }
-
-    /**
-     * Checker method that will throw if any pooling related standard OSGi
-     * options are present.
-     *
-     * @param p the properties to check
-     * @throws SQLFeatureNotSupportedException if unsupported properties are
-     *             present
-     */
-    private static void rejectPoolingOptions(Properties p)
-            throws SQLFeatureNotSupportedException {
-        if (p.containsKey(DataSourceFactory.JDBC_INITIAL_POOL_SIZE) ||
-                p.containsKey(DataSourceFactory.JDBC_MAX_IDLE_TIME) ||
-                p.containsKey(DataSourceFactory.JDBC_MAX_POOL_SIZE) ||
-                p.containsKey(DataSourceFactory.JDBC_MAX_STATEMENTS) ||
-                p.containsKey(DataSourceFactory.JDBC_MIN_POOL_SIZE) ||
-                p.containsKey(DataSourceFactory.JDBC_PROPERTY_CYCLE)) {
-            throw new SQLFeatureNotSupportedException(
-                    "Pooling properties are not supported by H2");
-        }
-    }
-
-    /**
-     * Register the H2 JDBC driver service.
-     *
-     * @param bundleContext the bundle context
-     * @param driver the driver
-     */
-    static void registerService(BundleContext bundleContext,
-            org.h2.Driver driver) {
-        Properties properties = new Properties();
-        properties.put(
-                DataSourceFactory.OSGI_JDBC_DRIVER_CLASS,
-                org.h2.Driver.class.getName());
-        properties.put(
-                DataSourceFactory.OSGI_JDBC_DRIVER_NAME,
-                "H2 JDBC Driver");
-        properties.put(
-                DataSourceFactory.OSGI_JDBC_DRIVER_VERSION,
-                Constants.getFullVersion());
-        bundleContext.registerService(
-                DataSourceFactory.class.getName(),
-                new OsgiDataSourceFactory(driver), properties);
-    }
-}
diff --git a/modules/h2/src/test/java/org/h2/samples/fullTextSearch.sql b/modules/h2/src/test/java/org/h2/samples/fullTextSearch.sql
deleted file mode 100644
index 30ba8e3..0000000
--- a/modules/h2/src/test/java/org/h2/samples/fullTextSearch.sql
+++ /dev/null
@@ -1,59 +0,0 @@
-/*
- * Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
- * and the EPL 1.0 (http://h2database.com/html/license.html).
- * Initial Developer: H2 Group
- */
-
-// Example using the 'native' fulltext search implementation
-CREATE ALIAS IF NOT EXISTS FT_INIT FOR "org.h2.fulltext.FullText.init";
-CALL FT_INIT();
-DROP TABLE IF EXISTS TEST;
-CREATE TABLE TEST(ID INT PRIMARY KEY, NAME VARCHAR);
-INSERT INTO TEST VALUES(1, 'Hello World');
-CALL FT_CREATE_INDEX('PUBLIC', 'TEST', NULL);
-SELECT * FROM FT_SEARCH('Hello', 0, 0);
-SELECT * FROM FT_SEARCH('Hallo', 0, 0);
-INSERT INTO TEST VALUES(2, 'Hallo Welt');
-SELECT * FROM FT_SEARCH('Hello', 0, 0);
-SELECT * FROM FT_SEARCH('Hallo', 0, 0);
-CALL FT_REINDEX();
-SELECT * FROM FT_SEARCH('Hello', 0, 0);
-SELECT * FROM FT_SEARCH('Hallo', 0, 0);
-INSERT INTO TEST VALUES(3, 'Hello World');
-INSERT INTO TEST VALUES(4, 'Hello World');
-INSERT INTO TEST VALUES(5, 'Hello World');
-SELECT * FROM FT_SEARCH('World', 0, 0);
-SELECT * FROM FT_SEARCH('World', 1, 0);
-SELECT * FROM FT_SEARCH('World', 0, 2);
-SELECT * FROM FT_SEARCH('World', 2, 1);
-SELECT * FROM FT_SEARCH('1', 0, 0);
-CALL FT_DROP_INDEX('PUBLIC', 'TEST');
-SELECT * FROM FT_SEARCH('World', 2, 1);
-CALL FT_DROP_ALL();
-
-// Example using the 'Lucene' fulltext search implementation
-CREATE ALIAS IF NOT EXISTS FTL_INIT FOR "org.h2.fulltext.FullTextLucene.init";
-CALL FTL_INIT();
-DROP TABLE IF EXISTS TEST;
-CREATE TABLE TEST(ID INT PRIMARY KEY, NAME VARCHAR);
-INSERT INTO TEST VALUES(1, 'Hello World');
-CALL FTL_CREATE_INDEX('PUBLIC', 'TEST', NULL);
-SELECT * FROM FTL_SEARCH('Hello', 0, 0);
-SELECT * FROM FTL_SEARCH('Hallo', 0, 0);
-INSERT INTO TEST VALUES(2, 'Hallo Welt');
-SELECT * FROM FTL_SEARCH('Hello', 0, 0);
-SELECT * FROM FTL_SEARCH('Hallo', 0, 0);
-CALL FTL_REINDEX();
-SELECT * FROM FTL_SEARCH('Hello', 0, 0);
-SELECT * FROM FTL_SEARCH('Hallo', 0, 0);
-INSERT INTO TEST VALUES(3, 'Hello World');
-INSERT INTO TEST VALUES(4, 'Hello World');
-INSERT INTO TEST VALUES(5, 'Hello World');
-SELECT * FROM FTL_SEARCH('World', 0, 0);
-SELECT * FROM FTL_SEARCH('World', 1, 0);
-SELECT * FROM FTL_SEARCH('World', 0, 2);
-SELECT * FROM FTL_SEARCH('World', 2, 1);
-SELECT * FROM FTL_SEARCH('1', 0, 0);
-CALL FTL_DROP_ALL();
-SELECT * FROM FTL_SEARCH('World', 2, 1);
-CALL FTL_DROP_ALL();
diff --git a/modules/h2/src/test/java/org/h2/test/TestAll.java b/modules/h2/src/test/java/org/h2/test/TestAll.java
index 460d850..2fae8ee 100644
--- a/modules/h2/src/test/java/org/h2/test/TestAll.java
+++ b/modules/h2/src/test/java/org/h2/test/TestAll.java
@@ -40,7 +40,6 @@ import org.h2.test.db.TestDrop;
 import org.h2.test.db.TestDuplicateKeyUpdate;
 import org.h2.test.db.TestEncryptedDb;
 import org.h2.test.db.TestExclusive;
-import org.h2.test.db.TestFullText;
 import org.h2.test.db.TestFunctionOverload;
 import org.h2.test.db.TestFunctions;
 import org.h2.test.db.TestGeneralCommonTableQueries;
@@ -170,7 +169,6 @@ import org.h2.test.synth.TestTimer;
 import org.h2.test.synth.sql.TestSynth;
 import org.h2.test.synth.thread.TestMulti;
 import org.h2.test.unit.TestAnsCompression;
-import org.h2.test.unit.TestAutoReconnect;
 import org.h2.test.unit.TestBinaryArithmeticStream;
 import org.h2.test.unit.TestBitStream;
 import org.h2.test.unit.TestBnf;
@@ -188,7 +186,6 @@ import org.h2.test.unit.TestDbException;
 import org.h2.test.unit.TestExit;
 import org.h2.test.unit.TestFile;
 import org.h2.test.unit.TestFileLock;
-import org.h2.test.unit.TestFileLockProcess;
 import org.h2.test.unit.TestFileLockSerialized;
 import org.h2.test.unit.TestFileSystem;
 import org.h2.test.unit.TestFtp;
@@ -227,7 +224,6 @@ import org.h2.test.unit.TestStreams;
 import org.h2.test.unit.TestStringCache;
 import org.h2.test.unit.TestStringUtils;
 import org.h2.test.unit.TestTimeStampWithTimeZone;
-import org.h2.test.unit.TestTools;
 import org.h2.test.unit.TestTraceSystem;
 import org.h2.test.unit.TestUtils;
 import org.h2.test.unit.TestValue;
@@ -763,7 +759,6 @@ kill -9 `jps -l | grep "org.h2.test." | cut -d " " -f 1`
         addTest(new TestDuplicateKeyUpdate());
         addTest(new TestEncryptedDb());
         addTest(new TestExclusive());
-        addTest(new TestFullText());
         addTest(new TestFunctionOverload());
         addTest(new TestFunctions());
         addTest(new TestInit());
diff --git a/modules/h2/src/test/java/org/h2/test/db/TestDeadlock.java b/modules/h2/src/test/java/org/h2/test/db/TestDeadlock.java
index b09df72..38d6cc1 100644
--- a/modules/h2/src/test/java/org/h2/test/db/TestDeadlock.java
+++ b/modules/h2/src/test/java/org/h2/test/db/TestDeadlock.java
@@ -51,7 +51,6 @@ public class TestDeadlock extends TestDb {
     public void test() throws Exception {
         deleteDb("deadlock");
         testTemporaryTablesAndMetaDataLocking();
-        testDeadlockInFulltextSearch();
         testConcurrentLobReadAndTempResultTableDelete();
         testDiningPhilosophers();
         testLockUpgrade();
@@ -61,41 +60,6 @@ public class TestDeadlock extends TestDb {
         deleteDb("deadlock");
     }
 
-    private void testDeadlockInFulltextSearch() throws SQLException {
-        deleteDb("deadlock");
-        String url = "deadlock";
-        Connection conn, conn2;
-        conn = getConnection(url);
-        conn2 = getConnection(url);
-        final Statement stat = conn.createStatement();
-        Statement stat2 = conn2.createStatement();
-        stat.execute("create alias if not exists ft_init for " +
-                "\"org.h2.fulltext.FullText.init\"");
-        stat.execute("call ft_init()");
-        stat.execute("create table test(id int primary key, name varchar)");
-        stat.execute("call ft_create_index('PUBLIC', 'TEST', null)");
-        Task t = new Task() {
-            @Override
-            public void call() throws Exception {
-                while (!stop) {
-                    stat.executeQuery("select * from test");
-                }
-            }
-        };
-        t.execute();
-        long start = System.nanoTime();
-        while (System.nanoTime() - start < TimeUnit.SECONDS.toNanos(1)) {
-            stat2.execute("insert into test values(1, 'Hello')");
-            stat2.execute("delete from test");
-        }
-        t.get();
-        conn2.close();
-        conn.close();
-        conn = getConnection(url);
-        conn.createStatement().execute("drop all objects");
-        conn.close();
-    }
-
     private void testConcurrentLobReadAndTempResultTableDelete() throws Exception {
         deleteDb("deadlock");
         String url = "deadlock;MAX_MEMORY_ROWS=10";
diff --git a/modules/h2/src/test/java/org/h2/test/db/TestFullText.java b/modules/h2/src/test/java/org/h2/test/db/TestFullText.java
deleted file mode 100644
index fc7faa9..0000000
--- a/modules/h2/src/test/java/org/h2/test/db/TestFullText.java
+++ /dev/null
@@ -1,637 +0,0 @@
-/*
- * Copyright 2004-2019 H2 Group. Multiple-Licensed under the MPL 2.0,
- * and the EPL 1.0 (http://h2database.com/html/license.html).
- * Initial Developer: H2 Group
- */
-package org.h2.test.db;
-
-import java.io.Reader;
-import java.lang.reflect.InvocationTargetException;
-import java.lang.reflect.Method;
-import java.sql.Connection;
-import java.sql.PreparedStatement;
-import java.sql.ResultSet;
-import java.sql.SQLException;
-import java.sql.Statement;
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.Random;
-import java.util.StringTokenizer;
-import java.util.UUID;
-import java.util.concurrent.TimeUnit;
-
-import org.h2.fulltext.FullText;
-import org.h2.store.fs.FileUtils;
-import org.h2.test.TestBase;
-import org.h2.test.TestDb;
-import org.h2.util.IOUtils;
-import org.h2.util.Task;
-
-/**
- * Fulltext search tests.
- */
-public class TestFullText extends TestDb {
-
-    /**
-     * The words used in this test.
-     */
-    static final String[] KNOWN_WORDS = { "skiing", "balance", "storage",
-            "water", "train" };
-    private static final String LUCENE_FULLTEXT_CLASS_NAME =
-            "org.h2.fulltext.FullTextLucene";
-
-    /**
-     * Run just this test.
-     *
-     * @param a ignored
-     */
-    public static void main(String... a) throws Exception {
-        TestBase.createCaller().init().test();
-    }
-
-    @Override
-    public void test() throws Exception {
-        testUuidPrimaryKey(false);
-        testAutoAnalyze();
-        testNativeFeatures();
-        testTransaction(false);
-        testCreateDropNative();
-        testStreamLob();
-        test(false, "VARCHAR");
-        test(false, "CLOB");
-        testPerformance(false);
-        testReopen(false);
-        testDropIndex(false);
-        if (!config.reopen) {
-            try {
-                Class.forName(LUCENE_FULLTEXT_CLASS_NAME);
-                testCreateDropLucene();
-                testUuidPrimaryKey(true);
-                testMultiThreaded(true);
-                if(config.mvStore || !config.multiThreaded) {
-                    testMultiThreaded(false);
-                }
-                testTransaction(true);
-                test(true, "VARCHAR");
-                test(true, "CLOB");
-                testPerformance(true);
-                testReopen(true);
-                testDropIndex(true);
-            } catch (ClassNotFoundException | NoClassDefFoundError e) {
-                println("Class not found, not tested: " + LUCENE_FULLTEXT_CLASS_NAME);
-                // ok
-            }
-            FullText.closeAll();
-        }
-        deleteDb("fullText");
-        deleteDb("fullTextReopen");
-    }
-
-    private static void close(Collection<Connection> list) {
-        for (Connection conn : list) {
-            IOUtils.closeSilently(conn);
-        }
-    }
-
-    private Connection getConnection(String name, Collection<Connection> list)
-            throws SQLException {
-        Connection conn = getConnection(name);
-        list.add(conn);
-        return conn;
-    }
-
-    private void testAutoAnalyze() throws SQLException {
-        deleteDb("fullTextNative");
-        Connection conn;
-        Statement stat;
-
-        ArrayList<Connection> connList = new ArrayList<>();
-
-        conn = getConnection("fullTextNative", connList);
-        stat = conn.createStatement();
-        stat.execute("create alias if not exists ft_init " +
-                "for \"org.h2.fulltext.FullText.init\"");
-        stat.execute("call ft_init()");
-        stat.execute("create table test(id int primary key, name varchar)");
-        stat.execute("call ft_create_index('PUBLIC', 'TEST', 'NAME')");
-
-        if (!config.memory) {
-            conn.close();
-        }
-
-        conn = getConnection("fullTextNative", connList);
-        stat = conn.createStatement();
-        stat.execute("insert into test select x, 'x' from system_range(1, 3000)");
-        close(connList);
-    }
-
-    private void testNativeFeatures() throws SQLException {
-        deleteDb("fullTextNative");
-        ArrayList<Connection> connList = new ArrayList<>();
-        Connection conn = getConnection("fullTextNative", connList);
-        Statement stat = conn.createStatement();
-        stat.execute("CREATE ALIAS IF NOT EXISTS FT_INIT " +
-                "FOR \"org.h2.fulltext.FullText.init\"");
-        stat.execute("CALL FT_INIT()");
-        FullText.setIgnoreList(conn, "to,this");
-        FullText.setWhitespaceChars(conn, " ,.-");
-        stat.execute("CREATE TABLE TEST(ID INT PRIMARY KEY, NAME VARCHAR)");
-        stat.execute("INSERT INTO TEST VALUES(1, 'Welcome to this world, One_Word')");
-        stat.execute("CALL FT_CREATE_INDEX('PUBLIC', 'TEST', NULL)");
-        ResultSet rs;
-        rs = stat.executeQuery("SELECT * FROM FT_SEARCH('Welcome', 0, 0)");
-        assertTrue(rs.next());
-        assertEquals("QUERY", rs.getMetaData().getColumnLabel(1));
-        assertEquals("SCORE", rs.getMetaData().getColumnLabel(2));
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=1", rs.getString(1));
-        assertEquals("1.0", rs.getString(2));
-        rs = stat.executeQuery("SELECT * FROM FT_SEARCH_DATA('One', 0, 0)");
-        assertFalse(rs.next());
-        rs = stat.executeQuery("SELECT * FROM FT_SEARCH_DATA('One_Word', 0, 0)");
-        assertTrue(rs.next());
-        rs = stat.executeQuery("SELECT * FROM FT_SEARCH_DATA('Welcome', 0, 0)");
-        assertTrue(rs.next());
-        assertEquals("SCHEMA", rs.getMetaData().getColumnLabel(1));
-        assertEquals("TABLE", rs.getMetaData().getColumnLabel(2));
-        assertEquals("COLUMNS", rs.getMetaData().getColumnLabel(3));
-        assertEquals("KEYS", rs.getMetaData().getColumnLabel(4));
-        assertEquals("PUBLIC", rs.getString(1));
-        assertEquals("TEST", rs.getString(2));
-        assertEquals("[ID]", rs.getString(3));
-        assertEquals("[1]", rs.getString(4));
-
-        rs = stat.executeQuery("SELECT * FROM FT_SEARCH('this', 0, 0)");
-        assertFalse(rs.next());
-
-        if (!config.memory) {
-            conn.close();
-        }
-        conn = getConnection("fullTextNative", connList);
-        stat = conn.createStatement();
-        conn.setAutoCommit(false);
-        rs = stat.executeQuery("SELECT * FROM FT_SEARCH_DATA('Welcome', 0, 0)");
-        assertTrue(rs.next());
-        stat.execute("delete from test");
-        rs = stat.executeQuery("SELECT * FROM FT_SEARCH_DATA('Welcome', 0, 0)");
-        assertFalse(rs.next());
-        conn.rollback();
-        rs = stat.executeQuery("SELECT * FROM FT_SEARCH_DATA('Welcome', 0, 0)");
-        assertTrue(rs.next());
-        conn.setAutoCommit(true);
-        close(connList);
-    }
-
-    private void testUuidPrimaryKey(boolean lucene) throws SQLException {
-        deleteDb("fullText");
-        Connection conn = getConnection("fullText");
-        Statement stat = conn.createStatement();
-        String prefix = lucene ? "FTL" : "FT";
-        initFullText(stat, lucene);
-        stat.execute("CREATE TABLE TEST(ID UUID PRIMARY KEY, NAME VARCHAR)");
-        String id = UUID.randomUUID().toString();
-        stat.execute("INSERT INTO TEST VALUES('" + id + "', 'Hello World')");
-        stat.execute("CALL " + prefix + "_CREATE_INDEX('PUBLIC', 'TEST', 'NAME')");
-        ResultSet rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "_SEARCH('Hello', 0, 0)");
-        assertTrue(rs.next());
-        stat.execute("UPDATE TEST SET NAME=NULL WHERE ID='" + id + "'");
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "_SEARCH('Hello', 0, 0)");
-        assertFalse(rs.next());
-        stat.execute("UPDATE TEST SET NAME='Good Bye' WHERE ID='" + id + "'");
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "_SEARCH('bye', 0, 0)");
-        assertTrue(rs.next());
-        FullText.dropAll(conn);
-        conn.close();
-        deleteDb("fullText");
-    }
-
-    private void testTransaction(boolean lucene) throws SQLException {
-        String prefix = lucene ? "FTL" : "FT";
-        deleteDb("fullTextTransaction");
-        FileUtils.deleteRecursive(getBaseDir() + "/fullTextTransaction", false);
-        ArrayList<Connection> connList = new ArrayList<>();
-        Connection conn = getConnection("fullTextTransaction", connList);
-        Statement stat = conn.createStatement();
-        initFullText(stat, lucene);
-        stat.execute("CREATE TABLE TEST(ID INT PRIMARY KEY, NAME VARCHAR)");
-        stat.execute("INSERT INTO TEST VALUES(1, 'Hello World')");
-        stat.execute("CALL " + prefix + "_CREATE_INDEX('PUBLIC', 'TEST', NULL)");
-        ResultSet rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "_SEARCH('Hello', 0, 0)");
-        assertTrue(rs.next());
-        stat.execute("UPDATE TEST SET NAME=NULL WHERE ID=1");
-        stat.execute("UPDATE TEST SET NAME='Hello World' WHERE ID=1");
-        conn.setAutoCommit(false);
-        stat.execute("insert into test values(2, 'Hello Moon!')");
-        conn.rollback();
-        if (!config.memory) {
-            conn.close();
-        }
-        conn = getConnection("fullTextTransaction", connList);
-        stat = conn.createStatement();
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "_SEARCH('Hello', 0, 0)");
-        assertTrue(rs.next());
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "_SEARCH('Moon', 0, 0)");
-        assertFalse(rs.next());
-        FullText.dropAll(conn);
-        close(connList);
-        deleteDb("fullTextTransaction");
-        FileUtils.deleteRecursive(getBaseDir() + "/fullTextTransaction", false);
-    }
-
-    private void testMultiThreaded(boolean lucene) throws Exception {
-        final String prefix = lucene ? "FTL" : "FT";
-        trace("Testing multithreaded " + prefix);
-        deleteDb("fullText");
-        ArrayList<Connection> connList = new ArrayList<>();
-        try {
-            int len = 2;
-            Task[] task = new Task[len];
-            for (int i = 0; i < len; i++) {
-                final Connection conn = getConnection("fullText;LOCK_TIMEOUT=60000", connList);
-                Statement stat = conn.createStatement();
-                initFullText(stat, lucene);
-                initFullText(stat, lucene);
-                final String tableName = "TEST" + i;
-                stat.execute("CREATE TABLE " + tableName +
-                        "(ID INT PRIMARY KEY, DATA VARCHAR)");
-                stat.execute("CALL " + prefix +
-                        "_CREATE_INDEX('PUBLIC', '" + tableName + "', NULL)");
-                task[i] = new Task() {
-                    @Override
-                    public void call() throws SQLException {
-                        trace("starting thread " + Thread.currentThread());
-                        PreparedStatement prep = conn.prepareStatement(
-                                "INSERT INTO " + tableName + " VALUES(?, ?)");
-                        Statement stat = conn.createStatement();
-                        Random random = new Random();
-                        int x = 0;
-                        while (!stop) {
-                            trace("stop = " + stop + " for " + Thread.currentThread());
-                            StringBuilder buff = new StringBuilder();
-                            for (int j = 0; j < 1000; j++) {
-                                buff.append(" ").append(random.nextInt(10000));
-                                buff.append(" x").append(j);
-                                buff.append(" ").append(KNOWN_WORDS[j % KNOWN_WORDS.length]);
-                            }
-                            prep.setInt(1, x);
-                            prep.setString(2, buff.toString());
-                            prep.execute();
-                            x++;
-                            for (String knownWord : KNOWN_WORDS) {
-                                trace("searching for " + knownWord + " with " +
-                                        Thread.currentThread());
-                                ResultSet rs = stat.executeQuery("SELECT * FROM " +
-                                        prefix + "_SEARCH('" + knownWord +
-                                        "', 0, 0)");
-                                assertTrue(rs.next());
-                            }
-                        }
-                        trace("closing connection");
-                        if (!config.memory) {
-                            conn.close();
-                        }
-                        trace("completed thread " + Thread.currentThread());
-                    }
-                };
-            }
-            for (Task t : task) {
-                t.execute();
-            }
-            trace("sleeping");
-            Thread.sleep(1000);
-
-            trace("setting stop to true");
-            for (Task t : task) {
-                trace("joining " + t);
-                t.get();
-                trace("done joining " + t);
-            }
-        } finally {
-            close(connList);
-        }
-    }
-
-    private void testStreamLob() throws SQLException {
-        deleteDb("fullText");
-        Connection conn = getConnection("fullText");
-        Statement stat = conn.createStatement();
-        stat.execute("CREATE ALIAS IF NOT EXISTS FT_INIT " +
-                "FOR \"org.h2.fulltext.FullText.init\"");
-        stat.execute("CREATE TABLE TEST(ID INT PRIMARY KEY, DATA CLOB)");
-        FullText.createIndex(conn, "PUBLIC", "TEST", null);
-        conn.setAutoCommit(false);
-        stat.execute("insert into test values(1, 'Hello Moon!')");
-        conn.rollback();
-        conn.setAutoCommit(true);
-        stat.execute("insert into test values(0, 'Hello World!')");
-        PreparedStatement prep = conn.prepareStatement(
-                "insert into test values(1, ?)");
-        final int length = 1024 * 1024;
-        prep.setCharacterStream(1, new Reader() {
-            int remaining = length;
-
-            @Override
-            public void close() {
-                // ignore
-            }
-
-            @Override
-            public int read(char[] buff, int off, int len) {
-                if (remaining >= len) {
-                    remaining -= len;
-                    return len;
-                }
-                remaining = -1;
-                return -1;
-            }
-        }, length);
-        prep.execute();
-        ResultSet rs = stat.executeQuery(
-                "SELECT * FROM FT_SEARCH('World', 0, 0)");
-        assertTrue(rs.next());
-        rs = stat.executeQuery("SELECT * FROM FT_SEARCH('Moon', 0, 0)");
-        assertFalse(rs.next());
-        FullText.dropAll(conn);
-        conn.close();
-        deleteDb("fullText");
-    }
-
-    private void testCreateDropNative() throws SQLException {
-        deleteDb("fullText");
-        FileUtils.deleteRecursive(getBaseDir() + "/fullText", false);
-        Connection conn = getConnection("fullText");
-        Statement stat = conn.createStatement();
-        stat.execute("CREATE ALIAS IF NOT EXISTS FT_INIT " +
-                "FOR \"org.h2.fulltext.FullText.init\"");
-        stat.execute("CREATE TABLE TEST(ID INT PRIMARY KEY, NAME VARCHAR)");
-        for (int i = 0; i < 10; i++) {
-            FullText.createIndex(conn, "PUBLIC", "TEST", null);
-            FullText.dropIndex(conn, "PUBLIC", "TEST");
-        }
-        conn.close();
-        deleteDb("fullText");
-        FileUtils.deleteRecursive(getBaseDir() + "/fullText", false);
-    }
-
-    private void testCreateDropLucene() throws SQLException, SecurityException,
-            NoSuchMethodException, ClassNotFoundException,
-            IllegalArgumentException, IllegalAccessException,
-            InvocationTargetException {
-        deleteDb("fullText");
-        FileUtils.deleteRecursive(getBaseDir() + "/fullText", false);
-        Connection conn = getConnection("fullText");
-        Statement stat = conn.createStatement();
-        initFullText(stat, true);
-        stat.execute("CREATE TABLE TEST(ID INT PRIMARY KEY, NAME VARCHAR)");
-        Method createIndexMethod = Class.forName(
-                LUCENE_FULLTEXT_CLASS_NAME).getMethod("createIndex",
-                new Class[] { java.sql.Connection.class,
-                        String.class, String.class, String.class });
-        Method dropIndexMethod = Class.forName(
-                LUCENE_FULLTEXT_CLASS_NAME).getMethod("dropIndex",
-                new Class[] { java.sql.Connection.class,
-                        String.class, String.class });
-        for (int i = 0; i < 10; i++) {
-            createIndexMethod.invoke(null, conn, "PUBLIC", "TEST", null);
-            dropIndexMethod.invoke(null, conn, "PUBLIC", "TEST");
-        }
-        conn.close();
-        deleteDb("fullText");
-        FileUtils.deleteRecursive(getBaseDir() + "/fullText", false);
-    }
-
-    private void testReopen(boolean lucene) throws SQLException {
-        if (config.memory) {
-            return;
-        }
-        String prefix = lucene ? "FTL" : "FT";
-        deleteDb("fullTextReopen");
-        FileUtils.deleteRecursive(getBaseDir() + "/fullTextReopen", false);
-        Connection conn = getConnection("fullTextReopen");
-        Statement stat = conn.createStatement();
-        initFullText(stat, lucene);
-        stat.execute("CREATE TABLE TEST(ID INT PRIMARY KEY, NAME VARCHAR)");
-        stat.execute("INSERT INTO TEST VALUES(1, 'Hello World')");
-        stat.execute("CALL " + prefix + "_CREATE_INDEX('PUBLIC', 'TEST', NULL)");
-        stat.execute("UPDATE TEST SET NAME=NULL WHERE ID=1");
-        stat.execute("UPDATE TEST SET NAME='Hello World' WHERE ID=1");
-        conn.close();
-
-        conn = getConnection("fullTextReopen");
-        stat = conn.createStatement();
-        ResultSet rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "_SEARCH('Hello', 0, 0)");
-        assertTrue(rs.next());
-        stat.executeQuery("SELECT * FROM " + prefix + "_SEARCH(NULL, 0, 0)");
-        stat.execute("INSERT INTO TEST VALUES(2, NULL)");
-        conn.close();
-
-        FullText.closeAll();
-        conn = getConnection("fullTextReopen");
-        stat = conn.createStatement();
-        stat.execute("INSERT INTO TEST VALUES(3, 'Hello')");
-        conn.close();
-        FileUtils.deleteRecursive(getBaseDir() + "/fullTextReopen", false);
-    }
-
-    private void testPerformance(boolean lucene) throws SQLException {
-        deleteDb("fullText");
-        FileUtils.deleteRecursive(getBaseDir() + "/fullText", false);
-        Connection conn = getConnection("fullText");
-        String prefix = lucene ? "FTL" : "FT";
-        Statement stat = conn.createStatement();
-        initFullText(stat, lucene);
-        stat.execute("DROP TABLE IF EXISTS TEST");
-        stat.execute(
-                "CREATE TABLE TEST AS SELECT * FROM INFORMATION_SCHEMA.HELP");
-        stat.execute("ALTER TABLE TEST ALTER COLUMN ID INT NOT NULL");
-        stat.execute("CREATE PRIMARY KEY ON TEST(ID)");
-        long time = System.nanoTime();
-        stat.execute("CALL " + prefix + "_CREATE_INDEX('PUBLIC', 'TEST', NULL)");
-        println("create " + prefix + ": " +
-                TimeUnit.NANOSECONDS.toMillis(System.nanoTime() - time));
-        PreparedStatement prep = conn.prepareStatement(
-                "SELECT * FROM " + prefix + "_SEARCH(?, 0, 0)");
-        time = System.nanoTime();
-        ResultSet rs = stat.executeQuery("SELECT TEXT FROM TEST");
-        int count = 0;
-        while (rs.next()) {
-            String text = rs.getString(1);
-            StringTokenizer tokenizer = new StringTokenizer(
-                        text, " ()[].,;:-+*/!?=<>{}#@'\"~$_%&|");
-            while (tokenizer.hasMoreTokens()) {
-                String word = tokenizer.nextToken();
-                if (word.length() < 10) {
-                    continue;
-                }
-                prep.setString(1, word);
-                ResultSet rs2 = prep.executeQuery();
-                while (rs2.next()) {
-                    rs2.getString(1);
-                    count++;
-                }
-            }
-        }
-        println("search " + prefix + ": " +
-                TimeUnit.NANOSECONDS.toMillis(System.nanoTime() - time) + " count: " + count);
-        stat.execute("CALL " + prefix + "_DROP_ALL()");
-        conn.close();
-    }
-
-    private void test(boolean lucene, String dataType) throws SQLException {
-        if (lucene && getBaseDir().indexOf(':') > 0) {
-            return;
-        }
-        deleteDb("fullText");
-        Connection conn = getConnection("fullText");
-        String prefix = lucene ? "FTL_" : "FT_";
-        Statement stat = conn.createStatement();
-        String className = lucene ? "FullTextLucene" : "FullText";
-        stat.execute("CREATE ALIAS IF NOT EXISTS " +
-                prefix + "INIT FOR \"org.h2.fulltext." + className + ".init\"");
-        stat.execute("CALL " + prefix + "INIT()");
-        stat.execute("DROP TABLE IF EXISTS TEST");
-        stat.execute("CREATE TABLE TEST(ID INT PRIMARY KEY, NAME " + dataType + ")");
-        stat.execute("INSERT INTO TEST VALUES(1, 'Hello World')");
-        stat.execute("CALL " + prefix + "CREATE_INDEX('PUBLIC', 'TEST', NULL)");
-        ResultSet rs;
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('Hello', 0, 0)");
-        rs.next();
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=1", rs.getString(1));
-        assertFalse(rs.next());
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('Hallo', 0, 0)");
-        assertFalse(rs.next());
-        stat.execute("INSERT INTO TEST VALUES(2, 'Hallo Welt')");
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('Hello', 0, 0)");
-        rs.next();
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=1", rs.getString(1));
-        assertFalse(rs.next());
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('Hallo', 0, 0)");
-        rs.next();
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=2", rs.getString(1));
-        assertFalse(rs.next());
-
-        stat.execute("CALL " + prefix + "REINDEX()");
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('Hello', 0, 0)");
-        rs.next();
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=1", rs.getString(1));
-        assertFalse(rs.next());
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('Hallo', 0, 0)");
-        rs.next();
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=2", rs.getString(1));
-        assertFalse(rs.next());
-
-        stat.execute("INSERT INTO TEST VALUES(3, 'Hello World')");
-        stat.execute("INSERT INTO TEST VALUES(4, 'Hello World')");
-        stat.execute("INSERT INTO TEST VALUES(5, 'Hello World')");
-
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('World', 0, 0) ORDER BY QUERY");
-        rs.next();
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=1", rs.getString(1));
-        rs.next();
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=3", rs.getString(1));
-        rs.next();
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=4", rs.getString(1));
-        rs.next();
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=5", rs.getString(1));
-        assertFalse(rs.next());
-
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('World', 1, 0)");
-        rs.next();
-        assertTrue(rs.getString(1).startsWith("\"PUBLIC\".\"TEST\" WHERE \"ID\"="));
-        assertFalse(rs.next());
-
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('World', 0, 2) ORDER BY QUERY");
-        rs.next();
-        assertTrue(rs.getString(1).startsWith("\"PUBLIC\".\"TEST\" WHERE \"ID\"="));
-        rs.next();
-        assertTrue(rs.getString(1).startsWith("\"PUBLIC\".\"TEST\" WHERE \"ID\"="));
-        assertFalse(rs.next());
-
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('World', 2, 1) ORDER BY QUERY");
-        rs.next();
-        assertTrue(rs.getString(1).startsWith("\"PUBLIC\".\"TEST\" WHERE \"ID\"="));
-        rs.next();
-        assertTrue(rs.getString(1).startsWith("\"PUBLIC\".\"TEST\" WHERE \"ID\"="));
-        assertFalse(rs.next());
-
-        rs = stat.executeQuery("SELECT * FROM " +
-                prefix + "SEARCH('1', 0, 0)");
-        rs.next();
-        assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=1", rs.getString(1));
-        assertFalse(rs.next());
-
-        if (lucene) {
-            rs = stat.executeQuery("SELECT * FROM " +
-                    prefix + "SEARCH('NAME:Hallo', 0, 0)");
-            rs.next();
-            assertEquals("\"PUBLIC\".\"TEST\" WHERE \"ID\"=2", rs.getString(1));
-            assertFalse(rs.next());
-        }
-
-        if (!config.memory) {
-            conn.close();
-            conn = getConnection("fullText");
-        }
-
-        stat = conn.createStatement();
-        stat.executeQuery("SELECT * FROM " + prefix + "SEARCH('World', 0, 0)");
-
-        stat.execute("CALL " + prefix + "DROP_ALL()");
-
-        conn.close();
-    }
-
-    private void testDropIndex(boolean lucene) throws SQLException {
-        if (config.memory) {
-            return;
-        }
-        deleteDb("fullTextDropIndex");
-        String prefix = lucene ? "FTL" : "FT";
-        FileUtils.deleteRecursive(getBaseDir() + "/fullTextDropIndex", false);
-        Connection conn = getConnection("fullTextDropIndex");
-        Statement stat = conn.createStatement();
-        initFullText(stat, lucene);
-        stat.execute("CREATE TABLE TEST" +
-                "(ID INT PRIMARY KEY, NAME1 VARCHAR, NAME2 VARCHAR)");
-        stat.execute("INSERT INTO TEST VALUES" +
-                "(1, 'Hello World', 'Hello Again')");
-        stat.execute("CALL " + prefix +
-                "_CREATE_INDEX('PUBLIC', 'TEST', 'NAME1')");
-        stat.execute("UPDATE TEST SET NAME1=NULL WHERE ID=1");
-        stat.execute("UPDATE TEST SET NAME1='Hello World' WHERE ID=1");
-        stat.execute("CALL " + prefix +
-                "_DROP_INDEX('PUBLIC', 'TEST')");
-        stat.execute("CALL " + prefix +
-                "_CREATE_INDEX('PUBLIC', 'TEST', 'NAME1, NAME2')");
-        stat.execute("UPDATE TEST SET NAME2=NULL WHERE ID=1");
-        stat.execute("UPDATE TEST SET NAME2='Hello World' WHERE ID=1");
-
-        conn.close();
-        FileUtils.deleteRecursive(getBaseDir() + "/fullTextDropIndex", false);
-    }
-
-    private static void initFullText(Statement stat, boolean lucene)
-            throws SQLException {
-        String prefix = lucene ? "FTL" : "FT";
-        String className = lucene ? "FullTextLucene" : "FullText";
-        stat.execute("CREATE ALIAS IF NOT EXISTS " + prefix +
-                "_INIT FOR \"org.h2.fulltext." + className + ".init\"");
-        stat.execute("CALL " + prefix + "_INIT()");
-    }
-}
diff --git a/modules/h2/src/test/java/org/h2/test/unit/TestRecovery.java b/modules/h2/src/test/java/org/h2/test/unit/TestRecovery.java
index 006e210..21c3244 100644
--- a/modules/h2/src/test/java/org/h2/test/unit/TestRecovery.java
+++ b/modules/h2/src/test/java/org/h2/test/unit/TestRecovery.java
@@ -50,7 +50,6 @@ public class TestRecovery extends TestDb {
             testRecoverTestMode();
         }
         testRecoverClob();
-        testRecoverFulltext();
         testRedoTransactions();
         testCorrupt();
         testWithTransactionLog();
@@ -88,25 +87,6 @@ public class TestRecovery extends TestDb {
         conn.close();
     }
 
-    private void testRecoverFulltext() throws Exception {
-        DeleteDbFiles.execute(getBaseDir(), "recovery", true);
-        Connection conn = getConnection("recovery");
-        Statement stat = conn.createStatement();
-        stat.execute("CREATE ALIAS IF NOT EXISTS FTL_INIT " +
-                "FOR \"org.h2.fulltext.FullTextLucene.init\"");
-        stat.execute("CALL FTL_INIT()");
-        stat.execute("create table test(id int primary key, name varchar) as " +
-                "select 1, 'Hello'");
-        stat.execute("CALL FTL_CREATE_INDEX('PUBLIC', 'TEST', 'NAME')");
-        conn.close();
-        Recover.main("-dir", getBaseDir(), "-db", "recovery");
-        DeleteDbFiles.execute(getBaseDir(), "recovery", true);
-        conn = getConnection(
-                "recovery;init=runscript from '" +
-                getBaseDir() + "/recovery.h2.sql'");
-        conn.close();
-    }
-
     private void testRedoTransactions() throws Exception {
         if (config.mvStore) {
             // not needed for MV_STORE=TRUE


[ignite] 11/17: GG-17466 Web Console: Fixed e2e tests. Fixes #15.

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 1326c5eaaba1a30b3e2a6856fcb333cf582df55d
Author: Ilya Borisov <ib...@gridgain.com>
AuthorDate: Mon Apr 29 14:36:34 2019 +0700

    GG-17466 Web Console: Fixed e2e tests. Fixes #15.
---
 modules/web-console/e2e/testcafe/components/FormField.js         | 2 +-
 modules/web-console/e2e/testcafe/fixtures/configuration/basic.js | 6 +++---
 2 files changed, 4 insertions(+), 4 deletions(-)

diff --git a/modules/web-console/e2e/testcafe/components/FormField.js b/modules/web-console/e2e/testcafe/components/FormField.js
index 9b577a0..1be4faf 100644
--- a/modules/web-console/e2e/testcafe/components/FormField.js
+++ b/modules/web-console/e2e/testcafe/components/FormField.js
@@ -51,7 +51,7 @@ export class FormField {
     async selectOption(label) {
         await t
             .click(this.control)
-            .click(Selector('.bssm-item-button').withText(label));
+            .click(this.control.find('option').withText(label));
     }
     /**
      * Get error element by error type
diff --git a/modules/web-console/e2e/testcafe/fixtures/configuration/basic.js b/modules/web-console/e2e/testcafe/fixtures/configuration/basic.js
index d6c178e..c38965f 100644
--- a/modules/web-console/e2e/testcafe/fixtures/configuration/basic.js
+++ b/modules/web-console/e2e/testcafe/fixtures/configuration/basic.js
@@ -56,7 +56,7 @@ test('Basic editing', async(t) => {
     const page = new PageConfigurationBasic();
     const clusterName = 'Test basic cluster #1';
     const localMode = 'LOCAL';
-    const atomic = 'ATOMIC';
+    const transactional = 'TRANSACTIONAL';
 
     await t
         .expect(page.buttonPreviewProject.visible).notOk('Preview project button is hidden for new cluster configs')
@@ -69,12 +69,12 @@ test('Basic editing', async(t) => {
     await cache1.startEdit();
     await t.typeText(cache1.fields.name.control, 'Foobar');
     await cache1.fields.cacheMode.selectOption(localMode);
-    await cache1.fields.atomicityMode.selectOption(atomic);
+    await cache1.fields.atomicityMode.selectOption(transactional);
     await cache1.stopEdit();
 
     await t.expect(cache1.getItemViewColumn(0).textContent).contains(`Cache1Foobar`, 'Can edit cache name');
     await t.expect(cache1.getItemViewColumn(1).textContent).eql(localMode, 'Can edit cache mode');
-    await t.expect(cache1.getItemViewColumn(2).textContent).eql(atomic, 'Can edit cache atomicity');
+    await t.expect(cache1.getItemViewColumn(2).textContent).eql(transactional, 'Can edit cache atomicity');
 
     await page.save();
     await t


[ignite] 13/17: GG-17440 DMS feature id changed for the sake of rolling upgrade support.

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit ac5baab7d240470a82887e1d9892ac6c5c73f72a
Author: ibessonov <be...@gmail.com>
AuthorDate: Mon Apr 29 16:22:57 2019 +0300

    GG-17440 DMS feature id changed for the sake of rolling upgrade support.
---
 .../src/main/java/org/apache/ignite/internal/IgniteFeatures.java | 9 ++++-----
 1 file changed, 4 insertions(+), 5 deletions(-)

diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgniteFeatures.java b/modules/core/src/main/java/org/apache/ignite/internal/IgniteFeatures.java
index cf02103..22f83b1 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgniteFeatures.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgniteFeatures.java
@@ -35,9 +35,6 @@ public enum IgniteFeatures {
     /** Cache metrics v2 support. */
     CACHE_METRICS_V2(1),
 
-    /** Distributed metastorage. */
-    DISTRIBUTED_METASTORAGE(2),
-
     /** Data paket compression. */
     DATA_PACKET_COMPRESSION(3),
 
@@ -53,9 +50,11 @@ public enum IgniteFeatures {
      */
     TRANSACTION_OWNER_THREAD_DUMP_PROVIDING(6),
 
-
     /** Displaying versbose transaction information: --info option of --tx control script command. */
-    TX_INFO_COMMAND(7);
+    TX_INFO_COMMAND(7),
+
+    /** Distributed metastorage. */
+    DISTRIBUTED_METASTORAGE(11);
 
     /**
      * Unique feature identifier.


[ignite] 05/17: GG-17331 Clean up GridDhtPartitionsFullMessage when not needed, do not hold decompressed partsSizes in field.

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

amashenkov pushed a commit to branch gg-18539
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit c35f196fb4cde684e1de2ce240a362a849dde922
Author: Ilya Kasnacheev <il...@gmail.com>
AuthorDate: Fri Apr 26 14:35:02 2019 +0300

    GG-17331 Clean up GridDhtPartitionsFullMessage when not needed, do not hold decompressed partsSizes in field.
    
    Since uncompression of partsSizes is de-parallelized, PME might be slightly slower while consuming way less Heap.
    
    Cherry-picked from 478277e5e3fe1a535ea905f8beab42926453825a
---
 .../cache/GridCachePartitionExchangeManager.java   | 21 ++++-
 .../GridDhtPartitionsAbstractMessage.java          |  4 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java | 14 ++-
 .../preloader/GridDhtPartitionsFullMessage.java    | 99 ++++++++++------------
 .../preloader/GridDhtPartitionsSingleMessage.java  | 15 +---
 .../cache/CacheGroupsMetricsRebalanceTest.java     |  4 +-
 6 files changed, 81 insertions(+), 76 deletions(-)

diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePartitionExchangeManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePartitionExchangeManager.java
index bcb1dc5..357fa6f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePartitionExchangeManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePartitionExchangeManager.java
@@ -1377,10 +1377,12 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
             partsToReload
             );
 
-        m.compress(compress);
+        m.compressed(compress);
 
         final Map<Object, T2<Integer, GridDhtPartitionFullMap>> dupData = new HashMap<>();
 
+        Map<Integer, Map<Integer, Long>> partsSizes = new HashMap<>();
+
         for (CacheGroupContext grp : grps) {
             if (!grp.isLocal()) {
                 if (exchId != null) {
@@ -1397,7 +1399,10 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
                 if (locMap != null)
                     addFullPartitionsMap(m, dupData, compress, grp.groupId(), locMap, affCache.similarAffinityKey());
 
-                m.addPartitionSizes(grp.groupId(), grp.topology().globalPartSizes());
+                Map<Integer, Long> partSizesMap = grp.topology().globalPartSizes();
+
+                if (!partSizesMap.isEmpty())
+                    partsSizes.put(grp.groupId(), partSizesMap);
 
                 if (exchId != null) {
                     CachePartitionFullCountersMap cntrsMap = grp.topology().fullUpdateCounters();
@@ -1427,12 +1432,18 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
                 else
                     m.addPartitionUpdateCounters(top.groupId(), CachePartitionFullCountersMap.toCountersMap(cntrsMap));
 
-                m.addPartitionSizes(top.groupId(), top.globalPartSizes());
+                Map<Integer, Long> partSizesMap = top.globalPartSizes();
+
+                if (!partSizesMap.isEmpty())
+                    partsSizes.put(top.groupId(), partSizesMap);
             }
         }
 
         cctx.kernalContext().txDr().onPartitionsFullMessagePrepared(exchId, m);
 
+        if (!partsSizes.isEmpty())
+            m.partitionSizes(cctx, partsSizes);
+
         return m;
     }
 
@@ -1778,6 +1789,8 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
 
                 boolean updated = false;
 
+                Map<Integer, Map<Integer, Long>> partsSizes = msg.partitionSizes(cctx);
+
                 for (Map.Entry<Integer, GridDhtPartitionFullMap> entry : msg.partitions().entrySet()) {
                     Integer grpId = entry.getKey();
 
@@ -1795,7 +1808,7 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
                             entry.getValue(),
                             null,
                             msg.partsToReload(cctx.localNodeId(), grpId),
-                            msg.partitionSizes(grpId),
+                            partsSizes.getOrDefault(grpId, Collections.emptyMap()),
                             msg.topologyVersion());
                     }
                 }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsAbstractMessage.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsAbstractMessage.java
index a82b4ba..e5ae699 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsAbstractMessage.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsAbstractMessage.java
@@ -117,14 +117,14 @@ public abstract class GridDhtPartitionsAbstractMessage extends GridCacheMessage
     /**
      * @return {@code True} if message data is compressed.
      */
-    protected final boolean compressed() {
+    public final boolean compressed() {
         return (flags & COMPRESSED_FLAG_MASK) != 0;
     }
 
     /**
      * @param compressed {@code True} if message data is compressed.
      */
-    protected final void compressed(boolean compressed) {
+    public final void compressed(boolean compressed) {
         flags = compressed ? (byte)(flags | COMPRESSED_FLAG_MASK) : (byte)(flags & ~COMPRESSED_FLAG_MASK);
     }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
index 4ba4d5b..6330d4f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
@@ -2493,6 +2493,8 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
         newCrdFut = null;
         exchangeLocE = null;
         exchangeGlobalExceptions.clear();
+        if (finishState != null)
+            finishState.cleanUp();
     }
 
     /**
@@ -4250,6 +4252,8 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
         int parallelismLvl = U.availableThreadCount(cctx.kernalContext(), GridIoPolicy.SYSTEM_POOL, 2);
 
         try {
+            Map<Integer, Map<Integer, Long>> partsSizes = msg.partitionSizes(cctx);
+
             doInParallel(
                 parallelismLvl,
                 cctx.kernalContext().getSystemExecutorService(),
@@ -4264,7 +4268,7 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
                             msg.partitions().get(grpId),
                             cntrMap,
                             msg.partsToReload(cctx.localNodeId(), grpId),
-                            msg.partitionSizes(grpId),
+                            partsSizes.getOrDefault(grpId, Collections.emptyMap()),
                             null);
                     }
                     else {
@@ -5079,6 +5083,14 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
             this.resTopVer = resTopVer;
             this.msg = msg;
         }
+
+        /**
+         * Cleans up resources to avoid excessive memory usage.
+         */
+        public void cleanUp() {
+            if (msg != null)
+                msg.cleanUp();
+        }
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsFullMessage.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsFullMessage.java
index b010ff5..b8f57ce 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsFullMessage.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsFullMessage.java
@@ -27,6 +27,7 @@ import java.util.Map;
 import java.util.Set;
 import java.util.UUID;
 import org.apache.ignite.IgniteCheckedException;
+import org.apache.ignite.IgniteException;
 import org.apache.ignite.cluster.ClusterNode;
 import org.apache.ignite.internal.GridDirectMap;
 import org.apache.ignite.internal.GridDirectTransient;
@@ -99,11 +100,6 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
     /** Serialized partitions that must be cleared and re-loaded. */
     private byte[] partsToReloadBytes;
 
-    /** Partitions sizes. */
-    @GridToStringInclude
-    @GridDirectTransient
-    private Map<Integer, Map<Integer, Long>> partsSizes;
-
     /** Serialized partitions sizes. */
     private byte[] partsSizesBytes;
 
@@ -119,10 +115,6 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
     private byte[] errsBytes;
 
     /** */
-    @GridDirectTransient
-    private transient boolean compress;
-
-    /** */
     private AffinityTopologyVersion resTopVer;
 
     /** */
@@ -178,12 +170,10 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
         cp.partHistSuppliersBytes = partHistSuppliersBytes;
         cp.partsToReload = partsToReload;
         cp.partsToReloadBytes = partsToReloadBytes;
-        cp.partsSizes = partsSizes;
         cp.partsSizesBytes = partsSizesBytes;
         cp.topVer = topVer;
         cp.errs = errs;
         cp.errsBytes = errsBytes;
-        cp.compress = compress;
         cp.resTopVer = resTopVer;
         cp.joinedNodeAff = joinedNodeAff;
         cp.idealAffDiff = idealAffDiff;
@@ -250,13 +240,6 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
     }
 
     /**
-     * @param compress {@code True} if it is possible to use compression for message.
-     */
-    public void compress(boolean compress) {
-        this.compress = compress;
-    }
-
-    /**
      * @return Local partitions.
      */
     public Map<Integer, GridDhtPartitionFullMap> partitions() {
@@ -289,7 +272,7 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
             parts.put(grpId, fullMap);
 
             if (dupDataCache != null) {
-                assert compress;
+                assert compressed();
                 assert parts.containsKey(dupDataCache);
 
                 if (dupPartsData == null)
@@ -360,32 +343,43 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
     }
 
     /**
-     * Adds partition sizes map for specified {@code grpId} to the current message.
+     * Supplies partition sizes map for all cache groups.
      *
-     * @param grpId Group id.
-     * @param partSizesMap Partition sizes map.
+     * @param ctx Cache context.
+     * @param partsSizes Partitions sizes map.
      */
-    public void addPartitionSizes(int grpId, Map<Integer, Long> partSizesMap) {
-        if (partSizesMap.isEmpty())
-            return;
+    public void partitionSizes(GridCacheSharedContext ctx, Map<Integer, Map<Integer, Long>> partsSizes) {
+        try {
+            byte[] marshalled = U.marshal(ctx, partsSizes);
 
-        if (partsSizes == null)
-            partsSizes = new HashMap<>();
+            if (compressed())
+                marshalled = U.zip(marshalled, ctx.gridConfig().getNetworkCompressionLevel());
 
-        partsSizes.put(grpId, partSizesMap);
+            partsSizesBytes = marshalled;
+        }
+        catch (IgniteCheckedException ex) {
+            throw new IgniteException(ex);
+        }
     }
 
     /**
-     * Returns partition sizes map for specified {@code grpId}.
+     * Returns partition sizes map for all cache groups.
      *
-     * @param grpId Group id.
-     * @return Partition sizes map (partId, partSize).
+     * @param ctx Cache context.
+     * @return Partition sizes map (grpId, (partId, partSize)).
      */
-    public Map<Integer, Long> partitionSizes(int grpId) {
-        if (partsSizes == null)
+    public Map<Integer, Map<Integer, Long>> partitionSizes(GridCacheSharedContext ctx) {
+        if (partsSizesBytes == null)
             return Collections.emptyMap();
 
-        return partsSizes.getOrDefault(grpId, Collections.emptyMap());
+        try {
+            return compressed()
+                ? U.unmarshalZip(ctx.marshaller(), partsSizesBytes, ctx.deploy().globalLoader())
+                : U.unmarshal(ctx, partsSizesBytes, ctx.deploy().globalLoader());
+        }
+        catch (IgniteCheckedException ex) {
+            throw new IgniteException(ex);
+        }
     }
 
     /**
@@ -434,9 +428,6 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
             if (partsToReload != null && partsToReloadBytes == null)
                 objectsToMarshall.add(partsToReload);
 
-            if (partsSizes != null && partsSizesBytes == null)
-                objectsToMarshall.add(partsSizes);
-
             if (!F.isEmpty(errs) && errsBytes == null)
                 objectsToMarshall.add(errs);
 
@@ -448,7 +439,7 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
                     @Override public byte[] apply(Object payload) throws IgniteCheckedException {
                         byte[] marshalled = U.marshal(ctx, payload);
 
-                        if(compress)
+                        if(compressed())
                             marshalled = U.zip(marshalled, ctx.gridConfig().getNetworkCompressionLevel());
 
                         return marshalled;
@@ -472,17 +463,8 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
             if (partsToReload != null && partsToReloadBytes == null)
                 partsToReloadBytes = iterator.next();
 
-            if (partsSizes != null && partsSizesBytes == null)
-                partsSizesBytes = iterator.next();
-
             if (!F.isEmpty(errs) && errsBytes == null)
                 errsBytes = iterator.next();
-
-            if (compress) {
-                assert !compressed() : "Unexpected compressed state";
-
-                compressed(true);
-            }
         }
     }
 
@@ -526,9 +508,6 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
         if (partsToReloadBytes != null && partsToReload == null)
             objectsToUnmarshall.add(partsToReloadBytes);
 
-        if (partsSizesBytes != null && partsSizes == null)
-            objectsToUnmarshall.add(partsSizesBytes);
-
         if (errsBytes != null && errs == null)
             objectsToUnmarshall.add(errsBytes);
 
@@ -590,9 +569,6 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
         if (partsToReloadBytes != null && partsToReload == null)
             partsToReload = (IgniteDhtPartitionsToReloadMap)iterator.next();
 
-        if (partsSizesBytes != null && partsSizes == null)
-            partsSizes = (Map<Integer, Map<Integer, Long>>)iterator.next();
-
         if (errsBytes != null && errs == null)
             errs = (Map<UUID, Exception>)iterator.next();
 
@@ -611,9 +587,6 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
         if(partsToReload == null)
             partsToReload = new IgniteDhtPartitionsToReloadMap();
 
-        if(partsSizes == null)
-            partsSizes = new HashMap<>();
-
         if (errs == null)
             errs = new HashMap<>();
     }
@@ -868,4 +841,18 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
             }
         }
     }
+
+    /**
+     * Cleans up resources to avoid excessive memory usage.
+     */
+    public void cleanUp() {
+        partsBytes = null;
+        partCntrs2 = null;
+        partCntrsBytes = null;
+        partCntrsBytes2 = null;
+        partHistSuppliersBytes = null;
+        partsToReloadBytes = null;
+        partsSizesBytes = null;
+        errsBytes = null;
+    }
 }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsSingleMessage.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsSingleMessage.java
index 398649f..793224c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsSingleMessage.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsSingleMessage.java
@@ -94,10 +94,6 @@ public class GridDhtPartitionsSingleMessage extends GridDhtPartitionsAbstractMes
     private boolean client;
 
     /** */
-    @GridDirectTransient
-    private transient boolean compress;
-
-    /** */
     @GridDirectCollection(Integer.class)
     private Collection<Integer> grpsAffRequest;
 
@@ -130,8 +126,9 @@ public class GridDhtPartitionsSingleMessage extends GridDhtPartitionsAbstractMes
     ) {
         super(exchId, lastVer);
 
+        compressed(compress);
+
         this.client = client;
-        this.compress = compress;
     }
 
     /**
@@ -186,7 +183,7 @@ public class GridDhtPartitionsSingleMessage extends GridDhtPartitionsAbstractMes
         parts.put(cacheId, locMap);
 
         if (dupDataCache != null) {
-            assert compress;
+            assert compressed();
             assert F.isEmpty(locMap.map());
             assert parts.containsKey(dupDataCache);
 
@@ -365,9 +362,7 @@ public class GridDhtPartitionsSingleMessage extends GridDhtPartitionsAbstractMes
             if (err != null && errBytes == null)
                 errBytes0 = U.marshal(ctx, err);
 
-            if (compress) {
-                assert !compressed();
-
+            if (compressed()) {
                 try {
                     byte[] partsBytesZip = U.zip(partsBytes0);
                     byte[] partCntrsBytesZip = U.zip(partCntrsBytes0);
@@ -380,8 +375,6 @@ public class GridDhtPartitionsSingleMessage extends GridDhtPartitionsAbstractMes
                     partHistCntrsBytes0 = partHistCntrsBytesZip;
                     partsSizesBytes0 = partsSizesBytesZip;
                     errBytes0 = exBytesZip;
-
-                    compressed(true);
                 }
                 catch (IgniteCheckedException e) {
                     U.error(ctx.logger(getClass()), "Failed to compress partitions data: " + e, e);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheGroupsMetricsRebalanceTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheGroupsMetricsRebalanceTest.java
index f615410..1eb1115 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheGroupsMetricsRebalanceTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheGroupsMetricsRebalanceTest.java
@@ -346,7 +346,7 @@ public class CacheGroupsMetricsRebalanceTest extends GridCommonAbstractTest {
             @Override public boolean apply() {
                 return ig2.cache(CACHE1).localMetrics().getKeysToRebalanceLeft() == 0;
             }
-        }, timeLeft + 10_000L);
+        }, timeLeft + 12_000L);
 
         log.info("[timePassed=" + timePassed + ", timeLeft=" + timeLeft +
                 ", Time to rebalance=" + (finishTime - startTime) +
@@ -361,7 +361,7 @@ public class CacheGroupsMetricsRebalanceTest extends GridCommonAbstractTest {
 
         long diff = finishTime - currTime;
 
-        assertTrue("Expected less than 10000, but actual: " + diff, Math.abs(diff) < 10_000L);
+        assertTrue("Expected less than 12000, but actual: " + diff, Math.abs(diff) < 12_000L);
     }
 
     /**