You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@griffin.apache.org by gu...@apache.org on 2017/06/26 06:04:43 UTC

[1/6] incubator-griffin git commit: remove stale docs

Repository: incubator-griffin
Updated Branches:
  refs/heads/master c883cf868 -> e934c0d69


http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/livy/livy.conf
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/livy/livy.conf b/docker/griffin_env/conf/livy/livy.conf
deleted file mode 100644
index 87b3b93..0000000
--- a/docker/griffin_env/conf/livy/livy.conf
+++ /dev/null
@@ -1,20 +0,0 @@
-
-# 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.
-
-
-livy.spark.master = yarn
-livy.spark.deployMode = cluster
-livy.repl.enableHiveContext = true

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/mysql/bind_0.cnf
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/mysql/bind_0.cnf b/docker/griffin_env/conf/mysql/bind_0.cnf
deleted file mode 100644
index 9897d43..0000000
--- a/docker/griffin_env/conf/mysql/bind_0.cnf
+++ /dev/null
@@ -1,19 +0,0 @@
-
-
-# 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.
-
-[mysqld]
-bind-address=0.0.0.0

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/mysql/hive-metastore-init.sql
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/mysql/hive-metastore-init.sql b/docker/griffin_env/conf/mysql/hive-metastore-init.sql
deleted file mode 100644
index d08da6d..0000000
--- a/docker/griffin_env/conf/mysql/hive-metastore-init.sql
+++ /dev/null
@@ -1,22 +0,0 @@
-# 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.
-
-CREATE DATABASE metastore;
-USE metastore;
-SOURCE /apache/hive/scripts/metastore/upgrade/mysql/hive-schema-1.2.0.mysql.sql;
-
-CREATE USER 'hive'@'%' IDENTIFIED BY '123456';
-GRANT ALL PRIVILEGES ON metastore.* TO 'hive'@'%';
-FLUSH PRIVILEGES;

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/mysql/mysql-init.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/mysql/mysql-init.sh b/docker/griffin_env/conf/mysql/mysql-init.sh
deleted file mode 100755
index 85ef45f..0000000
--- a/docker/griffin_env/conf/mysql/mysql-init.sh
+++ /dev/null
@@ -1,26 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-service mysql start
-
-sed -i.bak s/^.*"hive-txn-schema-0.13.0.mysql.sql".*/"SOURCE \/apache\/hive\/scripts\/metastore\/upgrade\/mysql\/hive-txn-schema-0.13.0.mysql.sql;"/ /apache/hive/scripts/metastore/upgrade/mysql/hive-schema-1.2.0.mysql.sql
-
-mysql -u root < hive-metastore-init.sql
-
-mysql -u root < quartz-metastore-init.sql
-mysql -u griffin -p123456 -D quartz < quartz-table-init.sql

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/mysql/quartz-metastore-init.sql
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/mysql/quartz-metastore-init.sql b/docker/griffin_env/conf/mysql/quartz-metastore-init.sql
deleted file mode 100644
index 0cc9dac..0000000
--- a/docker/griffin_env/conf/mysql/quartz-metastore-init.sql
+++ /dev/null
@@ -1,22 +0,0 @@
-# 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.
-
-
-CREATE DATABASE quartz;
-USE quartz;
-
-CREATE USER 'griffin'@'%' IDENTIFIED BY '123456';
-GRANT ALL PRIVILEGES ON quartz.* TO 'griffin'@'%';
-FLUSH PRIVILEGES;

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/mysql/quartz-table-init.sql
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/mysql/quartz-table-init.sql b/docker/griffin_env/conf/mysql/quartz-table-init.sql
deleted file mode 100644
index 2a37482..0000000
--- a/docker/griffin_env/conf/mysql/quartz-table-init.sql
+++ /dev/null
@@ -1,196 +0,0 @@
-# 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.
-
-
-#
-# In your Quartz properties file, you'll need to set
-# org.quartz.jobStore.driverDelegateClass = org.quartz.impl.jdbcjobstore.StdJDBCDelegate
-#
-#
-# By: Ron Cordell - roncordell
-#  I didn't see this anywhere, so I thought I'd post it here. This is the script from Quartz to create the tables in a MySQL database, modified to use INNODB instead of MYISAM.
-
-DROP TABLE IF EXISTS QRTZ_FIRED_TRIGGERS;
-DROP TABLE IF EXISTS QRTZ_PAUSED_TRIGGER_GRPS;
-DROP TABLE IF EXISTS QRTZ_SCHEDULER_STATE;
-DROP TABLE IF EXISTS QRTZ_LOCKS;
-DROP TABLE IF EXISTS QRTZ_SIMPLE_TRIGGERS;
-DROP TABLE IF EXISTS QRTZ_SIMPROP_TRIGGERS;
-DROP TABLE IF EXISTS QRTZ_CRON_TRIGGERS;
-DROP TABLE IF EXISTS QRTZ_BLOB_TRIGGERS;
-DROP TABLE IF EXISTS QRTZ_TRIGGERS;
-DROP TABLE IF EXISTS QRTZ_JOB_DETAILS;
-DROP TABLE IF EXISTS QRTZ_CALENDARS;
-
-CREATE TABLE QRTZ_JOB_DETAILS(
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  JOB_NAME VARCHAR(200) NOT NULL,
-  JOB_GROUP VARCHAR(200) NOT NULL,
-  DESCRIPTION VARCHAR(250) NULL,
-  JOB_CLASS_NAME VARCHAR(250) NOT NULL,
-  IS_DURABLE VARCHAR(1) NOT NULL,
-  IS_NONCONCURRENT VARCHAR(1) NOT NULL,
-  IS_UPDATE_DATA VARCHAR(1) NOT NULL,
-  REQUESTS_RECOVERY VARCHAR(1) NOT NULL,
-  JOB_DATA BLOB NULL,
-  PRIMARY KEY (SCHED_NAME,JOB_NAME,JOB_GROUP))
-  ENGINE=InnoDB;
-
-CREATE TABLE QRTZ_TRIGGERS (
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  TRIGGER_NAME VARCHAR(200) NOT NULL,
-  TRIGGER_GROUP VARCHAR(200) NOT NULL,
-  JOB_NAME VARCHAR(200) NOT NULL,
-  JOB_GROUP VARCHAR(200) NOT NULL,
-  DESCRIPTION VARCHAR(250) NULL,
-  NEXT_FIRE_TIME BIGINT(13) NULL,
-  PREV_FIRE_TIME BIGINT(13) NULL,
-  PRIORITY INTEGER NULL,
-  TRIGGER_STATE VARCHAR(16) NOT NULL,
-  TRIGGER_TYPE VARCHAR(8) NOT NULL,
-  START_TIME BIGINT(13) NOT NULL,
-  END_TIME BIGINT(13) NULL,
-  CALENDAR_NAME VARCHAR(200) NULL,
-  MISFIRE_INSTR SMALLINT(2) NULL,
-  JOB_DATA BLOB NULL,
-  PRIMARY KEY (SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP),
-  FOREIGN KEY (SCHED_NAME,JOB_NAME,JOB_GROUP)
-  REFERENCES QRTZ_JOB_DETAILS(SCHED_NAME,JOB_NAME,JOB_GROUP))
-  ENGINE=InnoDB;
-
-CREATE TABLE QRTZ_SIMPLE_TRIGGERS (
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  TRIGGER_NAME VARCHAR(200) NOT NULL,
-  TRIGGER_GROUP VARCHAR(200) NOT NULL,
-  REPEAT_COUNT BIGINT(7) NOT NULL,
-  REPEAT_INTERVAL BIGINT(12) NOT NULL,
-  TIMES_TRIGGERED BIGINT(10) NOT NULL,
-  PRIMARY KEY (SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP),
-  FOREIGN KEY (SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP)
-  REFERENCES QRTZ_TRIGGERS(SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP))
-  ENGINE=InnoDB;
-
-CREATE TABLE QRTZ_CRON_TRIGGERS (
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  TRIGGER_NAME VARCHAR(200) NOT NULL,
-  TRIGGER_GROUP VARCHAR(200) NOT NULL,
-  CRON_EXPRESSION VARCHAR(120) NOT NULL,
-  TIME_ZONE_ID VARCHAR(80),
-  PRIMARY KEY (SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP),
-  FOREIGN KEY (SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP)
-  REFERENCES QRTZ_TRIGGERS(SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP))
-  ENGINE=InnoDB;
-
-CREATE TABLE QRTZ_SIMPROP_TRIGGERS
-(
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  TRIGGER_NAME VARCHAR(200) NOT NULL,
-  TRIGGER_GROUP VARCHAR(200) NOT NULL,
-  STR_PROP_1 VARCHAR(512) NULL,
-  STR_PROP_2 VARCHAR(512) NULL,
-  STR_PROP_3 VARCHAR(512) NULL,
-  INT_PROP_1 INT NULL,
-  INT_PROP_2 INT NULL,
-  LONG_PROP_1 BIGINT NULL,
-  LONG_PROP_2 BIGINT NULL,
-  DEC_PROP_1 NUMERIC(13,4) NULL,
-  DEC_PROP_2 NUMERIC(13,4) NULL,
-  BOOL_PROP_1 VARCHAR(1) NULL,
-  BOOL_PROP_2 VARCHAR(1) NULL,
-  PRIMARY KEY (SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP),
-  FOREIGN KEY (SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP)
-  REFERENCES QRTZ_TRIGGERS(SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP))
-  ENGINE=InnoDB;
-
-CREATE TABLE QRTZ_BLOB_TRIGGERS (
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  TRIGGER_NAME VARCHAR(200) NOT NULL,
-  TRIGGER_GROUP VARCHAR(200) NOT NULL,
-  BLOB_DATA BLOB NULL,
-  PRIMARY KEY (SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP),
-  INDEX (SCHED_NAME,TRIGGER_NAME, TRIGGER_GROUP),
-  FOREIGN KEY (SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP)
-  REFERENCES QRTZ_TRIGGERS(SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP))
-  ENGINE=InnoDB;
-
-CREATE TABLE QRTZ_CALENDARS (
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  CALENDAR_NAME VARCHAR(200) NOT NULL,
-  CALENDAR BLOB NOT NULL,
-  PRIMARY KEY (SCHED_NAME,CALENDAR_NAME))
-  ENGINE=InnoDB;
-
-CREATE TABLE QRTZ_PAUSED_TRIGGER_GRPS (
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  TRIGGER_GROUP VARCHAR(200) NOT NULL,
-  PRIMARY KEY (SCHED_NAME,TRIGGER_GROUP))
-  ENGINE=InnoDB;
-
-CREATE TABLE QRTZ_FIRED_TRIGGERS (
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  ENTRY_ID VARCHAR(95) NOT NULL,
-  TRIGGER_NAME VARCHAR(200) NOT NULL,
-  TRIGGER_GROUP VARCHAR(200) NOT NULL,
-  INSTANCE_NAME VARCHAR(200) NOT NULL,
-  FIRED_TIME BIGINT(13) NOT NULL,
-  SCHED_TIME BIGINT(13) NOT NULL,
-  PRIORITY INTEGER NOT NULL,
-  STATE VARCHAR(16) NOT NULL,
-  JOB_NAME VARCHAR(200) NULL,
-  JOB_GROUP VARCHAR(200) NULL,
-  IS_NONCONCURRENT VARCHAR(1) NULL,
-  REQUESTS_RECOVERY VARCHAR(1) NULL,
-  PRIMARY KEY (SCHED_NAME,ENTRY_ID))
-  ENGINE=InnoDB;
-
-CREATE TABLE QRTZ_SCHEDULER_STATE (
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  INSTANCE_NAME VARCHAR(200) NOT NULL,
-  LAST_CHECKIN_TIME BIGINT(13) NOT NULL,
-  CHECKIN_INTERVAL BIGINT(13) NOT NULL,
-  PRIMARY KEY (SCHED_NAME,INSTANCE_NAME))
-  ENGINE=InnoDB;
-
-CREATE TABLE QRTZ_LOCKS (
-  SCHED_NAME VARCHAR(120) NOT NULL,
-  LOCK_NAME VARCHAR(40) NOT NULL,
-  PRIMARY KEY (SCHED_NAME,LOCK_NAME))
-  ENGINE=InnoDB;
-
-CREATE INDEX IDX_QRTZ_J_REQ_RECOVERY ON QRTZ_JOB_DETAILS(SCHED_NAME,REQUESTS_RECOVERY);
-CREATE INDEX IDX_QRTZ_J_GRP ON QRTZ_JOB_DETAILS(SCHED_NAME,JOB_GROUP);
-
-CREATE INDEX IDX_QRTZ_T_J ON QRTZ_TRIGGERS(SCHED_NAME,JOB_NAME,JOB_GROUP);
-CREATE INDEX IDX_QRTZ_T_JG ON QRTZ_TRIGGERS(SCHED_NAME,JOB_GROUP);
-CREATE INDEX IDX_QRTZ_T_C ON QRTZ_TRIGGERS(SCHED_NAME,CALENDAR_NAME);
-CREATE INDEX IDX_QRTZ_T_G ON QRTZ_TRIGGERS(SCHED_NAME,TRIGGER_GROUP);
-CREATE INDEX IDX_QRTZ_T_STATE ON QRTZ_TRIGGERS(SCHED_NAME,TRIGGER_STATE);
-CREATE INDEX IDX_QRTZ_T_N_STATE ON QRTZ_TRIGGERS(SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP,TRIGGER_STATE);
-CREATE INDEX IDX_QRTZ_T_N_G_STATE ON QRTZ_TRIGGERS(SCHED_NAME,TRIGGER_GROUP,TRIGGER_STATE);
-CREATE INDEX IDX_QRTZ_T_NEXT_FIRE_TIME ON QRTZ_TRIGGERS(SCHED_NAME,NEXT_FIRE_TIME);
-CREATE INDEX IDX_QRTZ_T_NFT_ST ON QRTZ_TRIGGERS(SCHED_NAME,TRIGGER_STATE,NEXT_FIRE_TIME);
-CREATE INDEX IDX_QRTZ_T_NFT_MISFIRE ON QRTZ_TRIGGERS(SCHED_NAME,MISFIRE_INSTR,NEXT_FIRE_TIME);
-CREATE INDEX IDX_QRTZ_T_NFT_ST_MISFIRE ON QRTZ_TRIGGERS(SCHED_NAME,MISFIRE_INSTR,NEXT_FIRE_TIME,TRIGGER_STATE);
-CREATE INDEX IDX_QRTZ_T_NFT_ST_MISFIRE_GRP ON QRTZ_TRIGGERS(SCHED_NAME,MISFIRE_INSTR,NEXT_FIRE_TIME,TRIGGER_GROUP,TRIGGER_STATE);
-
-CREATE INDEX IDX_QRTZ_FT_TRIG_INST_NAME ON QRTZ_FIRED_TRIGGERS(SCHED_NAME,INSTANCE_NAME);
-CREATE INDEX IDX_QRTZ_FT_INST_JOB_REQ_RCVRY ON QRTZ_FIRED_TRIGGERS(SCHED_NAME,INSTANCE_NAME,REQUESTS_RECOVERY);
-CREATE INDEX IDX_QRTZ_FT_J_G ON QRTZ_FIRED_TRIGGERS(SCHED_NAME,JOB_NAME,JOB_GROUP);
-CREATE INDEX IDX_QRTZ_FT_JG ON QRTZ_FIRED_TRIGGERS(SCHED_NAME,JOB_GROUP);
-CREATE INDEX IDX_QRTZ_FT_T_G ON QRTZ_FIRED_TRIGGERS(SCHED_NAME,TRIGGER_NAME,TRIGGER_GROUP);
-CREATE INDEX IDX_QRTZ_FT_TG ON QRTZ_FIRED_TRIGGERS(SCHED_NAME,TRIGGER_GROUP);
-
-commit;
-

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/spark/slaves
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/spark/slaves b/docker/griffin_env/conf/spark/slaves
deleted file mode 100644
index e13d73d..0000000
--- a/docker/griffin_env/conf/spark/slaves
+++ /dev/null
@@ -1,19 +0,0 @@
-#
-# 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.
-#
-
-# A Spark Worker will be started on each of the machines listed below.
-localhost

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/spark/spark-defaults.conf
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/spark/spark-defaults.conf b/docker/griffin_env/conf/spark/spark-defaults.conf
deleted file mode 100644
index d89a2f0..0000000
--- a/docker/griffin_env/conf/spark/spark-defaults.conf
+++ /dev/null
@@ -1,32 +0,0 @@
-#
-# 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.
-#
-
-# Default system properties included when running spark-submit.
-# This is useful for setting default environmental settings.
-
-# Example:
-# spark.master                     spark://master:7077
-# spark.eventLog.enabled           true
-# spark.eventLog.dir               hdfs://namenode:8021/directory
-# spark.serializer                 org.apache.spark.serializer.KryoSerializer
-# spark.driver.memory              5g
-# spark.executor.extraJavaOptions  -XX:+PrintGCDetails -Dkey=value -Dnumbers="one two three"
-
-#spark.master                    spark://10.9.246.187:7077
-spark.master                    yarn-cluster
-spark.serializer                org.apache.spark.serializer.KryoSerializer
-spark.yarn.jar			hdfs:///home/spark_lib/spark-assembly-1.6.0-hadoop2.6.0.jar

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/spark/spark-env.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/spark/spark-env.sh b/docker/griffin_env/conf/spark/spark-env.sh
deleted file mode 100755
index 46de554..0000000
--- a/docker/griffin_env/conf/spark/spark-env.sh
+++ /dev/null
@@ -1,75 +0,0 @@
-#!/usr/bin/env bash
-
-#
-# 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.
-#
-
-# This file is sourced when running various Spark programs.
-# Copy it as spark-env.sh and edit that to configure Spark for your site.
-
-# Options read when launching programs locally with
-# ./bin/run-example or ./bin/spark-submit
-# - HADOOP_CONF_DIR, to point Spark towards Hadoop configuration files
-# - SPARK_LOCAL_IP, to set the IP address Spark binds to on this node
-# - SPARK_PUBLIC_DNS, to set the public dns name of the driver program
-# - SPARK_CLASSPATH, default classpath entries to append
-
-# Options read by executors and drivers running inside the cluster
-# - SPARK_LOCAL_IP, to set the IP address Spark binds to on this node
-# - SPARK_PUBLIC_DNS, to set the public DNS name of the driver program
-# - SPARK_CLASSPATH, default classpath entries to append
-# - SPARK_LOCAL_DIRS, storage directories to use on this node for shuffle and RDD data
-# - MESOS_NATIVE_JAVA_LIBRARY, to point to your libmesos.so if you use Mesos
-
-# Options read in YARN client mode
-# - HADOOP_CONF_DIR, to point Spark towards Hadoop configuration files
-# - SPARK_EXECUTOR_INSTANCES, Number of executors to start (Default: 2)
-# - SPARK_EXECUTOR_CORES, Number of cores for the executors (Default: 1).
-# - SPARK_EXECUTOR_MEMORY, Memory per Executor (e.g. 1000M, 2G) (Default: 1G)
-# - SPARK_DRIVER_MEMORY, Memory for Driver (e.g. 1000M, 2G) (Default: 1G)
-# - SPARK_YARN_APP_NAME, The name of your application (Default: Spark)
-# - SPARK_YARN_QUEUE, The hadoop queue to use for allocation requests (Default: ‘default’)
-# - SPARK_YARN_DIST_FILES, Comma separated list of files to be distributed with the job.
-# - SPARK_YARN_DIST_ARCHIVES, Comma separated list of archives to be distributed with the job.
-
-# Options for the daemons used in the standalone deploy mode
-# - SPARK_MASTER_IP, to bind the master to a different IP address or hostname
-# - SPARK_MASTER_PORT / SPARK_MASTER_WEBUI_PORT, to use non-default ports for the master
-# - SPARK_MASTER_OPTS, to set config properties only for the master (e.g. "-Dx=y")
-# - SPARK_WORKER_CORES, to set the number of cores to use on this machine
-# - SPARK_WORKER_MEMORY, to set how much total memory workers have to give executors (e.g. 1000m, 2g)
-# - SPARK_WORKER_PORT / SPARK_WORKER_WEBUI_PORT, to use non-default ports for the worker
-# - SPARK_WORKER_INSTANCES, to set the number of worker processes per node
-# - SPARK_WORKER_DIR, to set the working directory of worker processes
-# - SPARK_WORKER_OPTS, to set config properties only for the worker (e.g. "-Dx=y")
-# - SPARK_DAEMON_MEMORY, to allocate to the master, worker and history server themselves (default: 1g).
-# - SPARK_HISTORY_OPTS, to set config properties only for the history server (e.g. "-Dx=y")
-# - SPARK_SHUFFLE_OPTS, to set config properties only for the external shuffle service (e.g. "-Dx=y")
-# - SPARK_DAEMON_JAVA_OPTS, to set config properties for all daemons (e.g. "-Dx=y")
-# - SPARK_PUBLIC_DNS, to set the public dns name of the master or workers
-
-# Generic options for the daemons used in the standalone deploy mode
-# - SPARK_CONF_DIR      Alternate conf dir. (Default: ${SPARK_HOME}/conf)
-# - SPARK_LOG_DIR       Where log files are stored.  (Default: ${SPARK_HOME}/logs)
-# - SPARK_PID_DIR       Where the pid file is stored. (Default: /tmp)
-# - SPARK_IDENT_STRING  A string representing this instance of spark. (Default: $USER)
-# - SPARK_NICENESS      The scheduling priority for daemons. (Default: 0)
-
-JAVA_HOME=/apache/jdk
-SPARK_JAVA_OPTS=-Dspark.driver.port=53411
-HADOOP_CONF_DIR=$HADOOP_HOME/etc/hadoop
-SPARK_MASTER_IP=localhost
-SPARK_MASTER_WEBUI_PORT=8082

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/prep/dir.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_env/prep/dir.sh b/docker/griffin_env/prep/dir.sh
deleted file mode 100755
index cf81f15..0000000
--- a/docker/griffin_env/prep/dir.sh
+++ /dev/null
@@ -1,32 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-mkdir /data
-chmod 777 /data
-mkdir -p /data/hadoop-data/nn
-mkdir -p /data/hadoop-data/snn
-mkdir -p /data/hadoop-data/dn
-mkdir -p /data/hadoop-data/tmp
-mkdir -p /data/hadoop-data/mapred/system
-mkdir -p /data/hadoop-data/mapred/local
-
-mkdir -p /tmp/logs
-chmod 777 /tmp/logs
-
-#elasticsearch
-mkdir /data/elasticsearch
-chmod 777 /data/elasticsearch

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/prep/hdfs_file.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_env/prep/hdfs_file.sh b/docker/griffin_env/prep/hdfs_file.sh
deleted file mode 100755
index bf8c549..0000000
--- a/docker/griffin_env/prep/hdfs_file.sh
+++ /dev/null
@@ -1,45 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-# spark dir
-hadoop fs -mkdir -p /home/spark_lib
-hadoop fs -put $SPARK_HOME/lib/spark-assembly-1.6.0-hadoop2.6.0.jar /home/spark_lib/
-hadoop fs -chmod 755 /home/spark_lib/spark-assembly-1.6.0-hadoop2.6.0.jar
-
-# yarn dir
-hadoop fs -mkdir -p /yarn-logs/logs
-hadoop fs -chmod g+w /yarn-logs/logs
-
-# hive dir
-hadoop fs -mkdir /tmp
-hadoop fs -mkdir /user
-hadoop fs -mkdir /user/hive
-hadoop fs -mkdir /user/hive/warehouse
-hadoop fs -chmod g+w /tmp
-hadoop fs -chmod g+w /user/hive/warehouse
-
-# livy dir
-hadoop fs -mkdir /livy
-
-wget http://central.maven.org/maven2/org/datanucleus/datanucleus-rdbms/3.2.9/datanucleus-rdbms-3.2.9.jar -O /apache/datanucleus-rdbms-3.2.9.jar
-wget http://central.maven.org/maven2/org/datanucleus/datanucleus-core/3.2.10/datanucleus-core-3.2.10.jar -O /apache/datanucleus-core-3.2.10.jar
-wget http://central.maven.org/maven2/org/datanucleus/datanucleus-api-jdo/3.2.6/datanucleus-api-jdo-3.2.6.jar -O /apache/datanucleus-api-jdo-3.2.6.jar
-
-hadoop fs -put /apache/datanucleus-rdbms-3.2.9.jar /livy/
-hadoop fs -put /apache/datanucleus-core-3.2.10.jar /livy/
-hadoop fs -put /apache/datanucleus-api-jdo-3.2.6.jar /livy/

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/prep/software-config.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_env/prep/software-config.sh b/docker/griffin_env/prep/software-config.sh
deleted file mode 100755
index 79af32a..0000000
--- a/docker/griffin_env/prep/software-config.sh
+++ /dev/null
@@ -1,51 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-# java 8
-
-# hadoop
-
-cp conf/hadoop/* hadoop/etc/hadoop/
-sed s/HOSTNAME/localhost/ hadoop/etc/hadoop/core-site.xml.template > hadoop/etc/hadoop/core-site.xml
-sed s/HOSTNAME/localhost/ hadoop/etc/hadoop/yarn-site.xml.template > hadoop/etc/hadoop/yarn-site.xml
-sed s/HOSTNAME/localhost/ hadoop/etc/hadoop/mapred-site.xml.template > hadoop/etc/hadoop/mapred-site.xml
-
-chmod 755 hadoop/etc/hadoop/hadoop-env.sh
-
-# scala
-
-# spark
-
-cp conf/spark/* spark/conf/
-
-# hive
-
-cp conf/hive/* hive/conf/
-sed s/HOSTNAME/localhost/ hive/conf/hive-site.xml.template > hive/conf/hive-site.xml
-echo "export HADOOP_HOME=/apache/hadoop" >> hive/bin/hive-config.sh
-
-# livy
-
-cp conf/livy/* livy/conf/
-mkdir livy/logs
-
-# elasticsearch
-
-cp conf/elasticsearch/elasticsearch.yml /etc/elasticsearch/
-cp conf/elasticsearch/elasticsearch /etc/init.d/
-chmod 755 /etc/init.d/elasticsearch

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/prep/software-install.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_env/prep/software-install.sh b/docker/griffin_env/prep/software-install.sh
deleted file mode 100755
index 801ca87..0000000
--- a/docker/griffin_env/prep/software-install.sh
+++ /dev/null
@@ -1,54 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-# java 8
-wget --no-cookies --no-check-certificate --header "Cookie: oraclelicense=accept-securebackup-cookie" \
-http://download.oracle.com/otn-pub/java/jdk/8u131-b11/d54c1d3a095b4ff2b6607d096fa80163/jdk-8u131-linux-x64.tar.gz \
--O jdk8-linux-x64.tar.gz
-tar -xvzf jdk8-linux-x64.tar.gz
-ln -s jdk1.8.0_131 jdk
-
-# hadoop
-wget http://mirror.cogentco.com/pub/apache/hadoop/common/hadoop-2.6.5/hadoop-2.6.5.tar.gz
-tar -xvf hadoop-2.6.5.tar.gz
-ln -s hadoop-2.6.5 hadoop
-
-# scala
-wget http://downloads.lightbend.com/scala/2.10.6/scala-2.10.6.tgz
-tar -xvf scala-2.10.6.tgz
-ln -s scala-2.10.6 scala
-
-# spark
-wget http://archive.apache.org/dist/spark/spark-1.6.0/spark-1.6.0-bin-hadoop2.6.tgz
-tar -xvf spark-1.6.0-bin-hadoop2.6.tgz
-ln -s spark-1.6.0-bin-hadoop2.6 spark
-
-# hive
-wget https://www.apache.org/dist/hive/hive-1.2.2/apache-hive-1.2.2-bin.tar.gz
-tar -xvf apache-hive-1.2.2-bin.tar.gz
-ln -s apache-hive-1.2.2-bin hive
-
-# livy
-wget http://archive.cloudera.com/beta/livy/livy-server-0.3.0.zip
-unzip livy-server-0.3.0.zip
-ln -s livy-server-0.3.0 livy
-
-#elasticsearch
-wget https://artifacts.elastic.co/downloads/elasticsearch/elasticsearch-5.4.0.deb
-dpkg -i elasticsearch-5.4.0.deb
-update-rc.d elasticsearch defaults

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/ssh_config
----------------------------------------------------------------------
diff --git a/docker/griffin_env/ssh_config b/docker/griffin_env/ssh_config
deleted file mode 100644
index 4af9f9b..0000000
--- a/docker/griffin_env/ssh_config
+++ /dev/null
@@ -1,22 +0,0 @@
-
-# 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.
-
-
-Host *
-  UserKnownHostsFile /dev/null
-  StrictHostKeyChecking no
-  LogLevel quiet
-  Port 2122

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/griffin-doc/hive/json/accu_config.json
----------------------------------------------------------------------
diff --git a/griffin-doc/hive/json/accu_config.json b/griffin-doc/hive/json/accu_config.json
deleted file mode 100644
index f18989b..0000000
--- a/griffin-doc/hive/json/accu_config.json
+++ /dev/null
@@ -1,62 +0,0 @@
-{
-  "source": "users_info_src",
-  "target": "users_info_target",
-  "accuracyMapping": [
-    {
-      "sourceColId": 0,
-      "sourceColName": "user_id",
-      "targetColId": 0,
-      "targetColName": "user_id",
-      "matchFunction": "true",
-      "isPK": true
-    },
-    {
-      "sourceColId": 1,
-      "sourceColName": "first_name",
-      "targetColId": 1,
-      "targetColName": "first_name",
-      "matchFunction": "false",
-      "isPK": false
-    },
-    {
-      "sourceColId": 2,
-      "sourceColName": "last_name",
-      "targetColId": 2,
-      "targetColName": "last_name",
-      "matchFunction": "false",
-      "isPK": false
-    },
-    {
-      "sourceColId": 3,
-      "sourceColName": "address",
-      "targetColId": 3,
-      "targetColName": "address",
-      "matchFunction": "false",
-      "isPK": false
-    },
-    {
-      "sourceColId": 4,
-      "sourceColName": "email",
-      "targetColId": 4,
-      "targetColName": "email",
-      "matchFunction": "false",
-      "isPK": false
-    },
-    {
-      "sourceColId": 5,
-      "sourceColName": "phone",
-      "targetColId": 5,
-      "targetColName": "phone",
-      "matchFunction": "false",
-      "isPK": false
-    },
-    {
-      "sourceColId": 6,
-      "sourceColName": "post_code",
-      "targetColId": 6,
-      "targetColName": "post_code",
-      "matchFunction": "false",
-      "isPK": false
-    }
-  ]
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/griffin-doc/hive/json/vali_config.json
----------------------------------------------------------------------
diff --git a/griffin-doc/hive/json/vali_config.json b/griffin-doc/hive/json/vali_config.json
deleted file mode 100644
index a07c4cd..0000000
--- a/griffin-doc/hive/json/vali_config.json
+++ /dev/null
@@ -1,131 +0,0 @@
-{
-	"dataSet": "users_info_src",
-	"validityReq": [
-		{
-			"colId": 0,
-			"colName": "user_id",
-			"metrics": [
-				{
-					"name": 1
-				},
-				{
-					"name": 2
-				},
-				{
-					"name": 3
-				},
-				{
-					"name": 4
-				}
-			]
-		},
-		{
-			"colId": 1,
-			"colName": "first_name",
-			"metrics": [
-				{
-					"name": 1
-				},
-				{
-					"name": 2
-				},
-				{
-					"name": 3
-				},
-				{
-					"name": 4
-				}
-			]
-		},
-		{
-			"colId": 2,
-			"colName": "last_name",
-			"metrics": [
-				{
-					"name": 1
-				},
-				{
-					"name": 2
-				},
-				{
-					"name": 3
-				},
-				{
-					"name": 4
-				}
-			]
-		},
-		{
-			"colId": 3,
-			"colName": "address",
-			"metrics": [
-				{
-					"name": 1
-				},
-				{
-					"name": 2
-				},
-				{
-					"name": 3
-				},
-				{
-					"name": 4
-				}
-			]
-		},
-		{
-			"colId": 4,
-			"colName": "email",
-			"metrics": [
-				{
-					"name": 1
-				},
-				{
-					"name": 2
-				},
-				{
-					"name": 3
-				},
-				{
-					"name": 4
-				}
-			]
-		},
-		{
-			"colId": 5,
-			"colName": "phone",
-			"metrics": [
-				{
-					"name": 1
-				},
-				{
-					"name": 2
-				},
-				{
-					"name": 3
-				},
-				{
-					"name": 4
-				}
-			]
-		},
-		{
-			"colId": 6,
-			"colName": "post_code",
-			"metrics": [
-				{
-					"name": 1
-				},
-				{
-					"name": 2
-				},
-				{
-					"name": 3
-				},
-				{
-					"name": 4
-				}
-			]
-		}
-	]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/griffin-doc/hive/script/bark_jobs.sh
----------------------------------------------------------------------
diff --git a/griffin-doc/hive/script/bark_jobs.sh b/griffin-doc/hive/script/bark_jobs.sh
deleted file mode 100644
index 01c3b38..0000000
--- a/griffin-doc/hive/script/bark_jobs.sh
+++ /dev/null
@@ -1,86 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-ROOT_DIR=$(cd $(dirname $0); pwd)
-if [ -f $ROOT_DIR/env.sh ]; then
-  . $ROOT_DIR/env.sh
-fi
-
-HDFS_WORKDIR=${HDFS_WORKDIR:-/user/bark/running}
-TEMP_DIR=${TEMP_DIR:-$ROOT_DIR/temp}
-LOG_DIR=${LOG_DIR:-$ROOT_DIR/log}
-
-mkdir -p $TEMP_DIR
-mkdir -p $LOG_DIR
-
-lv1tempfile=$TEMP_DIR/temp.txt
-lv2tempfile=$TEMP_DIR/temp2.txt
-logfile=$LOG_DIR/log.txt
-
-set +e
-
-hadoop fs -ls $HDFS_WORKDIR > $lv1tempfile
-
-rm -rf $logfile
-touch $logfile
-
-while read line
-do
-  lv1dir=${line##* }
-  echo $lv1dir
-  hadoop fs -test -f $lv1dir/_START
-  if [ $? -ne 0 ] && [ "${lv1dir:0:1}" == "/" ]
-  then
-    hadoop fs -cat $lv1dir/_watchfile > $lv2tempfile
-
-    watchfiledone=1
-    while read watchline
-    do
-      echo $watchline >> $logfile
-      hadoop fs -test -f $watchline/_SUCCESS
-      if [ $? -ne 0 ]
-      then
-        watchfiledone=0
-      fi
-    done < $lv2tempfile
-
-    if [ $watchfiledone -eq 1 ]
-    then
-      hadoop fs -touchz $lv1dir/_START
-      hadoop fs -test -f $lv1dir/_type_0.done
-      rc1=$?
-      hadoop fs -test -f $lv1dir/_type_1.done
-      rc2=$?
-      if [ $rc1 -eq 0 ]
-      then
-        echo "spark-submit --class com.ebay.bark.Accu33 --master yarn-client --queue default --executor-memory 512m --num-executors 10 accuracy-1.0-SNAPSHOT.jar  $lv1dir/cmd.txt $lv1dir/ "
-        spark-submit --class com.ebay.bark.Accu33 --master yarn-client --queue default --executor-memory 512m --num-executors 10 bark-models-0.0.1-SNAPSHOT.jar  $lv1dir/cmd.txt $lv1dir/
-      elif [ $rc2 -eq 0 ]
-      then
-        echo "spark-submit --class com.ebay.bark.Vali3 --master yarn-client --queue default --executor-memory 512m --num-executors 10 accuracy-1.0-SNAPSHOT.jar  $lv1dir/cmd.txt $lv1dir/ "
-        spark-submit --class com.ebay.bark.Vali3 --master yarn-client --queue default --executor-memory 512m --num-executors 10 bark-models-0.0.1-SNAPSHOT.jar  $lv1dir/cmd.txt $lv1dir/
-      fi
-
-      echo "watch file ready" >> $logfile
-      exit
-    fi
-  fi
-
-done < $lv1tempfile
-
-set -e
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/griffin-doc/hive/script/bark_regular_run.sh
----------------------------------------------------------------------
diff --git a/griffin-doc/hive/script/bark_regular_run.sh b/griffin-doc/hive/script/bark_regular_run.sh
deleted file mode 100644
index 8497761..0000000
--- a/griffin-doc/hive/script/bark_regular_run.sh
+++ /dev/null
@@ -1,30 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-ROOT_DIR=$(cd $(dirname $0); pwd)
-
-set +e
-while true
-do
-  echo "start"
-  $ROOT_DIR/bark_jobs.sh 2>&1
-  rcode=$?
-  echo "end $rcode"
-  rm -rf $ROOT_DIR/nohup.out
-  sleep 60
-done
-set -e
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/griffin-doc/hive/script/env.sh
----------------------------------------------------------------------
diff --git a/griffin-doc/hive/script/env.sh b/griffin-doc/hive/script/env.sh
deleted file mode 100644
index 4d6af55..0000000
--- a/griffin-doc/hive/script/env.sh
+++ /dev/null
@@ -1,19 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-HDFS_WORKDIR=/user/bark/running
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/griffin-doc/hive/users_info_src.dat
----------------------------------------------------------------------
diff --git a/griffin-doc/hive/users_info_src.dat b/griffin-doc/hive/users_info_src.dat
deleted file mode 100644
index ce49443..0000000
--- a/griffin-doc/hive/users_info_src.dat
+++ /dev/null
@@ -1,50 +0,0 @@
-10001|Tom001|Jerrya|201 DisneyCity|tomajerrya001@dc.org|10000001|94022
-10002|Tom002|Jerrya|202 DisneyCity|tomajerrya002@dc.org|10000002|94022
-10003|Tom003|Jerrya|203 DisneyCity|tomajerrya003@dc.org|10000003|94022
-10004|Tom004|Jerrya|204 DisneyCity|tomajerrya004@dc.org|10000004|94022
-10005|Tom005|Jerrya|205 DisneyCity|tomajerrya005@dc.org|10000005|94022
-10006|Tom006|Jerrya|206 DisneyCity|tomajerrya006@dc.org|10000006|94022
-10007|Tom007|Jerrya|207 DisneyCity|tomajerrya007@dc.org|10000007|94022
-10008|Tom008|Jerrya|208 DisneyCity|tomajerrya008@dc.org|10000008|94022
-10009|Tom009|Jerrya|209 DisneyCity|tomajerrya009@dc.org|10000009|94022
-10010|Tom010|Jerrya|210 DisneyCity|tomajerrya010@dc.org|10000010|94022
-10011|Tom011|Jerrya|211 DisneyCity|tomajerrya011@dc.org|10000011|94022
-10012|Tom012|Jerrya|212 DisneyCity|tomajerrya012@dc.org|10000012|94022
-10013|Tom013|Jerrya|213 DisneyCity|tomajerrya013@dc.org|10000013|94022
-10014|Tom014|Jerrya|214 DisneyCity|tomajerrya014@dc.org|10000014|94022
-10015|Tom015|Jerrya|215 DisneyCity|tomajerrya015@dc.org|10000015|94022
-10016|Tom016|Jerrya|216 DisneyCity|tomajerrya016@dc.org|10000016|94022
-10017|Tom017|Jerrya|217 DisneyCity|tomajerrya017@dc.org|10000017|94022
-10018|Tom018|Jerrya|218 DisneyCity|tomajerrya018@dc.org|10000018|94022
-10019|Tom019|Jerrya|219 DisneyCity|tomajerrya019@dc.org|10000019|94022
-10020|Tom020|Jerrya|220 DisneyCity|tomajerrya020@dc.org|10000020|94022
-10021|Tom021|Jerrya|221 DisneyCity|tomajerrya021@dc.org|10000021|94022
-10022|Tom022|Jerrya|222 DisneyCity|tomajerrya022@dc.org|10000022|94022
-10023|Tom023|Jerrya|223 DisneyCity|tomajerrya023@dc.org|10000023|94022
-10024|Tom024|Jerrya|224 DisneyCity|tomajerrya024@dc.org|10000024|94022
-10025|Tom025|Jerrya|225 DisneyCity|tomajerrya025@dc.org|10000025|94022
-10026|Tom026|Jerrya|226 DisneyCity|tomajerrya026@dc.org|10000026|94022
-10027|Tom027|Jerrya|227 DisneyCity|tomajerrya027@dc.org|10000027|94022
-10028|Tom028|Jerrya|228 DisneyCity|tomajerrya028@dc.org|10000028|94022
-10029|Tom029|Jerrya|229 DisneyCity|tomajerrya029@dc.org|10000029|94022
-10030|Tom030|Jerrya|230 DisneyCity|tomajerrya030@dc.org|10000030|94022
-10031|Tom031|Jerrya|231 DisneyCity|tomajerrya031@dc.org|10000031|94022
-10032|Tom032|Jerrya|232 DisneyCity|tomajerrya032@dc.org|10000032|94022
-10033|Tom033|Jerrya|233 DisneyCity|tomajerrya033@dc.org|10000033|94022
-10034|Tom034|Jerrya|234 DisneyCity|tomajerrya034@dc.org|10000034|94022
-10035|Tom035|Jerrya|235 DisneyCity|tomajerrya035@dc.org|10000035|94022
-10036|Tom036|Jerrya|236 DisneyCity|tomajerrya036@dc.org|10000036|94022
-10037|Tom037|Jerrya|237 DisneyCity|tomajerrya037@dc.org|10000037|94022
-10038|Tom038|Jerrya|238 DisneyCity|tomajerrya038@dc.org|10000038|94022
-10039|Tom039|Jerrya|239 DisneyCity|tomajerrya039@dc.org|10000039|94022
-10040|Tom040|Jerrya|240 DisneyCity|tomajerrya040@dc.org|10000040|94022
-10041|Tom041|Jerrya|241 DisneyCity|tomajerrya041@dc.org|10000041|94022
-10042|Tom042|Jerrya|242 DisneyCity|tomajerrya042@dc.org|10000042|94022
-10043|Tom043|Jerrya|243 DisneyCity|tomajerrya043@dc.org|10000043|94022
-10044|Tom044|Jerrya|244 DisneyCity|tomajerrya044@dc.org|10000044|94022
-10045|Tom045|Jerrya|245 DisneyCity|tomajerrya045@dc.org|10000045|94022
-10046|Tom046|Jerrya|246 DisneyCity|tomajerrya046@dc.org|10000046|94022
-10047|Tom047|Jerrya|247 DisneyCity|tomajerrya047@dc.org|10000047|94022
-10048|Tom048|Jerrya|248 DisneyCity|tomajerrya048@dc.org|10000048|94022
-10049|Tom049|Jerrya|249 DisneyCity|tomajerrya049@dc.org|10000049|94022
-10050|Tom050|Jerrya|250 DisneyCity|tomajerrya050@dc.org|10000050|94022
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/griffin-doc/hive/users_info_target.dat
----------------------------------------------------------------------
diff --git a/griffin-doc/hive/users_info_target.dat b/griffin-doc/hive/users_info_target.dat
deleted file mode 100644
index 07a6b40..0000000
--- a/griffin-doc/hive/users_info_target.dat
+++ /dev/null
@@ -1,50 +0,0 @@
-10001|Tom001|Jerrya|201 DisneyCity|tomajerrya001@dc.org|10000101|94022
-10002|Tom002|Jerrya|202 DisneyCity|tomajerrya002@dc.org|10000102|94022
-10003|Tom003|Jerrya|203 DisneyCity|tomajerrya003@dc.org|10000003|94022
-10004|Tom004|Jerrya|204 DisneyCity|tomajerrya004@dc.org|10000004|94022
-10005|Tom005|Jerrya|205 DisneyCity|tomajerrya005@dc.org|10000005|94022
-10006|Tom006|Jerrya|206 DisneyCity|tomajerrya006@dc.org|10000006|94022
-10007|Tom007|Jerrya|207 DisneyCity|tomajerrya007@dc.org|10000007|94022
-10008|Tom008|Jerrya|208 DisneyCity|tomajerrya008@dc.org|10000008|94022
-10009|Tom009|Jerrya|209 DisneyCity|tomajerrya009@dc.org|10000009|94022
-10010|Tom010|Jerrya|210 DisneyCity|tomajerrya010@dc.org|10000010|94022
-10011|Tom011|Jerrya|211 DisneyCity|tomajerrya011@dc.org|10000011|94022
-10012|Tom012|Jerrya|212 DisneyCity|tomajerrya012@dc.org|10000012|94022
-10013|Tom013|Jerrya|213 DisneyCity|tomajerrya013@dc.org|10000013|94022
-10014|Tom014|Jerrya|214 DisneyCity|tomajerrya014@dc.org|10000014|94022
-10015|Tom015|Jerrya|215 DisneyCity|tomajerrya015@dc.org|10000015|94022
-10016|Tom016|Jerrya|216 DisneyCity|tomajerrya016@dc.org|10000016|94022
-10017|Tom017|Jerrya|217 DisneyCity|tomajerrya017@dc.org|10000017|94022
-10018|Tom018|Jerrya|218 DisneyCity|tomajerrya018@dc.org|10000018|94022
-10019|Tom019|Jerrya|219 DisneyCity|tomajerrya019@dc.org|10000019|94022
-10020|Tom020|Jerrya|220 DisneyCity|tomajerrya020@dc.org|10000020|94022
-10021|Tom021|Jerrya|221 DisneyCity|tomajerrya021@dc.org|10000021|94022
-10022|Tom022|Jerrya|222 DisneyCity|tomajerrya022@dc.org|10000022|94022
-10023|Tom023|Jerrya|223 DisneyCity|tomajerrya023@dc.org|10000023|94022
-10024|Tom024|Jerrya|224 DisneyCity|tomajerrya024@dc.org|10000024|94022
-10025|Tom025|Jerrya|225 DisneyCity|tomajerrya025@dc.org|10000025|94022
-10026|Tom026|Jerrya|226 DisneyCity|tomajerrya026@dc.org|10000026|94022
-10027|Tom027|Jerrya|227 DisneyCity|tomajerrya027@dc.org|10000027|94022
-10028|Tom028|Jerrya|228 DisneyCity|tomajerrya028@dc.org|10000028|94022
-10029|Tom029|Jerrya|229 DisneyCity|tomajerrya029@dc.org|10000029|94022
-10030|Tom030|Jerrya|230 DisneyCity|tomajerrya030@dc.org|10000030|94022
-10031|Tom031|Jerrya|231 DisneyCity|tomajerrya031@dc.org|10000031|94022
-10032|Tom032|Jerrya|232 DisneyCity|tomajerrya032@dc.org|10000032|94022
-10033|Tom033|Jerrya|233 DisneyCity|tomajerrya033@dc.org|10000033|94022
-10034|Tom034|Jerrya|234 DisneyCity|tomajerrya034@dc.org|10000034|94022
-10035|Tom035|Jerrya|235 DisneyCity|tomajerrya035@dc.org|10000035|94022
-10036|Tom036|Jerrya|236 DisneyCity|tomajerrya036@dc.org|10000036|94022
-10037|Tom037|Jerrya|237 DisneyCity|tomajerrya037@dc.org|10000037|94022
-10038|Tom038|Jerrya|238 DisneyCity|tomajerrya038@dc.org|10000038|94022
-10039|Tom039|Jerrya|239 DisneyCity|tomajerrya039@dc.org|10000039|94022
-10040|Tom040|Jerrya|240 DisneyCity|tomajerrya040@dc.org|10000040|94022
-10041|Tom041|Jerrya|241 DisneyCity|tomajerrya041@dc.org|10000041|94022
-10042|Tom042|Jerrya|242 DisneyCity|tomajerrya042@dc.org|10000042|94022
-10043|Tom043|Jerrya|243 DisneyCity|tomajerrya043@dc.org|10000043|94022
-10044|Tom044|Jerrya|244 DisneyCity|tomajerrya044@dc.org|10000044|94022
-10045|Tom045|Jerrya|245 DisneyCity|tomajerrya045@dc.org|10000045|94022
-10046|Tom046|Jerrya|246 DisneyCity|tomajerrya046@dc.org|10000046|94022
-10047|Tom047|Jerrya|247 DisneyCity|tomajerrya047@dc.org|10000047|94022
-10048|Tom048|Jerrya|248 DisneyCity|tomajerrya048@dc.org|10000048|94022
-10049|Tom049|Jerrya|249 DisneyCity|tomajerrya049@dc.org|10000049|94022
-10050|Tom050|Jerrya|250 DisneyCity|tomajerrya050@dc.org|10000050|94022
\ No newline at end of file


[6/6] incubator-griffin git commit: remove stale docs

Posted by gu...@apache.org.
remove stale docs

Author: William Guo <gu...@icloud.com>

Closes #88 from guoyuepeng/20170626_remove_docker.


Project: http://git-wip-us.apache.org/repos/asf/incubator-griffin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-griffin/commit/e934c0d6
Tree: http://git-wip-us.apache.org/repos/asf/incubator-griffin/tree/e934c0d6
Diff: http://git-wip-us.apache.org/repos/asf/incubator-griffin/diff/e934c0d6

Branch: refs/heads/master
Commit: e934c0d69a7bfd8f498e96e29ab0e9d4cee2d7b5
Parents: c883cf8
Author: William Guo <gu...@icloud.com>
Authored: Mon Jun 26 14:04:26 2017 +0800
Committer: William Guo <gu...@icloud.com>
Committed: Mon Jun 26 14:04:26 2017 +0800

----------------------------------------------------------------------
 docker/griffin_demo/Dockerfile                  |     31 -
 docker/griffin_demo/bootstrap-all.sh            |     69 -
 docker/griffin_demo/prep/data/add-measure.sh    |     50 -
 docker/griffin_demo/prep/data/create-table.hql  |     40 -
 docker/griffin_demo/prep/data/demo_src          | 125000 ----------------
 docker/griffin_demo/prep/data/demo_tgt          | 125000 ----------------
 docker/griffin_demo/prep/data/gen-es-data.sh    |     79 -
 docker/griffin_demo/prep/data/gen-hive-data.sh  |     46 -
 docker/griffin_demo/prep/data/init-demo-data.sh |     22 -
 .../prep/data/insert-data.hql.template          |     18 -
 .../prep/jar/griffin-measure.jar.placeholder    |     15 -
 docker/griffin_demo/prep/job/config.json        |     27 -
 docker/griffin_demo/prep/job/env.json.template  |     27 -
 docker/griffin_demo/prep/prepare.sh             |     36 -
 .../config/application.properties.template      |     40 -
 .../prep/service/service.jar.placeholder        |      0
 docker/griffin_env/Dockerfile                   |     86 -
 docker/griffin_env/bootstrap-all.sh             |     56 -
 docker/griffin_env/bootstrap.sh                 |     41 -
 .../conf/elasticsearch/elasticsearch            |    223 -
 .../conf/elasticsearch/elasticsearch.yml        |     29 -
 .../conf/hadoop/core-site.xml.template          |     29 -
 docker/griffin_env/conf/hadoop/hadoop-env.sh    |     99 -
 docker/griffin_env/conf/hadoop/hdfs-site.xml    |     44 -
 .../conf/hadoop/mapred-site.xml.template        |     32 -
 docker/griffin_env/conf/hadoop/slaves           |      1 -
 .../conf/hadoop/yarn-site.xml.template          |     65 -
 .../conf/hive/hive-site.xml.template            |   3911 -
 docker/griffin_env/conf/livy/livy.conf          |     20 -
 docker/griffin_env/conf/mysql/bind_0.cnf        |     19 -
 .../conf/mysql/hive-metastore-init.sql          |     22 -
 docker/griffin_env/conf/mysql/mysql-init.sh     |     26 -
 .../conf/mysql/quartz-metastore-init.sql        |     22 -
 .../conf/mysql/quartz-table-init.sql            |    196 -
 docker/griffin_env/conf/spark/slaves            |     19 -
 .../griffin_env/conf/spark/spark-defaults.conf  |     32 -
 docker/griffin_env/conf/spark/spark-env.sh      |     75 -
 docker/griffin_env/prep/dir.sh                  |     32 -
 docker/griffin_env/prep/hdfs_file.sh            |     45 -
 docker/griffin_env/prep/software-config.sh      |     51 -
 docker/griffin_env/prep/software-install.sh     |     54 -
 docker/griffin_env/ssh_config                   |     22 -
 griffin-doc/hive/json/accu_config.json          |     62 -
 griffin-doc/hive/json/vali_config.json          |    131 -
 griffin-doc/hive/script/bark_jobs.sh            |     86 -
 griffin-doc/hive/script/bark_regular_run.sh     |     30 -
 griffin-doc/hive/script/env.sh                  |     19 -
 griffin-doc/hive/users_info_src.dat             |     50 -
 griffin-doc/hive/users_info_target.dat          |     50 -
 49 files changed, 256179 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/Dockerfile
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/Dockerfile b/docker/griffin_demo/Dockerfile
deleted file mode 100644
index 0cf4bd1..0000000
--- a/docker/griffin_demo/Dockerfile
+++ /dev/null
@@ -1,31 +0,0 @@
-# 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.
-
-
-FROM bhlx3lyx7/griffin_env:0.0.1
-MAINTAINER org.apache.griffin
-
-WORKDIR /root
-
-# files into hdfs
-ADD prep /root
-RUN chmod 755 prepare.sh
-RUN /etc/bootstrap.sh && ./prepare.sh
-
-# entrypoint
-ADD bootstrap-all.sh /etc/
-RUN chmod 755 /etc/bootstrap-all.sh
-
-ENTRYPOINT ["/etc/bootstrap-all.sh"]

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/bootstrap-all.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/bootstrap-all.sh b/docker/griffin_demo/bootstrap-all.sh
deleted file mode 100755
index 85c3c09..0000000
--- a/docker/griffin_demo/bootstrap-all.sh
+++ /dev/null
@@ -1,69 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-
-$HADOOP_HOME/etc/hadoop/hadoop-env.sh
-rm /tmp/*.pid
-
-cd $HADOOP_HOME/share/hadoop/common ; for cp in ${ACP//,/ }; do  echo == $cp; curl -LO $cp ; done; cd -
-
-service mysql start
-
-sed s/HOSTNAME/$HOSTNAME/ $HADOOP_HOME/etc/hadoop/core-site.xml.template > $HADOOP_HOME/etc/hadoop/core-site.xml
-sed s/HOSTNAME/$HOSTNAME/ $HADOOP_HOME/etc/hadoop/yarn-site.xml.template > $HADOOP_HOME/etc/hadoop/yarn-site.xml
-sed s/HOSTNAME/$HOSTNAME/ $HADOOP_HOME/etc/hadoop/mapred-site.xml.template > $HADOOP_HOME/etc/hadoop/mapred-site.xml
-
-sed s/HOSTNAME/$HOSTNAME/ $HIVE_HOME/conf/hive-site.xml.template > $HIVE_HOME/conf/hive-site.xml
-
-/etc/init.d/ssh start
-
-start-dfs.sh
-start-yarn.sh
-mr-jobhistory-daemon.sh start historyserver
-
-echo "$HADOOP_HOME/bin/hdfs dfsadmin -safemode wait"
-$HADOOP_HOME/bin/hdfs dfsadmin -safemode wait
-
-sed s/HOSTNAME/$HOSTNAME/ job/env.json.template > job/env.json
-hadoop fs -put job/env.json /griffin/json/
-
-hadoop fs -mkdir -p /home/spark_conf
-hadoop fs -put $HIVE_HOME/conf/hive-site.xml /home/spark_conf/
-echo "spark.yarn.dist.files		hdfs:///home/spark_conf/hive-site.xml" >> $SPARK_HOME/conf/spark-defaults.conf
-
-
-$SPARK_HOME/sbin/start-all.sh
-
-nohup hive --service metastore > metastore.log &
-
-nohup livy-server > livy.log &
-
-service elasticsearch start
-
-#griffin prepare
-cd /root/data
-nohup ./gen-hive-data.sh > hive-data.log &
-nohup ./init-demo-data.sh > init-data.log &
-cd /root
-
-sed s/HOSTNAME/$HOSTNAME/ /root/service/config/application.properties.template > /root/service/config/application.properties
-cd /root/service
-nohup java -jar service.jar > service.log &
-cd /root
-
-/bin/bash -c "bash"

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/data/add-measure.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/data/add-measure.sh b/docker/griffin_demo/prep/data/add-measure.sh
deleted file mode 100755
index 70e09e9..0000000
--- a/docker/griffin_demo/prep/data/add-measure.sh
+++ /dev/null
@@ -1,50 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-curl -X POST -H "Content-Type: application/json" -d '{
-	"name": "viewitem_hourly",
-	"description": "hourly accuracy of viewitem data",
-	"type": "accuracy",
-	"source": {},
-	"target": {},
-	"evaluateRule": {},
-	"owner": "test",
-	"organization": "demo"
-}' "localhost:8080/measures/add/"
-
-curl -X POST -H "Content-Type: application/json" -d '{
-	"name": "search_hourly",
-	"description": "hourly accuracy of viewitem data",
-	"type": "accuracy",
-	"source": {},
-	"target": {},
-	"evaluateRule": {},
-	"owner": "test",
-	"organization": "demo"
-}' "localhost:8080/measures/add/"
-
-curl -X POST -H "Content-Type: application/json" -d '{
-	"name": "buy_hourly",
-	"description": "hourly accuracy of viewitem data",
-	"type": "accuracy",
-	"source": {},
-	"target": {},
-	"evaluateRule": {},
-	"owner": "test",
-	"organization": "demo"
-}' "localhost:8080/measures/add/"

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/data/create-table.hql
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/data/create-table.hql b/docker/griffin_demo/prep/data/create-table.hql
deleted file mode 100644
index 7eaf6eb..0000000
--- a/docker/griffin_demo/prep/data/create-table.hql
+++ /dev/null
@@ -1,40 +0,0 @@
-# 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.
-
-
-CREATE EXTERNAL TABLE `demo_src`(
-  `id` bigint,
-  `age` int,
-  `desc` string) 
-PARTITIONED BY (
-  `dt` string,
-  `hour` string)
-ROW FORMAT DELIMITED
-  FIELDS TERMINATED BY '|'
-LOCATION
-  'hdfs:///griffin/data/batch/demo_src';
-
-CREATE EXTERNAL TABLE `demo_tgt`(
-  `id` bigint,
-  `age` int,
-  `desc` string) 
-PARTITIONED BY (
-  `dt` string,
-  `hour` string)
-ROW FORMAT DELIMITED
-  FIELDS TERMINATED BY '|'
-LOCATION
-  'hdfs:///griffin/data/batch/demo_tgt';
-


[4/6] incubator-griffin git commit: remove stale docs

Posted by gu...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/data/demo_tgt
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/data/demo_tgt b/docker/griffin_demo/prep/data/demo_tgt
deleted file mode 100644
index 648da8d..0000000
--- a/docker/griffin_demo/prep/data/demo_tgt
+++ /dev/null
@@ -1,125000 +0,0 @@
-0|1|13
-0|2|2
-0|3|3
-0|4|4
-0|5|5
-0|6|6
-0|7|7
-0|8|8
-0|9|9
-0|10|10
-0|11|11a
-0|12|12
-0|13|13
-0|14|14
-0|15|15
-0|16|16
-0|17|17
-0|18|18
-0|19|19fs
-0|20|20
-0|21|21
-0|22|22
-0|23|23
-0|24|24
-0|25|25
-0|26|26
-0|27|27
-0|28|2800
-0|29|29
-0|30|30
-0|31|3adfs1
-0|32|32fdsaf
-0|33|33
-0|34|34
-0|35|35
-0|36|36
-0|37|37
-0|38|38
-0|39|39
-0|40|40
-0|41|41
-0|42|42
-0|43|43
-0|44|44
-0|45|45
-0|46|46
-0|47|47
-0|48|48
-0|49|49
-0|50|50
-0|51|51
-0|52|52
-0|53|53
-0|54|54
-0|55|55fdsaf
-0|56|56
-0|57|57
-0|58|58
-0|59|59
-0|60|60
-0|61|61
-0|62|62
-0|63|63
-0|64|64
-0|65|65
-0|66|66
-0|67|67
-0|68|68
-0|69|69
-0|70|70
-0|71|71
-0|72|72
-0|73|73
-0|74|74
-0|75|75
-0|76|76
-0|77|77
-0|78|78
-0|79|79
-0|80|80
-0|81|81
-0|82|82
-0|83|83
-0|84|84
-0|85|85fdsf
-0|86|86
-0|87|87
-0|88|88
-0|89|89
-0|90|90
-0|91|91
-0|92|92
-0|93|93
-0|94|94
-0|95|95
-0|96|96
-0|97|97
-0|98|98
-0|99|99
-0|100|100
-0|101|101
-0|102|102
-0|103|103
-0|104|104
-0|105|105
-0|106|106
-0|107|107
-0|108|108
-0|109|109fdsf
-0|110|110fdsfsdf
-0|111|111
-0|112|112
-0|113|113
-0|114|114
-0|115|115
-0|116|116
-0|117|117
-0|118|118
-0|119|119
-0|120|120
-0|121|121
-0|122|122
-0|123|123
-0|124|124
-0|125|125
-0|126|126
-0|127|127
-0|128|128
-0|129|129
-0|130|130
-0|131|131
-0|132|132
-0|133|133
-0|134|134
-0|135|135
-0|136|136
-0|137|137
-0|138|138
-0|139|139
-0|140|140
-0|141|141
-0|142|142
-0|143|143
-0|144|144aa
-0|145|145
-0|146|146
-0|147|147
-0|148|148
-0|149|149
-0|150|150
-0|151|151
-0|152|152
-0|153|153
-0|154|154
-0|155|155
-0|156|156
-0|157|157
-0|158|158
-0|159|159
-0|160|160
-0|161|161
-0|162|162
-0|163|163
-0|164|164
-0|165|165
-0|166|166
-0|167|167
-0|168|168
-0|169|169
-0|170|170
-0|171|171
-0|172|172
-0|173|173
-0|174|174
-0|175|175
-0|176|176
-0|177|177
-0|178|178
-0|179|179
-0|180|180
-0|181|181
-0|182|182
-0|183|183
-0|184|184
-0|185|185
-0|186|186
-0|187|187
-0|188|188
-0|189|189
-0|190|190
-0|191|191
-0|192|192
-0|193|193
-0|194|194
-0|195|195
-0|196|196
-0|197|197
-0|198|198
-0|199|199
-0|200|200
-0|201|201
-0|202|202
-0|203|203
-0|204|204
-0|205|205
-0|206|206
-0|207|207
-0|208|208
-0|209|209
-0|210|210
-0|211|211
-0|212|212
-0|213|213
-0|214|214
-0|215|215
-0|216|216
-0|217|217
-0|218|218
-0|219|219
-0|220|220
-0|221|221
-0|222|222
-0|223|223
-0|224|224
-0|225|225
-0|226|226
-0|227|227
-0|228|228
-0|229|229
-0|230|230
-0|231|231
-0|232|232
-0|233|233
-0|234|234
-0|235|235
-0|236|236
-0|237|237
-0|238|238
-0|239|239
-0|240|240
-0|241|241
-0|242|242
-0|243|243
-0|244|244
-0|245|245
-0|246|246
-0|247|247
-0|248|248
-0|249|249
-0|250|250
-0|251|251
-0|252|252
-0|253|253
-0|254|254
-0|255|255
-0|256|256
-0|257|257
-0|258|258
-0|259|259
-0|260|260
-0|261|261
-0|262|262
-0|263|263
-0|264|264
-0|265|265
-0|266|266
-0|267|267
-0|268|268
-0|269|269
-0|270|270
-0|271|271
-0|272|272
-0|273|273
-0|274|274
-0|275|275
-0|276|276
-0|277|277
-0|278|278
-0|279|279
-0|280|280
-0|281|281
-0|282|282
-0|283|283
-0|284|284
-0|285|285
-0|286|286
-0|287|287
-0|288|288
-0|289|289
-0|290|290
-0|291|291
-0|292|292
-0|293|293
-0|294|294
-0|295|295
-0|296|296
-0|297|297
-0|298|298
-0|299|299
-0|300|300
-0|301|301
-0|302|302
-0|303|303
-0|304|304
-0|305|305
-0|306|306
-0|307|307
-0|308|308
-0|309|309
-0|310|310
-0|311|311
-0|312|312
-0|313|313
-0|314|314
-0|315|315
-0|316|316
-0|317|317
-0|318|318
-0|319|319
-0|320|320
-0|321|321
-0|322|322
-0|323|323
-0|324|324
-0|325|325
-0|326|326
-0|327|327
-0|328|328
-0|329|329
-0|330|330
-0|331|331
-0|332|332
-0|333|333
-0|334|334
-0|335|335
-0|336|336
-0|337|337
-0|338|338
-0|339|339
-0|340|340
-0|341|341
-0|342|342
-0|343|343
-0|344|344
-0|345|345
-0|346|346
-0|347|347
-0|348|348
-0|349|349
-0|350|350
-0|351|351
-0|352|352
-0|353|353
-0|354|354
-0|355|355
-0|356|356
-0|357|357
-0|358|358
-0|359|359
-0|360|360
-0|361|361
-0|362|362
-0|363|363
-0|364|364
-0|365|365
-0|366|366
-0|367|367
-0|368|368
-0|369|369
-0|370|370
-0|371|371
-0|372|372
-0|373|373
-0|374|374
-0|375|375
-0|376|376
-0|377|377
-0|378|378
-0|379|379
-0|380|380
-0|381|381
-0|382|382
-0|383|383
-0|384|384
-0|385|385
-0|386|386
-0|387|387
-0|388|388
-0|389|389
-0|390|390
-0|391|391
-0|392|392
-0|393|393
-0|394|394
-0|395|395
-0|396|396
-0|397|397
-0|398|398
-0|399|399
-0|400|400
-0|401|401
-0|402|402
-0|403|403
-0|404|404
-0|405|405
-0|406|406
-0|407|407
-0|408|408
-0|409|409
-0|410|410
-0|411|411
-0|412|412
-0|413|413
-0|414|414
-0|415|415
-0|416|416
-0|417|417
-0|418|418
-0|419|419
-0|420|420
-0|421|421
-0|422|422
-0|423|423
-0|424|424
-0|425|425
-0|426|426
-0|427|427
-0|428|428
-0|429|429
-0|430|430
-0|431|431
-0|432|432
-0|433|433
-0|434|434
-0|435|435
-0|436|436
-0|437|437
-0|438|438
-0|439|439
-0|440|440
-0|441|441
-0|442|442
-0|443|443
-0|444|444
-0|445|445
-0|446|446
-0|447|447
-0|448|448
-0|449|449
-0|450|450
-0|451|451
-0|452|452
-0|453|453
-0|454|454
-0|455|455
-0|456|456
-0|457|457
-0|458|458
-0|459|459
-0|460|460
-0|461|461
-0|462|462
-0|463|463
-0|464|464
-0|465|465
-0|466|466
-0|467|467
-0|468|468
-0|469|469
-0|470|470
-0|471|471
-0|472|472
-0|473|473
-0|474|474
-0|475|475
-0|476|476
-0|477|477
-0|478|478
-0|479|479
-0|480|480
-0|481|481
-0|482|482
-0|483|483
-0|484|484
-0|485|485
-0|486|486
-0|487|487
-0|488|488
-0|489|489
-0|490|490
-0|491|491
-0|492|492
-0|493|493
-0|494|494
-0|495|495
-0|496|496
-0|497|497
-0|498|498
-0|499|499
-0|500|500
-0|501|501
-0|502|502
-0|503|503
-0|504|504
-0|505|505
-0|506|506
-0|507|507
-0|508|508
-0|509|509
-0|510|510
-0|511|511
-0|512|512
-0|513|513
-0|514|514
-0|515|515
-0|516|516
-0|517|517
-0|518|518
-0|519|519
-0|520|520
-0|521|521
-0|522|522
-0|523|523
-0|524|524
-0|525|525
-0|526|526
-0|527|527
-0|528|528
-0|529|529
-0|530|530
-0|531|531
-0|532|532
-0|533|533
-0|534|534
-0|535|535
-0|536|536
-0|537|537
-0|538|538
-0|539|539
-0|540|540
-0|541|541
-0|542|542
-0|543|543
-0|544|544
-0|545|545
-0|546|546
-0|547|547
-0|548|548
-0|549|549
-0|550|550
-0|551|551
-0|552|552
-0|553|553
-0|554|554
-0|555|555
-0|556|556
-0|557|557
-0|558|558
-0|559|559
-0|560|560
-0|561|561
-0|562|562
-0|563|563
-0|564|564
-0|565|565
-0|566|566
-0|567|567
-0|568|568
-0|569|569
-0|570|570
-0|571|571
-0|572|572
-0|573|573
-0|574|574
-0|575|575
-0|576|576
-0|577|577
-0|578|578
-0|579|579
-0|580|580
-0|581|581
-0|582|582
-0|583|583
-0|584|584
-0|585|585
-0|586|586
-0|587|587
-0|588|588
-0|589|589
-0|590|590
-0|591|591
-0|592|592
-0|593|593
-0|594|594
-0|595|595
-0|596|596
-0|597|597
-0|598|598
-0|599|599
-0|600|600
-0|601|601
-0|602|602
-0|603|603
-0|604|604
-0|605|605
-0|606|606
-0|607|607
-0|608|608
-0|609|609
-0|610|610
-0|611|611
-0|612|612
-0|613|613
-0|614|614
-0|615|615
-0|616|616
-0|617|617
-0|618|618
-0|619|619
-0|620|620
-0|621|621
-0|622|622
-0|623|623
-0|624|624
-0|625|625
-0|626|626
-0|627|627
-0|628|628
-0|629|629
-0|630|630
-0|631|631
-0|632|632
-0|633|633
-0|634|634
-0|635|635
-0|636|636
-0|637|637
-0|638|638
-0|639|639
-0|640|640
-0|641|641
-0|642|642
-0|643|643
-0|644|644
-0|645|645
-0|646|646
-0|647|647
-0|648|648
-0|649|649
-0|650|650
-0|651|651
-0|652|652
-0|653|653
-0|654|654
-0|655|655
-0|656|656
-0|657|657
-0|658|658
-0|659|659
-0|660|660
-0|661|661
-0|662|662
-0|663|663
-0|664|664
-0|665|665
-0|666|666
-0|667|667
-0|668|668
-0|669|669
-0|670|670
-0|671|671
-0|672|672
-0|673|673
-0|674|674
-0|675|675
-0|676|676
-0|677|677
-0|678|678
-0|679|679
-0|680|680
-0|681|681
-0|682|682
-0|683|683
-0|684|684
-0|685|685
-0|686|686
-0|687|687
-0|688|688
-0|689|689
-0|690|690
-0|691|691
-0|692|692
-0|693|693
-0|694|694
-0|695|695
-0|696|696
-0|697|697
-0|698|698
-0|699|699
-0|700|700
-0|701|701
-0|702|702
-0|703|703
-0|704|704
-0|705|705
-0|706|706
-0|707|707
-0|708|708
-0|709|709
-0|710|710
-0|711|711
-0|712|712
-0|713|713
-0|714|714
-0|715|715
-0|716|716
-0|717|717
-0|718|718
-0|719|719
-0|720|720
-0|721|721
-0|722|722
-0|723|723
-0|724|724
-0|725|725
-0|726|726
-0|727|727
-0|728|728
-0|729|729
-0|730|730
-0|731|731
-0|732|732
-0|733|733
-0|734|734
-0|735|735
-0|736|736
-0|737|737
-0|738|738
-0|739|739
-0|740|740
-0|741|741
-0|742|742
-0|743|743
-0|744|744
-0|745|745
-0|746|746
-0|747|747
-0|748|748
-0|749|749
-0|750|750
-0|751|751
-0|752|752
-0|753|753
-0|754|754
-0|755|755
-0|756|756
-0|757|757
-0|758|758
-0|759|759
-0|760|760
-0|761|761
-0|762|762
-0|763|763
-0|764|764
-0|765|765
-0|766|766
-0|767|767
-0|768|768
-0|769|769
-0|770|770
-0|771|771
-0|772|772
-0|773|773
-0|774|774
-0|775|775
-0|776|776
-0|777|777
-0|778|778
-0|779|779
-0|780|780
-0|781|781
-0|782|782
-0|783|783
-0|784|784
-0|785|785
-0|786|786
-0|787|787
-0|788|788
-0|789|789
-0|790|790
-0|791|791
-0|792|792
-0|793|793
-0|794|794
-0|795|795
-0|796|796
-0|797|797
-0|798|798
-0|799|799
-0|800|800
-0|801|801
-0|802|802
-0|803|803
-0|804|804
-0|805|805
-0|806|806
-0|807|807
-0|808|808
-0|809|809
-0|810|810
-0|811|811
-0|812|812
-0|813|813
-0|814|814
-0|815|815
-0|816|816
-0|817|817
-0|818|818
-0|819|819
-0|820|820
-0|821|821
-0|822|822
-0|823|823
-0|824|824
-0|825|825
-0|826|826
-0|827|827
-0|828|828
-0|829|829
-0|830|830
-0|831|831
-0|832|832
-0|833|833
-0|834|834
-0|835|835
-0|836|836
-0|837|837
-0|838|838
-0|839|839
-0|840|840
-0|841|841
-0|842|842
-0|843|843
-0|844|844
-0|845|845
-0|846|846
-0|847|847
-0|848|848
-0|849|849
-0|850|850
-0|851|851
-0|852|852
-0|853|853
-0|854|854
-0|855|855
-0|856|856
-0|857|857
-0|858|858
-0|859|859
-0|860|860
-0|861|861
-0|862|862
-0|863|863
-0|864|864
-0|865|865
-0|866|866
-0|867|867
-0|868|868
-0|869|869
-0|870|870
-0|871|871
-0|872|872
-0|873|873
-0|874|874
-0|875|875
-0|876|876
-0|877|877
-0|878|878
-0|879|879
-0|880|880
-0|881|881
-0|882|882
-0|883|883
-0|884|884
-0|885|885
-0|886|886
-0|887|887
-0|888|888
-0|889|889
-0|890|890
-0|891|891
-0|892|892
-0|893|893
-0|894|894
-0|895|895
-0|896|896
-0|897|897
-0|898|898
-0|899|899
-0|900|900
-0|901|901
-0|902|902
-0|903|903
-0|904|904
-0|905|905
-0|906|906
-0|907|907
-0|908|908
-0|909|909
-0|910|910
-0|911|911
-0|912|912
-0|913|913
-0|914|914
-0|915|915
-0|916|916
-0|917|917
-0|918|918
-0|919|919
-0|920|920
-0|921|921
-0|922|922
-0|923|923
-0|924|924
-0|925|925
-0|926|926
-0|927|927
-0|928|928
-0|929|929
-0|930|930
-0|931|931
-0|932|932
-0|933|933
-0|934|934
-0|935|935
-0|936|936
-0|937|937
-0|938|938
-0|939|939
-0|940|940
-0|941|941
-0|942|942
-0|943|943
-0|944|944
-0|945|945
-0|946|946
-0|947|947
-0|948|948
-0|949|949
-0|950|950
-0|951|951
-0|952|952
-0|953|953
-0|954|954
-0|955|955
-0|956|956
-0|957|957
-0|958|958
-0|959|959
-0|960|960
-0|961|961
-0|962|962
-0|963|963
-0|964|964
-0|965|965
-0|966|966
-0|967|967
-0|968|968
-0|969|969
-0|970|970
-0|971|971
-0|972|972
-0|973|973
-0|974|974
-0|975|975
-0|976|976
-0|977|977
-0|978|978
-0|979|979
-0|980|980
-0|981|981
-0|982|982
-0|983|983
-0|984|984
-0|985|985
-0|986|986
-0|987|987
-0|988|988
-0|989|989
-0|990|990
-0|991|991
-0|992|992
-0|993|993
-0|994|994
-0|995|995
-0|996|996
-0|997|997
-0|998|998
-0|999|999
-0|1000|1000
-1|1|1
-1|2|2
-1|3|3
-1|4|4
-1|5|5
-1|6|6
-1|7|7
-1|8|8
-1|9|9
-1|10|10
-1|11|11
-1|12|12
-1|13|13
-1|14|14
-1|15|15
-1|16|16
-1|17|17
-1|18|18
-1|19|19
-1|20|20
-1|21|21
-1|22|22
-1|23|23
-1|24|24
-1|25|25
-1|26|26
-1|27|27
-1|28|28
-1|29|29
-1|30|30
-1|31|31
-1|32|32
-1|33|33
-1|34|34
-1|35|35
-1|36|36
-1|37|37
-1|38|38
-1|39|39
-1|40|40
-1|41|41
-1|42|42
-1|43|43
-1|44|44
-1|45|45
-1|46|46
-1|47|47
-1|48|48
-1|49|49
-1|50|50
-1|51|51
-1|52|52
-1|53|53
-1|54|54
-1|55|55
-1|56|56
-1|57|57
-1|58|58
-1|59|59
-1|60|60
-1|61|61
-1|62|62
-1|63|63
-1|64|64
-1|65|65
-1|66|66
-1|67|67
-1|68|68
-1|69|69
-1|70|70
-1|71|71
-1|72|72
-1|73|73
-1|74|74
-1|75|75
-1|76|76
-1|77|77
-1|78|78
-1|79|79
-1|80|80
-1|81|81
-1|82|82
-1|83|83
-1|84|84
-1|85|85
-1|86|86
-1|87|87
-1|88|88
-1|89|89
-1|90|90
-1|91|91
-1|92|92
-1|93|93
-1|94|94
-1|95|95
-1|96|96
-1|97|97
-1|98|98
-1|99|99
-1|100|100
-1|101|101
-1|102|102
-1|103|103
-1|104|104
-1|105|105
-1|106|106
-1|107|107
-1|108|108
-1|109|109
-1|110|110
-1|111|111
-1|112|112
-1|113|113
-1|114|114
-1|115|115
-1|116|116
-1|117|117
-1|118|118
-1|119|119
-1|120|120
-1|121|121
-1|122|122
-1|123|123
-1|124|124
-1|125|125
-1|126|126
-1|127|127
-1|128|128
-1|129|129
-1|130|130
-1|131|131
-1|132|132
-1|133|133
-1|134|134
-1|135|135
-1|136|136
-1|137|137
-1|138|138
-1|139|139
-1|140|140
-1|141|141
-1|142|142
-1|143|143
-1|144|144
-1|145|145
-1|146|146
-1|147|147
-1|148|148
-1|149|149
-1|150|150
-1|151|151
-1|152|152
-1|153|153
-1|154|154
-1|155|155
-1|156|156
-1|157|157
-1|158|158
-1|159|159
-1|160|160
-1|161|161
-1|162|162
-1|163|163
-1|164|164
-1|165|165
-1|166|166
-1|167|167
-1|168|168
-1|169|169
-1|170|170
-1|171|171
-1|172|172
-1|173|173
-1|174|174
-1|175|175
-1|176|176
-1|177|177
-1|178|178
-1|179|179
-1|180|180
-1|181|181
-1|182|182
-1|183|183
-1|184|184
-1|185|185
-1|186|186
-1|187|187
-1|188|188
-1|189|189
-1|190|190
-1|191|191
-1|192|192
-1|193|193
-1|194|194
-1|195|195
-1|196|196
-1|197|197
-1|198|198
-1|199|199
-1|200|200
-1|201|201
-1|202|202
-1|203|203
-1|204|204
-1|205|205
-1|206|206
-1|207|207
-1|208|208
-1|209|209
-1|210|210
-1|211|211
-1|212|212
-1|213|213
-1|214|214
-1|215|215
-1|216|216
-1|217|217
-1|218|218
-1|219|219
-1|220|220
-1|221|221
-1|222|222
-1|223|223
-1|224|224
-1|225|225
-1|226|226
-1|227|227
-1|228|228
-1|229|229
-1|230|230
-1|231|231
-1|232|232
-1|233|233
-1|234|234
-1|235|235
-1|236|236
-1|237|237
-1|238|238
-1|239|239
-1|240|240
-1|241|241
-1|242|242
-1|243|243
-1|244|244
-1|245|245
-1|246|246
-1|247|247
-1|248|248
-1|249|249
-1|250|250
-1|251|251
-1|252|252
-1|253|253
-1|254|254
-1|255|255
-1|256|256
-1|257|257
-1|258|258
-1|259|259
-1|260|260
-1|261|261
-1|262|262
-1|263|263
-1|264|264
-1|265|265
-1|266|266
-1|267|267
-1|268|268
-1|269|269
-1|270|270
-1|271|271
-1|272|272
-1|273|273
-1|274|274
-1|275|275
-1|276|276
-1|277|277
-1|278|278
-1|279|279
-1|280|280
-1|281|281
-1|282|282
-1|283|283
-1|284|284
-1|285|285
-1|286|286
-1|287|287
-1|288|288
-1|289|289
-1|290|290
-1|291|291
-1|292|292
-1|293|293
-1|294|294
-1|295|295
-1|296|296
-1|297|297
-1|298|298
-1|299|299
-1|300|300
-1|301|301
-1|302|302
-1|303|303
-1|304|304
-1|305|305
-1|306|306
-1|307|307
-1|308|308
-1|309|309
-1|310|310
-1|311|311
-1|312|312
-1|313|313
-1|314|314
-1|315|315
-1|316|316
-1|317|317
-1|318|318
-1|319|319
-1|320|320
-1|321|321
-1|322|322
-1|323|323
-1|324|324
-1|325|325
-1|326|326
-1|327|327
-1|328|328
-1|329|329
-1|330|330
-1|331|331
-1|332|332
-1|333|333
-1|334|334
-1|335|335
-1|336|336
-1|337|337
-1|338|338
-1|339|339
-1|340|340
-1|341|341
-1|342|342
-1|343|343
-1|344|344
-1|345|345
-1|346|346
-1|347|347
-1|348|348
-1|349|349
-1|350|350
-1|351|351
-1|352|352
-1|353|353
-1|354|354
-1|355|355
-1|356|356
-1|357|357
-1|358|358
-1|359|359
-1|360|360
-1|361|361
-1|362|362
-1|363|363
-1|364|364
-1|365|365
-1|366|366
-1|367|367
-1|368|368
-1|369|369
-1|370|370
-1|371|371
-1|372|372
-1|373|373
-1|374|374
-1|375|375
-1|376|376
-1|377|377
-1|378|378
-1|379|379
-1|380|380
-1|381|381
-1|382|382
-1|383|383
-1|384|384
-1|385|385
-1|386|386
-1|387|387
-1|388|388
-1|389|389
-1|390|390
-1|391|391
-1|392|392
-1|393|393
-1|394|394
-1|395|395
-1|396|396
-1|397|397
-1|398|398
-1|399|399
-1|400|400
-1|401|401
-1|402|402
-1|403|403
-1|404|404
-1|405|405
-1|406|406
-1|407|407
-1|408|408
-1|409|409
-1|410|410
-1|411|411
-1|412|412
-1|413|413
-1|414|414
-1|415|415
-1|416|416
-1|417|417
-1|418|418
-1|419|419
-1|420|420
-1|421|421
-1|422|422
-1|423|423
-1|424|424
-1|425|425
-1|426|426
-1|427|427
-1|428|428
-1|429|429
-1|430|430
-1|431|431
-1|432|432
-1|433|433
-1|434|434
-1|435|435
-1|436|436
-1|437|437
-1|438|438
-1|439|439
-1|440|440
-1|441|441
-1|442|442
-1|443|443
-1|444|444
-1|445|445
-1|446|446
-1|447|447
-1|448|448
-1|449|449
-1|450|450
-1|451|451
-1|452|452
-1|453|453
-1|454|454
-1|455|455
-1|456|456
-1|457|457
-1|458|458
-1|459|459
-1|460|460
-1|461|461
-1|462|462
-1|463|463
-1|464|464
-1|465|465
-1|466|466
-1|467|467
-1|468|468
-1|469|469
-1|470|470
-1|471|471
-1|472|472
-1|473|473
-1|474|474
-1|475|475
-1|476|476
-1|477|477
-1|478|478
-1|479|479
-1|480|480
-1|481|481
-1|482|482
-1|483|483
-1|484|484
-1|485|485
-1|486|486
-1|487|487
-1|488|488
-1|489|489
-1|490|490
-1|491|491
-1|492|492
-1|493|493
-1|494|494
-1|495|495
-1|496|496
-1|497|497
-1|498|498
-1|499|499
-1|500|500
-1|501|501
-1|502|502
-1|503|503
-1|504|504
-1|505|505
-1|506|506
-1|507|507
-1|508|508
-1|509|509
-1|510|510
-1|511|511
-1|512|512
-1|513|513
-1|514|514
-1|515|515
-1|516|516
-1|517|517
-1|518|518
-1|519|519
-1|520|520
-1|521|521
-1|522|522
-1|523|523
-1|524|524
-1|525|525
-1|526|526
-1|527|527
-1|528|528
-1|529|529
-1|530|530
-1|531|531
-1|532|532
-1|533|533
-1|534|534
-1|535|535
-1|536|536
-1|537|537
-1|538|538
-1|539|539
-1|540|540
-1|541|541
-1|542|542
-1|543|543
-1|544|544
-1|545|545
-1|546|546
-1|547|547
-1|548|548
-1|549|549
-1|550|550
-1|551|551
-1|552|552
-1|553|553
-1|554|554
-1|555|555
-1|556|556
-1|557|557
-1|558|558
-1|559|559
-1|560|560
-1|561|561
-1|562|562
-1|563|563
-1|564|564
-1|565|565
-1|566|566
-1|567|567
-1|568|568
-1|569|569
-1|570|570
-1|571|571
-1|572|572
-1|573|573
-1|574|574
-1|575|575
-1|576|576
-1|577|577
-1|578|578
-1|579|579
-1|580|580
-1|581|581
-1|582|582
-1|583|583
-1|584|584
-1|585|585
-1|586|586
-1|587|587
-1|588|588
-1|589|589
-1|590|590
-1|591|591
-1|592|592
-1|593|593
-1|594|594
-1|595|595
-1|596|596
-1|597|597
-1|598|598
-1|599|599
-1|600|600
-1|601|601
-1|602|602
-1|603|603
-1|604|604
-1|605|605
-1|606|606
-1|607|607
-1|608|608
-1|609|609
-1|610|610
-1|611|611
-1|612|612
-1|613|613
-1|614|614
-1|615|615
-1|616|616
-1|617|617
-1|618|618
-1|619|619
-1|620|620
-1|621|621
-1|622|622
-1|623|623
-1|624|624
-1|625|625
-1|626|626
-1|627|627
-1|628|628
-1|629|629
-1|630|630
-1|631|631
-1|632|632
-1|633|633
-1|634|634
-1|635|635
-1|636|636
-1|637|637
-1|638|638
-1|639|639
-1|640|640
-1|641|641
-1|642|642
-1|643|643
-1|644|644
-1|645|645
-1|646|646
-1|647|647
-1|648|648
-1|649|649
-1|650|650
-1|651|651
-1|652|652
-1|653|653
-1|654|654
-1|655|655
-1|656|656
-1|657|657
-1|658|658
-1|659|659
-1|660|660
-1|661|661
-1|662|662
-1|663|663
-1|664|664
-1|665|665
-1|666|666
-1|667|667
-1|668|668
-1|669|669
-1|670|670
-1|671|671
-1|672|672
-1|673|673
-1|674|674
-1|675|675
-1|676|676
-1|677|677
-1|678|678
-1|679|679
-1|680|680
-1|681|681
-1|682|682
-1|683|683
-1|684|684
-1|685|685
-1|686|686
-1|687|687
-1|688|688
-1|689|689
-1|690|690
-1|691|691
-1|692|692
-1|693|693
-1|694|694
-1|695|695
-1|696|696
-1|697|697
-1|698|698
-1|699|699
-1|700|700
-1|701|701
-1|702|702
-1|703|703
-1|704|704
-1|705|705
-1|706|706
-1|707|707
-1|708|708
-1|709|709
-1|710|710
-1|711|711
-1|712|712
-1|713|713
-1|714|714
-1|715|715
-1|716|716
-1|717|717
-1|718|718
-1|719|719
-1|720|720
-1|721|721
-1|722|722
-1|723|723
-1|724|724
-1|725|725
-1|726|726
-1|727|727
-1|728|728
-1|729|729
-1|730|730
-1|731|731
-1|732|732
-1|733|733
-1|734|734
-1|735|735
-1|736|736
-1|737|737
-1|738|738
-1|739|739
-1|740|740
-1|741|741
-1|742|742
-1|743|743
-1|744|744
-1|745|745
-1|746|746
-1|747|747
-1|748|748
-1|749|749
-1|750|750
-1|751|751
-1|752|752
-1|753|753
-1|754|754
-1|755|755
-1|756|756
-1|757|757
-1|758|758
-1|759|759
-1|760|760
-1|761|761
-1|762|762
-1|763|763
-1|764|764
-1|765|765
-1|766|766
-1|767|767
-1|768|768
-1|769|769
-1|770|770
-1|771|771
-1|772|772
-1|773|773
-1|774|774
-1|775|775
-1|776|776
-1|777|777
-1|778|778
-1|779|779
-1|780|780
-1|781|781
-1|782|782
-1|783|783
-1|784|784
-1|785|785
-1|786|786
-1|787|787
-1|788|788
-1|789|789
-1|790|790
-1|791|791
-1|792|792
-1|793|793
-1|794|794
-1|795|795
-1|796|796
-1|797|797
-1|798|798
-1|799|799
-1|800|800
-1|801|801
-1|802|802
-1|803|803
-1|804|804
-1|805|805
-1|806|806
-1|807|807
-1|808|808
-1|809|809
-1|810|810
-1|811|811
-1|812|812
-1|813|813
-1|814|814
-1|815|815
-1|816|816
-1|817|817
-1|818|818
-1|819|819
-1|820|820
-1|821|821
-1|822|822
-1|823|823
-1|824|824
-1|825|825
-1|826|826
-1|827|827
-1|828|828
-1|829|829
-1|830|830
-1|831|831
-1|832|832
-1|833|833
-1|834|834
-1|835|835
-1|836|836
-1|837|837
-1|838|838
-1|839|839
-1|840|840
-1|841|841
-1|842|842
-1|843|843
-1|844|844
-1|845|845
-1|846|846
-1|847|847
-1|848|848
-1|849|849
-1|850|850
-1|851|851
-1|852|852
-1|853|853
-1|854|854
-1|855|855
-1|856|856
-1|857|857
-1|858|858
-1|859|859
-1|860|860
-1|861|861
-1|862|862
-1|863|863
-1|864|864
-1|865|865
-1|866|866
-1|867|867
-1|868|868
-1|869|869
-1|870|870
-1|871|871
-1|872|872
-1|873|873
-1|874|874
-1|875|875
-1|876|876
-1|877|877
-1|878|878
-1|879|879
-1|880|880
-1|881|881
-1|882|882
-1|883|883
-1|884|884
-1|885|885
-1|886|886
-1|887|887
-1|888|888
-1|889|889
-1|890|890
-1|891|891
-1|892|892
-1|893|893
-1|894|894
-1|895|895
-1|896|896
-1|897|897
-1|898|898
-1|899|899
-1|900|900
-1|901|901
-1|902|902
-1|903|903
-1|904|904
-1|905|905
-1|906|906
-1|907|907
-1|908|908
-1|909|909
-1|910|910
-1|911|911
-1|912|912
-1|913|913
-1|914|914
-1|915|915
-1|916|916
-1|917|917
-1|918|918
-1|919|919
-1|920|920
-1|921|921
-1|922|922
-1|923|923
-1|924|924
-1|925|925
-1|926|926
-1|927|927
-1|928|928
-1|929|929
-1|930|930
-1|931|931
-1|932|932
-1|933|933
-1|934|934
-1|935|935
-1|936|936
-1|937|937
-1|938|938
-1|939|939
-1|940|940
-1|941|941
-1|942|942
-1|943|943
-1|944|944
-1|945|945
-1|946|946
-1|947|947
-1|948|948
-1|949|949
-1|950|950
-1|951|951
-1|952|952
-1|953|953
-1|954|954
-1|955|955
-1|956|956
-1|957|957
-1|958|958
-1|959|959
-1|960|960
-1|961|961
-1|962|962
-1|963|963
-1|964|964
-1|965|965
-1|966|966
-1|967|967
-1|968|968
-1|969|969
-1|970|970
-1|971|971
-1|972|972
-1|973|973
-1|974|974
-1|975|975
-1|976|976
-1|977|977
-1|978|978
-1|979|979
-1|980|980
-1|981|981
-1|982|982
-1|983|983
-1|984|984
-1|985|985
-1|986|986
-1|987|987
-1|988|988
-1|989|989
-1|990|990
-1|991|991
-1|992|992
-1|993|993
-1|994|994
-1|995|995
-1|996|996
-1|997|997
-1|998|998
-1|999|999
-1|1000|1000
-2|1|1
-2|2|2
-2|3|3
-2|4|4
-2|5|5
-2|6|6
-2|7|7
-2|8|8
-2|9|9
-2|10|10
-2|11|11
-2|12|12
-2|13|13
-2|14|14
-2|15|15
-2|16|16
-2|17|17
-2|18|18
-2|19|19
-2|20|20
-2|21|21
-2|22|22
-2|23|23
-2|24|24
-2|25|25
-2|26|26
-2|27|27
-2|28|28
-2|29|29
-2|30|30
-2|31|31
-2|32|32
-2|33|33
-2|34|34
-2|35|35
-2|36|36
-2|37|37
-2|38|38
-2|39|39
-2|40|40
-2|41|41
-2|42|42
-2|43|43
-2|44|44
-2|45|45
-2|46|46
-2|47|47
-2|48|48
-2|49|49
-2|50|50
-2|51|51
-2|52|52
-2|53|53
-2|54|54
-2|55|55
-2|56|56
-2|57|57
-2|58|58
-2|59|59
-2|60|60
-2|61|61
-2|62|62
-2|63|63
-2|64|64
-2|65|65
-2|66|66
-2|67|67
-2|68|68
-2|69|69
-2|70|70
-2|71|71
-2|72|72
-2|73|73
-2|74|74
-2|75|75
-2|76|76
-2|77|77
-2|78|78
-2|79|79
-2|80|80
-2|81|81
-2|82|82
-2|83|83
-2|84|84
-2|85|85
-2|86|86
-2|87|87
-2|88|88
-2|89|89
-2|90|90
-2|91|91
-2|92|92
-2|93|93
-2|94|94
-2|95|95
-2|96|96
-2|97|97
-2|98|98
-2|99|99
-2|100|100
-2|101|101
-2|102|102
-2|103|103
-2|104|104
-2|105|105
-2|106|106
-2|107|107
-2|108|108
-2|109|109
-2|110|110
-2|111|111
-2|112|112
-2|113|113
-2|114|114
-2|115|115
-2|116|116
-2|117|117
-2|118|118
-2|119|119
-2|120|120
-2|121|121
-2|122|122
-2|123|123
-2|124|124
-2|125|125
-2|126|126
-2|127|127
-2|128|128
-2|129|129
-2|130|130
-2|131|131
-2|132|132
-2|133|133
-2|134|134
-2|135|135
-2|136|136
-2|137|137
-2|138|138
-2|139|139
-2|140|140
-2|141|141
-2|142|142
-2|143|143
-2|144|144
-2|145|145
-2|146|146
-2|147|147
-2|148|148
-2|149|149
-2|150|150
-2|151|151
-2|152|152
-2|153|153
-2|154|154
-2|155|155
-2|156|156
-2|157|157
-2|158|158
-2|159|159
-2|160|160
-2|161|161
-2|162|162
-2|163|163
-2|164|164
-2|165|165
-2|166|166
-2|167|167
-2|168|168
-2|169|169
-2|170|170
-2|171|171
-2|172|172
-2|173|173
-2|174|174
-2|175|175
-2|176|176
-2|177|177
-2|178|178
-2|179|179
-2|180|180
-2|181|181
-2|182|182
-2|183|183
-2|184|184
-2|185|185
-2|186|186
-2|187|187
-2|188|188
-2|189|189
-2|190|190
-2|191|191
-2|192|192
-2|193|193
-2|194|194
-2|195|195
-2|196|196
-2|197|197
-2|198|198
-2|199|199
-2|200|200
-2|201|201
-2|202|202
-2|203|203
-2|204|204
-2|205|205
-2|206|206
-2|207|207
-2|208|208
-2|209|209
-2|210|210
-2|211|211
-2|212|212
-2|213|213
-2|214|214
-2|215|215
-2|216|216
-2|217|217
-2|218|218
-2|219|219
-2|220|220
-2|221|221
-2|222|222
-2|223|223
-2|224|224
-2|225|225
-2|226|226
-2|227|227
-2|228|228
-2|229|229
-2|230|230
-2|231|231
-2|232|232
-2|233|233
-2|234|234
-2|235|235
-2|236|236
-2|237|237
-2|238|238
-2|239|239
-2|240|240
-2|241|241
-2|242|242
-2|243|243
-2|244|244
-2|245|245
-2|246|246
-2|247|247
-2|248|248
-2|249|249
-2|250|250
-2|251|251
-2|252|252
-2|253|253
-2|254|254
-2|255|255
-2|256|256
-2|257|257
-2|258|258
-2|259|259
-2|260|260
-2|261|261
-2|262|262
-2|263|263
-2|264|264
-2|265|265
-2|266|266
-2|267|267
-2|268|268
-2|269|269
-2|270|270
-2|271|271
-2|272|272
-2|273|273
-2|274|274
-2|275|275
-2|276|276
-2|277|277
-2|278|278
-2|279|279
-2|280|280
-2|281|281
-2|282|282
-2|283|283
-2|284|284
-2|285|285
-2|286|286
-2|287|287
-2|288|288
-2|289|289
-2|290|290
-2|291|291
-2|292|292
-2|293|293
-2|294|294
-2|295|295
-2|296|296
-2|297|297
-2|298|298
-2|299|299
-2|300|300
-2|301|301
-2|302|302
-2|303|303
-2|304|304
-2|305|305
-2|306|306
-2|307|307
-2|308|308
-2|309|309
-2|310|310
-2|311|311
-2|312|312
-2|313|313
-2|314|314
-2|315|315
-2|316|316
-2|317|317
-2|318|318
-2|319|319
-2|320|320
-2|321|321
-2|322|322
-2|323|323
-2|324|324
-2|325|325
-2|326|326
-2|327|327
-2|328|328
-2|329|329
-2|330|330
-2|331|331
-2|332|332
-2|333|333
-2|334|334
-2|335|335
-2|336|336
-2|337|337
-2|338|338
-2|339|339
-2|340|340
-2|341|341
-2|342|342
-2|343|343
-2|344|344
-2|345|345
-2|346|346
-2|347|347
-2|348|348
-2|349|349
-2|350|350
-2|351|351
-2|352|352
-2|353|353
-2|354|354
-2|355|355
-2|356|356
-2|357|357
-2|358|358
-2|359|359
-2|360|360
-2|361|361
-2|362|362
-2|363|363
-2|364|364
-2|365|365
-2|366|366
-2|367|367
-2|368|368
-2|369|369
-2|370|370
-2|371|371
-2|372|372
-2|373|373
-2|374|374
-2|375|375
-2|376|376
-2|377|377
-2|378|378
-2|379|379
-2|380|380
-2|381|381
-2|382|382
-2|383|383
-2|384|384
-2|385|385
-2|386|386
-2|387|387
-2|388|388
-2|389|389
-2|390|390
-2|391|391
-2|392|392
-2|393|393
-2|394|394
-2|395|395
-2|396|396
-2|397|397
-2|398|398
-2|399|399
-2|400|400
-2|401|401
-2|402|402
-2|403|403
-2|404|404
-2|405|405
-2|406|406
-2|407|407
-2|408|408
-2|409|409
-2|410|410
-2|411|411
-2|412|412
-2|413|413
-2|414|414
-2|415|415
-2|416|416
-2|417|417
-2|418|418
-2|419|419
-2|420|420
-2|421|421
-2|422|422
-2|423|423
-2|424|424
-2|425|425
-2|426|426
-2|427|427
-2|428|428
-2|429|429
-2|430|430
-2|431|431
-2|432|432
-2|433|433
-2|434|434
-2|435|435
-2|436|436
-2|437|437
-2|438|438
-2|439|439
-2|440|440
-2|441|441
-2|442|442
-2|443|443
-2|444|444
-2|445|445
-2|446|446
-2|447|447
-2|448|448
-2|449|449
-2|450|450
-2|451|451
-2|452|452
-2|453|453
-2|454|454
-2|455|455
-2|456|456
-2|457|457
-2|458|458
-2|459|459
-2|460|460
-2|461|461
-2|462|462
-2|463|463
-2|464|464
-2|465|465
-2|466|466
-2|467|467
-2|468|468
-2|469|469
-2|470|470
-2|471|471
-2|472|472
-2|473|473
-2|474|474
-2|475|475
-2|476|476
-2|477|477
-2|478|478
-2|479|479
-2|480|480
-2|481|481
-2|482|482
-2|483|483
-2|484|484
-2|485|485
-2|486|486
-2|487|487
-2|488|488
-2|489|489
-2|490|490
-2|491|491
-2|492|492
-2|493|493
-2|494|494
-2|495|495
-2|496|496
-2|497|497
-2|498|498
-2|499|499
-2|500|500
-2|501|501
-2|502|502
-2|503|503
-2|504|504
-2|505|505
-2|506|506
-2|507|507
-2|508|508
-2|509|509
-2|510|510
-2|511|511
-2|512|512
-2|513|513
-2|514|514
-2|515|515
-2|516|516
-2|517|517
-2|518|518
-2|519|519
-2|520|520
-2|521|521
-2|522|522
-2|523|523
-2|524|524
-2|525|525
-2|526|526
-2|527|527
-2|528|528
-2|529|529
-2|530|530
-2|531|531
-2|532|532
-2|533|533
-2|534|534
-2|535|535
-2|536|536
-2|537|537
-2|538|538
-2|539|539
-2|540|540
-2|541|541
-2|542|542
-2|543|543
-2|544|544
-2|545|545
-2|546|546
-2|547|547
-2|548|548
-2|549|549
-2|550|550
-2|551|551
-2|552|552
-2|553|553
-2|554|554
-2|555|555
-2|556|556
-2|557|557
-2|558|558
-2|559|559
-2|560|560
-2|561|561
-2|562|562
-2|563|563
-2|564|564
-2|565|565
-2|566|566
-2|567|567
-2|568|568
-2|569|569
-2|570|570
-2|571|571
-2|572|572
-2|573|573
-2|574|574
-2|575|575
-2|576|576
-2|577|577
-2|578|578
-2|579|579
-2|580|580
-2|581|581
-2|582|582
-2|583|583
-2|584|584
-2|585|585
-2|586|586
-2|587|587
-2|588|588
-2|589|589
-2|590|590
-2|591|591
-2|592|592
-2|593|593
-2|594|594
-2|595|595
-2|596|596
-2|597|597
-2|598|598
-2|599|599
-2|600|600
-2|601|601
-2|602|602
-2|603|603
-2|604|604
-2|605|605
-2|606|606
-2|607|607
-2|608|608
-2|609|609
-2|610|610
-2|611|611
-2|612|612
-2|613|613
-2|614|614
-2|615|615
-2|616|616
-2|617|617
-2|618|618
-2|619|619
-2|620|620
-2|621|621
-2|622|622
-2|623|623
-2|624|624
-2|625|625
-2|626|626
-2|627|627
-2|628|628
-2|629|629
-2|630|630
-2|631|631
-2|632|632
-2|633|633
-2|634|634
-2|635|635
-2|636|636
-2|637|637
-2|638|638
-2|639|639
-2|640|640
-2|641|641
-2|642|642
-2|643|643
-2|644|644
-2|645|645
-2|646|646
-2|647|647
-2|648|648
-2|649|649
-2|650|650
-2|651|651
-2|652|652
-2|653|653
-2|654|654
-2|655|655
-2|656|656
-2|657|657
-2|658|658
-2|659|659
-2|660|660
-2|661|661
-2|662|662
-2|663|663
-2|664|664
-2|665|665
-2|666|666
-2|667|667
-2|668|668
-2|669|669
-2|670|670
-2|671|671
-2|672|672
-2|673|673
-2|674|674
-2|675|675
-2|676|676
-2|677|677
-2|678|678
-2|679|679
-2|680|680
-2|681|681
-2|682|682
-2|683|683
-2|684|684
-2|685|685
-2|686|686
-2|687|687
-2|688|688
-2|689|689
-2|690|690
-2|691|691
-2|692|692
-2|693|693
-2|694|694
-2|695|695
-2|696|696
-2|697|697
-2|698|698
-2|699|699
-2|700|700
-2|701|701
-2|702|702
-2|703|703
-2|704|704
-2|705|705
-2|706|706
-2|707|707
-2|708|708
-2|709|709
-2|710|710
-2|711|711
-2|712|712
-2|713|713
-2|714|714
-2|715|715
-2|716|716
-2|717|717
-2|718|718
-2|719|719
-2|720|720
-2|721|721
-2|722|722
-2|723|723
-2|724|724
-2|725|725
-2|726|726
-2|727|727
-2|728|728
-2|729|729
-2|730|730
-2|731|731
-2|732|732
-2|733|733
-2|734|734
-2|735|735
-2|736|736
-2|737|737
-2|738|738
-2|739|739
-2|740|740
-2|741|741
-2|742|742
-2|743|743
-2|744|744
-2|745|745
-2|746|746
-2|747|747
-2|748|748
-2|749|749
-2|750|750
-2|751|751
-2|752|752
-2|753|753
-2|754|754
-2|755|755
-2|756|756
-2|757|757
-2|758|758
-2|759|759
-2|760|760
-2|761|761
-2|762|762
-2|763|763
-2|764|764
-2|765|765
-2|766|766
-2|767|767
-2|768|768
-2|769|769
-2|770|770
-2|771|771
-2|772|772
-2|773|773
-2|774|774
-2|775|775
-2|776|776
-2|777|777
-2|778|778
-2|779|779
-2|780|780
-2|781|781
-2|782|782
-2|783|783
-2|784|784
-2|785|785
-2|786|786
-2|787|787
-2|788|788
-2|789|789
-2|790|790
-2|791|791
-2|792|792
-2|793|793
-2|794|794
-2|795|795
-2|796|796
-2|797|797
-2|798|798
-2|799|799
-2|800|800
-2|801|801
-2|802|802
-2|803|803
-2|804|804
-2|805|805
-2|806|806
-2|807|807
-2|808|808
-2|809|809
-2|810|810
-2|811|811
-2|812|812
-2|813|813
-2|814|814
-2|815|815
-2|816|816
-2|817|817
-2|818|818
-2|819|819
-2|820|820
-2|821|821
-2|822|822
-2|823|823
-2|824|824
-2|825|825
-2|826|826
-2|827|827
-2|828|828
-2|829|829
-2|830|830
-2|831|831
-2|832|832
-2|833|833
-2|834|834
-2|835|835
-2|836|836
-2|837|837
-2|838|838
-2|839|839
-2|840|840
-2|841|841
-2|842|842
-2|843|843
-2|844|844
-2|845|845
-2|846|846
-2|847|847
-2|848|848
-2|849|849
-2|850|850
-2|851|851
-2|852|852
-2|853|853
-2|854|854
-2|855|855
-2|856|856
-2|857|857
-2|858|858
-2|859|859
-2|860|860
-2|861|861
-2|862|862
-2|863|863
-2|864|864
-2|865|865
-2|866|866
-2|867|867
-2|868|868
-2|869|869
-2|870|870
-2|871|871
-2|872|872
-2|873|873
-2|874|874
-2|875|875
-2|876|876
-2|877|877
-2|878|878
-2|879|879
-2|880|880
-2|881|881
-2|882|882
-2|883|883
-2|884|884
-2|885|885
-2|886|886
-2|887|887
-2|888|888
-2|889|889
-2|890|890
-2|891|891
-2|892|892
-2|893|893
-2|894|894
-2|895|895
-2|896|896
-2|897|897
-2|898|898
-2|899|899
-2|900|900
-2|901|901
-2|902|902
-2|903|903
-2|904|904
-2|905|905
-2|906|906
-2|907|907
-2|908|908
-2|909|909
-2|910|910
-2|911|911
-2|912|912
-2|913|913
-2|914|914
-2|915|915
-2|916|916
-2|917|917
-2|918|918
-2|919|919
-2|920|920
-2|921|921
-2|922|922
-2|923|923
-2|924|924
-2|925|925
-2|926|926
-2|927|927
-2|928|928
-2|929|929
-2|930|930
-2|931|931
-2|932|932
-2|933|933
-2|934|934
-2|935|935
-2|936|936
-2|937|937
-2|938|938
-2|939|939
-2|940|940
-2|941|941
-2|942|942
-2|943|943
-2|944|944
-2|945|945
-2|946|946
-2|947|947
-2|948|948
-2|949|949
-2|950|950
-2|951|951
-2|952|952
-2|953|953
-2|954|954
-2|955|955
-2|956|956
-2|957|957
-2|958|958
-2|959|959
-2|960|960
-2|961|961
-2|962|962
-2|963|963
-2|964|964
-2|965|965
-2|966|966
-2|967|967
-2|968|968
-2|969|969
-2|970|970
-2|971|971
-2|972|972
-2|973|973
-2|974|974
-2|975|975
-2|976|976
-2|977|977
-2|978|978
-2|979|979
-2|980|980
-2|981|981
-2|982|982
-2|983|983
-2|984|984
-2|985|985
-2|986|986
-2|987|987
-2|988|988
-2|989|989
-2|990|990
-2|991|991
-2|992|992
-2|993|993
-2|994|994
-2|995|995
-2|996|996
-2|997|997
-2|998|998
-2|999|999
-2|1000|1000
-3|1|1
-3|2|2
-3|3|3
-3|4|4
-3|5|5
-3|6|6
-3|7|7
-3|8|8
-3|9|9
-3|10|10
-3|11|11
-3|12|12
-3|13|13
-3|14|14
-3|15|15
-3|16|16
-3|17|17
-3|18|18
-3|19|19
-3|20|20
-3|21|21
-3|22|22
-3|23|23
-3|24|24
-3|25|25
-3|26|26
-3|27|27
-3|28|28
-3|29|29
-3|30|30
-3|31|31
-3|32|32
-3|33|33
-3|34|34
-3|35|35
-3|36|36
-3|37|37
-3|38|38
-3|39|39
-3|40|40
-3|41|41
-3|42|42
-3|43|43
-3|44|44
-3|45|45
-3|46|46
-3|47|47
-3|48|48
-3|49|49
-3|50|50
-3|51|51
-3|52|52
-3|53|53
-3|54|54
-3|55|55
-3|56|56
-3|57|57
-3|58|58
-3|59|59
-3|60|60
-3|61|61
-3|62|62
-3|63|63
-3|64|64
-3|65|65
-3|66|66
-3|67|67
-3|68|68
-3|69|69
-3|70|70
-3|71|71
-3|72|72
-3|73|73
-3|74|74
-3|75|75
-3|76|76
-3|77|77
-3|78|78
-3|79|79
-3|80|80
-3|81|81
-3|82|82
-3|83|83
-3|84|84
-3|85|85
-3|86|86
-3|87|87
-3|88|88
-3|89|89
-3|90|90
-3|91|91
-3|92|92
-3|93|93
-3|94|94
-3|95|95
-3|96|96
-3|97|97
-3|98|98
-3|99|99
-3|100|100
-3|101|101
-3|102|102
-3|103|103
-3|104|104
-3|105|105
-3|106|106
-3|107|107
-3|108|108
-3|109|109
-3|110|110
-3|111|111
-3|112|112
-3|113|113
-3|114|114
-3|115|115
-3|116|116
-3|117|117
-3|118|118
-3|119|119
-3|120|120
-3|121|121
-3|122|122
-3|123|123
-3|124|124
-3|125|125
-3|126|126
-3|127|127
-3|128|128
-3|129|129
-3|130|130
-3|131|131
-3|132|132
-3|133|133
-3|134|134
-3|135|135
-3|136|136
-3|137|137
-3|138|138
-3|139|139
-3|140|140
-3|141|141
-3|142|142
-3|143|143
-3|144|144
-3|145|145
-3|146|146
-3|147|147
-3|148|148
-3|149|149
-3|150|150
-3|151|151
-3|152|152
-3|153|153
-3|154|154
-3|155|155
-3|156|156
-3|157|157
-3|158|158
-3|159|159
-3|160|160
-3|161|161
-3|162|162
-3|163|163
-3|164|164
-3|165|165
-3|166|166
-3|167|167
-3|168|168
-3|169|169
-3|170|170
-3|171|171
-3|172|172
-3|173|173
-3|174|174
-3|175|175
-3|176|176
-3|177|177
-3|178|178
-3|179|179
-3|180|180
-3|181|181
-3|182|182
-3|183|183
-3|184|184
-3|185|185
-3|186|186
-3|187|187
-3|188|188
-3|189|189
-3|190|190
-3|191|191
-3|192|192
-3|193|193
-3|194|194
-3|195|195
-3|196|196
-3|197|197
-3|198|198
-3|199|199
-3|200|200
-3|201|201
-3|202|202
-3|203|203
-3|204|204
-3|205|205
-3|206|206
-3|207|207
-3|208|208
-3|209|209
-3|210|210
-3|211|211
-3|212|212
-3|213|213
-3|214|214
-3|215|215
-3|216|216
-3|217|217
-3|218|218
-3|219|219
-3|220|220
-3|221|221
-3|222|222
-3|223|223
-3|224|224
-3|225|225
-3|226|226
-3|227|227
-3|228|228
-3|229|229
-3|230|230
-3|231|231
-3|232|232
-3|233|233
-3|234|234
-3|235|235
-3|236|236
-3|237|237
-3|238|238
-3|239|239
-3|240|240
-3|241|241
-3|242|242
-3|243|243
-3|244|244
-3|245|245
-3|246|246
-3|247|247
-3|248|248
-3|249|249
-3|250|250
-3|251|251
-3|252|252
-3|253|253
-3|254|254
-3|255|255
-3|256|256
-3|257|257
-3|258|258
-3|259|259
-3|260|260
-3|261|261
-3|262|262
-3|263|263
-3|264|264
-3|265|265
-3|266|266
-3|267|267
-3|268|268
-3|269|269
-3|270|270
-3|271|271
-3|272|272
-3|273|273
-3|274|274
-3|275|275
-3|276|276
-3|277|277
-3|278|278
-3|279|279
-3|280|280
-3|281|281
-3|282|282
-3|283|283
-3|284|284
-3|285|285
-3|286|286
-3|287|287
-3|288|288
-3|289|289
-3|290|290
-3|291|291
-3|292|292
-3|293|293
-3|294|294
-3|295|295
-3|296|296
-3|297|297
-3|298|298
-3|299|299
-3|300|300
-3|301|301
-3|302|302
-3|303|303
-3|304|304
-3|305|305
-3|306|306
-3|307|307
-3|308|308
-3|309|309
-3|310|310
-3|311|311
-3|312|312
-3|313|313
-3|314|314
-3|315|315
-3|316|316
-3|317|317
-3|318|318
-3|319|319
-3|320|320
-3|321|321
-3|322|322
-3|323|323
-3|324|324
-3|325|325
-3|326|326
-3|327|327
-3|328|328
-3|329|329
-3|330|330
-3|331|331
-3|332|332
-3|333|333
-3|334|334
-3|335|335
-3|336|336
-3|337|337
-3|338|338
-3|339|339
-3|340|340
-3|341|341
-3|342|342
-3|343|343
-3|344|344
-3|345|345
-3|346|346
-3|347|347
-3|348|348
-3|349|349
-3|350|350
-3|351|351
-3|352|352
-3|353|353
-3|354|354
-3|355|355
-3|356|356
-3|357|357
-3|358|358
-3|359|359
-3|360|360
-3|361|361
-3|362|362
-3|363|363
-3|364|364
-3|365|365
-3|366|366
-3|367|367
-3|368|368
-3|369|369
-3|370|370
-3|371|371
-3|372|372
-3|373|373
-3|374|374
-3|375|375
-3|376|376
-3|377|377
-3|378|378
-3|379|379
-3|380|380
-3|381|381
-3|382|382
-3|383|383
-3|384|384
-3|385|385
-3|386|386
-3|387|387
-3|388|388
-3|389|389
-3|390|390
-3|391|391
-3|392|392
-3|393|393
-3|394|394
-3|395|395
-3|396|396
-3|397|397
-3|398|398
-3|399|399
-3|400|400
-3|401|401
-3|402|402
-3|403|403
-3|404|404
-3|405|405
-3|406|406
-3|407|407
-3|408|408
-3|409|409
-3|410|410
-3|411|411
-3|412|412
-3|413|413
-3|414|414
-3|415|415
-3|416|416
-3|417|417
-3|418|418
-3|419|419
-3|420|420
-3|421|421
-3|422|422
-3|423|423
-3|424|424
-3|425|425
-3|426|426
-3|427|427
-3|428|428
-3|429|429
-3|430|430
-3|431|431
-3|432|432
-3|433|433
-3|434|434
-3|435|435
-3|436|436
-3|437|437
-3|438|438
-3|439|439
-3|440|440
-3|441|441
-3|442|442
-3|443|443
-3|444|444
-3|445|445
-3|446|446
-3|447|447
-3|448|448
-3|449|449
-3|450|450
-3|451|451
-3|452|452
-3|453|453
-3|454|454
-3|455|455
-3|456|456
-3|457|457
-3|458|458
-3|459|459
-3|460|460
-3|461|461
-3|462|462
-3|463|463
-3|464|464
-3|465|465
-3|466|466
-3|467|467
-3|468|468
-3|469|469
-3|470|470
-3|471|471
-3|472|472
-3|473|473
-3|474|474
-3|475|475
-3|476|476
-3|477|477
-3|478|478
-3|479|479
-3|480|480
-3|481|481
-3|482|482
-3|483|483
-3|484|484
-3|485|485
-3|486|486
-3|487|487
-3|488|488
-3|489|489
-3|490|490
-3|491|491
-3|492|492
-3|493|493
-3|494|494
-3|495|495
-3|496|496
-3|497|497
-3|498|498
-3|499|499
-3|500|500
-3|501|501
-3|502|502
-3|503|503
-3|504|504
-3|505|505
-3|506|506
-3|507|507
-3|508|508
-3|509|509
-3|510|510
-3|511|511
-3|512|512
-3|513|513
-3|514|514
-3|515|515
-3|516|516
-3|517|517
-3|518|518
-3|519|519
-3|520|520
-3|521|521
-3|522|522
-3|523|523
-3|524|524
-3|525|525
-3|526|526
-3|527|527
-3|528|528
-3|529|529
-3|530|530
-3|531|531
-3|532|532
-3|533|533
-3|534|534
-3|535|535
-3|536|536
-3|537|537
-3|538|538
-3|539|539
-3|540|540
-3|541|541
-3|542|542
-3|543|543
-3|544|544
-3|545|545
-3|546|546
-3|547|547
-3|548|548
-3|549|549
-3|550|550
-3|551|551
-3|552|552
-3|553|553
-3|554|554
-3|555|555
-3|556|556
-3|557|557
-3|558|558
-3|559|559
-3|560|560
-3|561|561
-3|562|562
-3|563|563
-3|564|564
-3|565|565
-3|566|566
-3|567|567
-3|568|568
-3|569|569
-3|570|570
-3|571|571
-3|572|572
-3|573|573
-3|574|574
-3|575|575
-3|576|576
-3|577|577
-3|578|578
-3|579|579
-3|580|580
-3|581|581
-3|582|582
-3|583|583
-3|584|584
-3|585|585
-3|586|586
-3|587|587
-3|588|588
-3|589|589
-3|590|590
-3|591|591
-3|592|592
-3|593|593
-3|594|594
-3|595|595
-3|596|596
-3|597|597
-3|598|598
-3|599|599
-3|600|600
-3|601|601
-3|602|602
-3|603|603
-3|604|604
-3|605|605
-3|606|606
-3|607|607
-3|608|608
-3|609|609
-3|610|610
-3|611|611
-3|612|612
-3|613|613
-3|614|614
-3|615|615
-3|616|616
-3|617|617
-3|618|618
-3|619|619
-3|620|620
-3|621|621
-3|622|622
-3|623|623
-3|624|624
-3|625|625
-3|626|626
-3|627|627
-3|628|628
-3|629|629
-3|630|630
-3|631|631
-3|632|632
-3|633|633
-3|634|634
-3|635|635
-3|636|636
-3|637|637
-3|638|638
-3|639|639
-3|640|640
-3|641|641
-3|642|642
-3|643|643
-3|644|644
-3|645|645
-3|646|646
-3|647|647
-3|648|648
-3|649|649
-3|650|650
-3|651|651
-3|652|652
-3|653|653
-3|654|654
-3|655|655
-3|656|656
-3|657|657
-3|658|658
-3|659|659
-3|660|660
-3|661|661
-3|662|662
-3|663|663
-3|664|664
-3|665|665
-3|666|666
-3|667|667
-3|668|668
-3|669|669
-3|670|670
-3|671|671
-3|672|672
-3|673|673
-3|674|674
-3|675|675
-3|676|676
-3|677|677
-3|678|678
-3|679|679
-3|680|680
-3|681|681
-3|682|682
-3|683|683
-3|684|684
-3|685|685
-3|686|686
-3|687|687
-3|688|688
-3|689|689
-3|690|690
-3|691|691
-3|692|692
-3|693|693
-3|694|694
-3|695|695
-3|696|696
-3|697|697
-3|698|698
-3|699|699
-3|700|700
-3|701|701
-3|702|702
-3|703|703
-3|704|704
-3|705|705
-3|706|706
-3|707|707
-3|708|708
-3|709|709
-3|710|710
-3|711|711
-3|712|712
-3|713|713
-3|714|714
-3|715|715
-3|716|716
-3|717|717
-3|718|718
-3|719|719
-3|720|720
-3|721|721
-3|722|722
-3|723|723
-3|724|724
-3|725|725
-3|726|726
-3|727|727
-3|728|728
-3|729|729
-3|730|730
-3|731|731
-3|732|732
-3|733|733
-3|734|734
-3|735|735
-3|736|736
-3|737|737
-3|738|738
-3|739|739
-3|740|740
-3|741|741
-3|742|742
-3|743|743
-3|744|744
-3|745|745
-3|746|746
-3|747|747
-3|748|748
-3|749|749
-3|750|750
-3|751|751
-3|752|752
-3|753|753
-3|754|754
-3|755|755
-3|756|756
-3|757|757
-3|758|758
-3|759|759
-3|760|760
-3|761|761
-3|762|762
-3|763|763
-3|764|764
-3|765|765
-3|766|766
-3|767|767
-3|768|768
-3|769|769
-3|770|770
-3|771|771
-3|772|772
-3|773|773
-3|774|774
-3|775|775
-3|776|776
-3|777|777
-3|778|778
-3|779|779
-3|780|780
-3|781|781
-3|782|782
-3|783|783
-3|784|784
-3|785|785
-3|786|786
-3|787|787
-3|788|788
-3|789|789
-3|790|790
-3|791|791
-3|792|792
-3|793|793
-3|794|794
-3|795|795
-3|796|796
-3|797|797
-3|798|798
-3|799|799
-3|800|800
-3|801|801
-3|802|802
-3|803|803
-3|804|804
-3|805|805
-3|806|806
-3|807|807
-3|808|808
-3|809|809
-3|810|810
-3|811|811
-3|812|812
-3|813|813
-3|814|814
-3|815|815
-3|816|816
-3|817|817
-3|818|818
-3|819|819
-3|820|820
-3|821|821
-3|822|822
-3|823|823
-3|824|824
-3|825|825
-3|826|826
-3|827|827
-3|828|828
-3|829|829
-3|830|830
-3|831|831
-3|832|832
-3|833|833
-3|834|834
-3|835|835
-3|836|836
-3|837|837
-3|838|838
-3|839|839
-3|840|840
-3|841|841
-3|842|842
-3|843|843
-3|844|844
-3|845|845
-3|846|846
-3|847|847
-3|848|848
-3|849|849
-3|850|850
-3|851|851
-3|852|852
-3|853|853
-3|854|854
-3|855|855
-3|856|856
-3|857|857
-3|858|858
-3|859|859
-3|860|860
-3|861|861
-3|862|862
-3|863|863
-3|864|864
-3|865|865
-3|866|866
-3|867|867
-3|868|868
-3|869|869
-3|870|870
-3|871|871
-3|872|872
-3|873|873
-3|874|874
-3|875|875
-3|876|876
-3|877|877
-3|878|878
-3|879|879
-3|880|880
-3|881|881
-3|882|882
-3|883|883
-3|884|884
-3|885|885
-3|886|886
-3|887|887
-3|888|888
-3|889|889
-3|890|890
-3|891|891
-3|892|892
-3|893|893
-3|894|894
-3|895|895
-3|896|896
-3|897|897
-3|898|898
-3|899|899
-3|900|900
-3|901|901
-3|902|902
-3|903|903
-3|904|904
-3|905|905
-3|906|906
-3|907|907
-3|908|908
-3|909|909
-3|910|910
-3|911|911
-3|912|912
-3|913|913
-3|914|914
-3|915|915
-3|916|916
-3|917|917
-3|918|918
-3|919|919
-3|920|920
-3|921|921
-3|922|922
-3|923|923
-3|924|924
-3|925|925
-3|926|926
-3|927|927
-3|928|928
-3|929|929
-3|930|930
-3|931|931
-3|932|932
-3|933|933
-3|934|934
-3|935|935
-3|936|936
-3|937|937
-3|938|938
-3|939|939
-3|940|940
-3|941|941
-3|942|942
-3|943|943
-3|944|944
-3|945|945
-3|946|946
-3|947|947
-3|948|948
-3|949|949
-3|950|950
-3|951|951
-3|952|952
-3|953|953
-3|954|954
-3|955|955
-3|956|956
-3|957|957
-3|958|958
-3|959|959
-3|960|960
-3|961|961
-3|962|962
-3|963|963
-3|964|964
-3|965|965
-3|966|966
-3|967|967
-3|968|968
-3|969|969
-3|970|970
-3|971|971
-3|972|972
-3|973|973
-3|974|974
-3|975|975
-3|976|976
-3|977|977
-3|978|978
-3|979|979
-3|980|980
-3|981|981
-3|982|982
-3|983|983
-3|984|984
-3|985|985
-3|986|986
-3|987|987
-3|988|988
-3|989|989
-3|990|990
-3|991|991
-3|992|992
-3|993|993
-3|994|994
-3|995|995
-3|996|996
-3|997|997
-3|998|998
-3|999|999
-3|1000|1000
-4|1|1
-4|2|2
-4|3|3
-4|4|4
-4|5|5
-4|6|6
-4|7|7
-4|8|8
-4|9|9
-4|10|10
-4|11|11
-4|12|12
-4|13|13
-4|14|14
-4|15|15
-4|16|16
-4|17|17
-4|18|18
-4|19|19
-4|20|20
-4|21|21
-4|22|22
-4|23|23
-4|24|24
-4|25|25
-4|26|26
-4|27|27
-4|28|28
-4|29|29
-4|30|30
-4|31|31
-4|32|32
-4|33|33
-4|34|34
-4|35|35
-4|36|36
-4|37|37
-4|38|38
-4|39|39
-4|40|40
-4|41|41
-4|42|42
-4|43|43
-4|44|44
-4|45|45
-4|46|46
-4|47|47
-4|48|48
-4|49|49
-4|50|50
-4|51|51
-4|52|52
-4|53|53
-4|54|54
-4|55|55
-4|56|56
-4|57|57
-4|58|58
-4|59|59
-4|60|60
-4|61|61
-4|62|62
-4|63|63
-4|64|64
-4|65|65
-4|66|66
-4|67|67
-4|68|68
-4|69|69
-4|70|70
-4|71|71
-4|72|72
-4|73|73
-4|74|74
-4|75|75
-4|76|76
-4|77|77
-4|78|78
-4|79|79
-4|80|80
-4|81|81
-4|82|82
-4|83|83
-4|84|84
-4|85|85
-4|86|86
-4|87|87
-4|88|88
-4|89|89
-4|90|90
-4|91|91
-4|92|92
-4|93|93
-4|94|94
-4|95|95
-4|96|96
-4|97|97
-4|98|98
-4|99|99
-4|100|100
-4|101|101
-4|102|102
-4|103|103
-4|104|104
-4|105|105
-4|106|106
-4|107|107
-4|108|108
-4|109|109
-4|110|110
-4|111|111
-4|112|112
-4|113|113
-4|114|114
-4|115|115
-4|116|116
-4|117|117
-4|118|118
-4|119|119
-4|120|120
-4|121|121
-4|122|122
-4|123|123
-4|124|124
-4|125|125
-4|126|126
-4|127|127
-4|128|128
-4|129|129
-4|130|130
-4|131|131
-4|132|132
-4|133|133
-4|134|134
-4|135|135
-4|136|136
-4|137|137
-4|138|138
-4|139|139
-4|140|140
-4|141|141
-4|142|142
-4|143|143
-4|144|144
-4|145|145
-4|146|146
-4|147|147
-4|148|148
-4|149|149
-4|150|150
-4|151|151
-4|152|152
-4|153|153
-4|154|154
-4|155|155
-4|156|156
-4|157|157
-4|158|158
-4|159|159
-4|160|160
-4|161|161
-4|162|162
-4|163|163
-4|164|164
-4|165|165
-4|166|166
-4|167|167
-4|168|168
-4|169|169
-4|170|170
-4|171|171
-4|172|172
-4|173|173
-4|174|174
-4|175|175
-4|176|176
-4|177|177
-4|178|178
-4|179|179
-4|180|180
-4|181|181
-4|182|182
-4|183|183
-4|184|184
-4|185|185
-4|186|186
-4|187|187
-4|188|188
-4|189|189
-4|190|190
-4|191|191
-4|192|192
-4|193|193
-4|194|194
-4|195|195
-4|196|196
-4|197|197
-4|198|198
-4|199|199
-4|200|200
-4|201|201
-4|202|202
-4|203|203
-4|204|204
-4|205|205
-4|206|206
-4|207|207
-4|208|208
-4|209|209
-4|210|210
-4|211|211
-4|212|212
-4|213|213
-4|214|214
-4|215|215
-4|216|216
-4|217|217
-4|218|218
-4|219|219
-4|220|220
-4|221|221
-4|222|222
-4|223|223
-4|224|224
-4|225|225
-4|226|226
-4|227|227
-4|228|228
-4|229|229
-4|230|230
-4|231|231
-4|232|232
-4|233|233
-4|234|234
-4|235|235
-4|236|236
-4|237|237
-4|238|238
-4|239|239
-4|240|240
-4|241|241
-4|242|242
-4|243|243
-4|244|244
-4|245|245
-4|246|246
-4|247|247
-4|248|248
-4|249|249
-4|250|250
-4|251|251
-4|252|252
-4|253|253
-4|254|254
-4|255|255
-4|256|256
-4|257|257
-4|258|258
-4|259|259
-4|260|260
-4|261|261
-4|262|262
-4|263|263
-4|264|264
-4|265|265
-4|266|266
-4|267|267
-4|268|268
-4|269|269
-4|270|270
-4|271|271
-4|272|272
-4|273|273
-4|274|274
-4|275|275
-4|276|276
-4|277|277
-4|278|278
-4|279|279
-4|280|280
-4|281|281
-4|282|282
-4|283|283
-4|284|284
-4|285|285
-4|286|286
-4|287|287
-4|288|288
-4|289|289
-4|290|290
-4|291|291
-4|292|292
-4|293|293
-4|294|294
-4|295|295
-4|296|296
-4|297|297
-4|298|298
-4|299|299
-4|300|300
-4|301|301
-4|302|302
-4|303|303
-4|304|304
-4|305|305
-4|306|306
-4|307|307
-4|308|308
-4|309|309
-4|310|310
-4|311|311
-4|312|312
-4|313|313
-4|314|314
-4|315|315
-4|316|316
-4|317|317
-4|318|318
-4|319|319
-4|320|320
-4|321|321
-4|322|322
-4|323|323
-4|324|324
-4|325|325
-4|326|326
-4|327|327
-4|328|328
-4|329|329
-4|330|330
-4|331|331
-4|332|332
-4|333|333
-4|334|334
-4|335|335
-4|336|336
-4|337|337
-4|338|338
-4|339|339
-4|340|340
-4|341|341
-4|342|342
-4|343|343
-4|344|344
-4|345|345
-4|346|346
-4|347|347
-4|348|348
-4|349|349
-4|350|350
-4|351|351
-4|352|352
-4|353|353
-4|354|354
-4|355|355
-4|356|356
-4|357|357
-4|358|358
-4|359|359
-4|360|360
-4|361|361
-4|362|362
-4|363|363
-4|364|364
-4|365|365
-4|366|366
-4|367|367
-4|368|368
-4|369|369
-4|370|370
-4|371|371
-4|372|372
-4|373|373
-4|374|374
-4|375|375
-4|376|376
-4|377|377
-4|378|378
-4|379|379
-4|380|380
-4|381|381
-4|382|382
-4|383|383
-4|384|384
-4|385|385
-4|386|386
-4|387|387
-4|388|388
-4|389|389
-4|390|390
-4|391|391
-4|392|392
-4|393|393
-4|394|394
-4|395|395
-4|396|396
-4|397|397
-4|398|398
-4|399|399
-4|400|400
-4|401|401
-4|402|402
-4|403|403
-4|404|404
-4|405|405
-4|406|406
-4|407|407
-4|408|408
-4|409|409
-4|410|410
-4|411|411
-4|412|412
-4|413|413
-4|414|414
-4|415|415
-4|416|416
-4|417|417
-4|418|418
-4|419|419
-4|420|420
-4|421|421
-4|422|422
-4|423|423
-4|424|424
-4|425|425
-4|426|426
-4|427|427
-4|428|428
-4|429|429
-4|430|430
-4|431|431
-4|432|432
-4|433|433
-4|434|434
-4|435|435
-4|436|436
-4|437|437
-4|438|438
-4|439|439
-4|440|440
-4|441|441
-4|442|442
-4|443|443
-4|444|444
-4|445|445
-4|446|446
-4|447|447
-4|448|448
-4|449|449
-4|450|450
-4|451|451
-4|452|452
-4|453|453
-4|454|454
-4|455|455
-4|456|456
-4|457|457
-4|458|458
-4|459|459
-4|460|460
-4|461|461
-4|462|462
-4|463|463
-4|464|464
-4|465|465
-4|466|466
-4|467|467
-4|468|468
-4|469|469
-4|470|470
-4|471|471
-4|472|472
-4|473|473
-4|474|474
-4|475|475
-4|476|476
-4|477|477
-4|478|478
-4|479|479
-4|480|480
-4|481|481
-4|482|482
-4|483|483
-4|484|484
-4|485|485
-4|486|486
-4|487|487
-4|488|488
-4|489|489
-4|490|490
-4|491|491
-4|492|492
-4|493|493
-4|494|494
-4|495|495
-4|496|496
-4|497|497
-4|498|498
-4|499|499
-4|500|500
-4|501|501
-4|502|502
-4|503|503
-4|504|504
-4|505|505
-4|506|506
-4|507|507
-4|508|508
-4|509|509
-4|510|510
-4|511|511
-4|512|512
-4|513|513
-4|514|514
-4|515|515
-4|516|516
-4|517|517
-4|518|518
-4|519|519
-4|520|520
-4|521|521
-4|522|522
-4|523|523
-4|524|524
-4|525|525
-4|526|526
-4|527|527
-4|528|528
-4|529|529
-4|530|530
-4|531|531
-4|532|532
-4|533|533
-4|534|534
-4|535|535
-4|536|536
-4|537|537
-4|538|538
-4|539|539
-4|540|540
-4|541|541
-4|542|542
-4|543|543
-4|544|544
-4|545|545
-4|546|546
-4|547|547
-4|548|548
-4|549|549
-4|550|550
-4|551|551
-4|552|552
-4|553|553
-4|554|554
-4|555|555
-4|556|556
-4|557|557
-4|558|558
-4|559|559
-4|560|560
-4|561|561
-4|562|562
-4|563|563
-4|564|564
-4|565|565
-4|566|566
-4|567|567
-4|568|568
-4|569|569
-4|570|570
-4|571|571
-4|572|572
-4|573|573
-4|574|574
-4|575|575
-4|576|576
-4|577|577
-4|578|578
-4|579|579
-4|580|580
-4|581|581
-4|582|582
-4|583|583
-4|584|584
-4|585|585
-4|586|586
-4|587|587
-4|588|588
-4|589|589
-4|590|590
-4|591|591
-4|592|592
-4|593|593
-4|594|594
-4|595|595
-4|596|596
-4|597|597
-4|598|598
-4|599|599
-4|600|600
-4|601|601
-4|602|602
-4|603|603
-4|604|604
-4|605|605
-4|606|606
-4|607|607
-4|608|608
-4|609|609
-4|610|610
-4|611|611
-4|612|612
-4|613|613
-4|614|614
-4|615|615
-4|616|616
-4|617|617
-4|618|618
-4|619|619
-4|620|620
-4|621|621
-4|622|622
-4|623|623
-4|624|624
-4|625|625
-4|626|626
-4|627|627
-4|628|628
-4|629|629
-4|630|630
-4|631|631
-4|632|632
-4|633|633
-4|634|634
-4|635|635
-4|636|636
-4|637|637
-4|638|638
-4|639|639
-4|640|640
-4|641|641
-4|642|642
-4|643|643
-4|644|644
-4|645|645
-4|646|646
-4|647|647
-4|648|648
-4|649|649
-4|650|650
-4|651|651
-4|652|652
-4|653|653
-4|654|654
-4|655|655
-4|656|656
-4|657|657
-4|658|658
-4|659|659
-4|660|660
-4|661|661
-4|662|662
-4|663|663
-4|664|664
-4|665|665
-4|666|666
-4|667|667
-4|668|668
-4|669|669
-4|670|670
-4|671|671
-4|672|672
-4|673|673
-4|674|674
-4|675|675
-4|676|676
-4|677|677
-4|678|678
-4|679|679
-4|680|680
-4|681|681
-4|682|682
-4|683|683
-4|684|684
-4|685|685
-4|686|686
-4|687|687
-4|688|688
-4|689|689
-4|690|690
-4|691|691
-4|692|692
-4|693|693
-4|694|694
-4|695|695
-4|696|696
-4|697|697
-4|698|698
-4|699|699
-4|700|700
-4|701|701
-4|702|702
-4|703|703
-4|704|704
-4|705|705
-4|706|706
-4|707|707
-4|708|708
-4|709|709
-4|710|710
-4|711|711
-4|712|712
-4|713|713
-4|714|714
-4|715|715
-4|716|716
-4|717|717
-4|718|718
-4|719|719
-4|720|720
-4|721|721
-4|722|722
-4|723|723
-4|724|724
-4|725|725
-4|726|726
-4|727|727
-4|728|728
-4|729|729
-4|730|730
-4|731|731
-4|732|732
-4|733|733
-4|734|734
-4|735|735
-4|736|736
-4|737|737
-4|738|738
-4|739|739
-4|740|740
-4|741|741
-4|742|742
-4|743|743
-4|744|744
-4|745|745
-4|746|746
-4|747|747
-4|748|748
-4|749|749
-4|750|750
-4|751|751
-4|752|752
-4|753|753
-4|754|754
-4|755|755
-4|756|756
-4|757|757
-4|758|758
-4|759|759
-4|760|760
-4|761|761
-4|762|762
-4|763|763
-4|764|764
-4|765|765
-4|766|766
-4|767|767
-4|768|768
-4|769|769
-4|770|770
-4|771|771
-4|772|772
-4|773|773
-4|774|774
-4|775|775
-4|776|776
-4|777|777
-4|778|778
-4|779|779
-4|780|780
-4|781|781
-4|782|782
-4|783|783
-4|784|784
-4|785|785
-4|786|786
-4|787|787
-4|788|788
-4|789|789
-4|790|790
-4|791|791
-4|792|792
-4|793|793
-4|794|794
-4|795|795
-4|796|796
-4|797|797
-4|798|798
-4|799|799
-4|800|800
-4|801|801
-4|802|802
-4|803|803
-4|804|804
-4|805|805
-4|806|806
-4|807|807
-4|808|808
-4|809|809
-4|810|810
-4|811|811
-4|812|812
-4|813|813
-4|814|814
-4|815|815
-4|816|816
-4|817|817
-4|818|818
-4|819|819
-4|820|820
-4|821|821
-4|822|822
-4|823|823
-4|824|824
-4|825|825
-4|826|826
-4|827|827
-4|828|828
-4|829|829
-4|830|830
-4|831|831
-4|832|832
-4|833|833
-4|834|834
-4|835|835
-4|836|836
-4|837|837
-4|838|838
-4|839|839
-4|840|840
-4|841|841
-4|842|842
-4|843|843
-4|844|844
-4|845|845
-4|846|846
-4|847|847
-4|848|848
-4|849|849
-4|850|850
-4|851|851
-4|852|852
-4|853|853
-4|854|854
-4|855|855
-4|856|856
-4|857|857
-4|858|858
-4|859|859
-4|860|860
-4|861|861
-4|862|862
-4|863|863
-4|864|864
-4|865|865
-4|866|866
-4|867|867
-4|868|868
-4|869|869
-4|870|870
-4|871|871
-4|872|872
-4|873|873
-4|874|874
-4|875|875
-4|876|876
-4|877|877
-4|878|878
-4|879|879
-4|880|880
-4|881|881
-4|882|882
-4|883|883
-4|884|884
-4|885|885
-4|886|886
-4|887|887
-4|888|888
-4|889|889
-4|890|890
-4|891|891
-4|892|892
-4|893|893
-4|894|894
-4|895|895
-4|896|896
-4|897|897
-4|898|898
-4|899|899
-4|900|900
-4|901|901
-4|902|902
-4|903|903
-4|904|904
-4|905|905
-4|906|906
-4|907|907
-4|908|908
-4|909|909
-4|910|910
-4|911|911
-4|912|912
-4|913|913
-4|914|914
-4|915|915
-4|916|916
-4|917|917
-4|918|918
-4|919|919
-4|920|920
-4|921|921
-4|922|922
-4|923|923
-4|924|924
-4|925|925
-4|926|926
-4|927|927
-4|928|928
-4|929|929
-4|930|930
-4|931|931
-4|932|932
-4|933|933
-4|934|934
-4|935|935
-4|936|936
-4|937|937
-4|938|938
-4|939|939
-4|940|940
-4|941|941
-4|942|942
-4|943|943
-4|944|944
-4|945|945
-4|946|946
-4|947|947
-4|948|948
-4|949|949
-4|950|950
-4|951|951
-4|952|952
-4|953|953
-4|954|954
-4|955|955
-4|956|956
-4|957|957
-4|958|958
-4|959|959
-4|960|960
-4|961|961
-4|962|962
-4|963|963
-4|964|964
-4|965|965
-4|966|966
-4|967|967
-4|968|968
-4|969|969
-4|970|970
-4|971|971
-4|972|972
-4|973|973
-4|974|974
-4|975|975
-4|976|976
-4|977|977
-4|978|978
-4|979|979
-4|980|980
-4|981|981
-4|982|982
-4|983|983
-4|984|984
-4|985|985
-4|986|986
-4|987|987
-4|988|988
-4|989|989
-4|990|990
-4|991|991
-4|992|992
-4|993|993
-4|994|994
-4|995|995
-4|996|996
-4|997|997
-4|998|998
-4|999|999
-4|1000|1000
-5|1|1
-5|2|2
-5|3|3
-5|4|4
-5|5|5
-5|6|6
-5|7|7
-5|8|8
-5|9|9
-5|10|10
-5|11|11
-5|12|12
-5|13|13
-5|14|14
-5|15|15
-5|16|16
-5|17|17
-5|18|18
-5|19|19
-5|20|20
-5|21|21
-5|22|22
-5|23|23
-5|24|24
-5|25|25
-5|26|26
-5|27|27
-5|28|28
-5|29|29
-5|30|30
-5|31|31
-5|32|32
-5|33|33
-5|34|34
-5|35|35
-5|36|36
-5|37|37
-5|38|38
-5|39|39
-5|40|40
-5|41|41
-5|42|42
-5|43|43
-5|44|44
-5|45|45
-5|46|46
-5|47|47
-5|48|48
-5|49|49
-5|50|50
-5|51|51
-5|52|52
-5|53|53
-5|54|54
-5|55|55
-5|56|56
-5|57|57
-5|58|58
-5|59|59
-5|60|60
-5|61|61
-5|62|62
-5|63|63
-5|64|64
-5|65|65
-5|66|66
-5|67|67
-5|68|68
-5|69|69
-5|70|70
-5|71|71
-5|72|72
-5|73|73
-5|74|74
-5|75|75
-5|76|76
-5|77|77
-5|78|78
-5|79|79
-5|80|80
-5|81|81
-5|82|82
-5|83|83
-5|84|84
-5|85|85
-5|86|86
-5|87|87
-5|88|88
-5|89|89
-5|90|90
-5|91|91
-5|92|92
-5|93|93
-5|94|94
-5|95|95
-5|96|96
-5|97|97
-5|98|98
-5|99|99
-5|100|100
-5|101|101
-5|102|102
-5|103|103
-5|104|104
-5|105|105
-5|106|106
-5|107|107
-5|108|108
-5|109|109
-5|110|110
-5|111|111
-5|112|112
-5|113|113
-5|114|114
-5|115|115
-5|116|116
-5|117|117
-5|118|118
-5|119|119
-5|120|120
-5|121|121
-5|122|122
-5|123|123
-5|124|124
-5|125|125
-5|126|126
-5|127|127
-5|128|128
-5|129|129
-5|130|130
-5|131|131
-5|132|132
-5|133|133
-5|134|134
-5|135|135
-5|136|136
-5|137|137
-5|138|138
-5|139|139
-5|140|140
-5|141|141
-5|142|142
-5|143|143
-5|144|144
-5|145|145
-5|146|146
-5|147|147
-5|148|148
-5|149|149
-5|150|150
-5|151|151
-5|152|152
-5|153|153
-5|154|154
-5|155|155
-5|156|156
-5|157|157
-5|158|158
-5|159|159
-5|160|160
-5|161|161
-5|162|162
-5|163|163
-5|164|164
-5|165|165
-5|166|166
-5|167|167
-5|168|168
-5|169|169
-5|170|170
-5|171|171
-5|172|172
-5|173|173
-5|174|174
-5|175|175
-5|176|176
-5|177|177
-5|178|178
-5|179|179
-5|180|180
-5|181|181
-5|182|182
-5|183|183
-5|184|184
-5|185|185
-5|186|186
-5|187|187
-5|188|188
-5|189|189
-5|190|190
-5|191|191
-5|192|192
-5|193|193
-5|194|194
-5|195|195
-5|196|196
-5|197|197
-5|198|198
-5|199|199
-5|200|200
-5|201|201
-5|202|202
-5|203|203
-5|204|204
-5|205|205
-5|206|206
-5|207|207
-5|208|208
-5|209|209
-5|210|210
-5|211|211
-5|212|212
-5|213|213
-5|214|214
-5|215|215
-5|216|216
-5|217|217
-5|218|218
-5|219|219
-5|220|220
-5|221|221
-5|222|222
-5|223|223
-5|224|224
-5|225|225
-5|226|226
-5|227|227
-5|228|228
-5|229|229
-5|230|230
-5|231|231
-5|232|232
-5|233|233
-5|234|234
-5|235|235
-5|236|236
-5|237|237
-5|238|238
-5|239|239
-5|240|240
-5|241|241
-5|242|242
-5|243|243
-5|244|244
-5|245|245
-5|246|246
-5|247|247
-5|248|248
-5|249|249
-5|250|250
-5|251|251
-5|252|252
-5|253|253
-5|254|254
-5|255|255
-5|256|256
-5|257|257
-5|258|258
-5|259|259
-5|260|260
-5|261|261
-5|262|262
-5|263|263
-5|264|264
-5|265|265
-5|266|266
-5|267|267
-5|268|268
-5|269|269
-5|270|270
-5|271|271
-5|272|272
-5|273|273
-5|274|274
-5|275|275
-5|276|276
-5|277|277
-5|278|278
-5|279|279
-5|280|280
-5|281|281
-5|282|282
-5|283|283
-5|284|284
-5|285|285
-5|286|286
-5|287|287
-5|288|288
-5|289|289
-5|290|290
-5|291|291
-5|292|292
-5|293|293
-5|294|294
-5|295|295
-5|296|296
-5|297|297
-5|298|298
-5|299|299
-5|300|300
-5|301|301
-5|302|302
-5|303|303
-5|304|304
-5|305|305
-5|306|306
-5|307|307
-5|308|308
-5|309|309
-5|310|310
-5|311|311
-5|312|312
-5|313|313
-5|314|314
-5|315|315
-5|316|316
-5|317|317
-5|318|318
-5|319|319
-5|320|320
-5|321|321
-5|322|322
-5|323|323
-5|324|324
-5|325|325
-5|326|326
-5|327|327
-5|328|328
-5|329|329
-5|330|330
-5|331|331
-5|332|332
-5|333|333
-5|334|334
-5|335|335
-5|336|336
-5|337|337
-5|338|338
-5|339|339
-5|340|340
-5|341|341
-5|342|342
-5|343|343
-5|344|344
-5|345|345
-5|346|346
-5|347|347
-5|348|348
-5|349|349
-5|350|350
-5|351|351
-5|352|352
-5|353|353
-5|354|354
-5|355|355
-5|356|356
-5|357|357
-5|358|358
-5|359|359
-5|360|360
-5|361|361
-5|362|362
-5|363|363
-5|364|364
-5|365|365
-5|366|366
-5|367|367
-5|368|368
-5|369|369
-5|370|370
-5|371|371
-5|372|372
-5|373|373
-5|374|374
-5|375|375
-5|376|376
-5|377|377
-5|378|378
-5|379|379
-5|380|380
-5|381|381
-5|382|382
-5|383|383
-5|384|384
-5|385|385
-5|386|386
-5|387|387
-5|388|388
-5|389|389
-5|390|390
-5|391|391
-5|392|392
-5|393|393
-5|394|394
-5|395|395
-5|396|396
-5|397|397
-5|398|398
-5|399|399
-5|400|400
-5|401|401
-5|402|402
-5|403|403
-5|404|404
-5|405|405
-5|406|406
-5|407|407
-5|408|408
-5|409|409
-5|410|410
-5|411|411
-5|412|412
-5|413|413
-5|414|414
-5|415|415
-5|416|416
-5|417|417
-5|418|418
-5|419|419
-5|420|420
-5|421|421
-5|422|422
-5|423|423
-5|424|424
-5|425|425
-5|426|426
-5|427|427
-5|428|428
-5|429|429
-5|430|430
-5|431|431
-5|432|432
-5|433|433
-5|434|434
-5|435|435
-5|436|436
-5|437|437
-5|438|438
-5|439|439
-5|440|440
-5|441|441
-5|442|442
-5|443|443
-5|444|444
-5|445|445
-5|446|446
-5|447|447
-5|448|448
-5|449|449
-5|450|450
-5|451|451
-5|452|452
-5|453|453
-5|454|454
-5|455|455
-5|456|456
-5|457|457
-5|458|458
-5|459|459
-5|460|460
-5|461|461
-5|462|462
-5|463|463
-5|464|464
-5|465|465
-5|466|466
-5|467|467
-5|468|468
-5|469|469
-5|470|470
-5|471|471
-5|472|472
-5|473|473
-5|474|474
-5|475|475
-5|476|476
-5|477|477
-5|478|478
-5|479|479
-5|480|480
-5|481|481
-5|482|482
-5|483|483
-5|484|484
-5|485|485
-5|486|486
-5|487|487
-5|488|488
-5|489|489
-5|490|490
-5|491|491
-5|492|492
-5|493|493
-5|494|494
-5|495|495
-5|496|496
-5|497|497
-5|498|498
-5|499|499
-5|500|500
-5|501|501
-5|502|502
-5|503|503
-5|504|504
-5|505|505
-5|506|506
-5|507|507
-5|508|508
-5|509|509
-5|510|510
-5|511|511
-5|512|512
-5|513|513
-5|514|514
-5|515|515
-5|516|516
-5|517|517
-5|518|518
-5|519|519
-5|520|520
-5|521|521
-5|522|522
-5|523|523
-5|524|524
-5|525|525
-5|526|526
-5|527|527
-5|528|528
-5|529|529
-5|530|530
-5|531|531
-5|532|532
-5|533|533
-5|534|534
-5|535|535
-5|536|536
-5|537|537
-5|538|538
-5|539|539
-5|540|540
-5|541|541
-5|542|542
-5|543|543
-5|544|544
-5|545|545
-5|546|546
-5|547|547
-5|548|548
-5|549|549
-5|550|550
-5|551|551
-5|552|552
-5|553|553
-5|554|554
-5|555|555
-5|556|556
-5|557|557
-5|558|558
-5|559|559
-5|560|560
-5|561|561
-5|562|562
-5|563|563
-5|564|564
-5|565|565
-5|566|566
-5|567|567
-5|568|568
-5|569|569
-5|570|570
-5|571|571
-5|572|572
-5|573|573
-5|574|574
-5|575|575
-5|576|576
-5|577|577
-5|578|578
-5|579|579
-5|580|580
-5|581|581
-5|582|582
-5|583|583
-5|584|584
-5|585|585
-5|586|586
-5|587|587
-5|588|588
-5|589|589
-5|590|590
-5|591|591
-5|592|592
-5|593|593
-5|594|594
-5|595|595
-5|596|596
-5|597|597
-5|598|598
-5|599|599
-5|600|600
-5|601|601
-5|602|602
-5|603|603
-5|604|604
-5|605|605
-5|606|606
-5|607|607
-5|608|608
-5|609|609
-5|610|610
-5|611|611
-5|612|612
-5|613|613
-5|614|614
-5|615|615
-5|616|616
-5|617|617
-5|618|618
-5|619|619
-5|620|620
-5|621|621
-5|622|622
-5|623|623
-5|624|624
-5|625|625
-5|626|626
-5|627|627
-5|628|628
-5|629|629
-5|630|630
-5|631|631
-5|632|632
-5|633|633
-5|634|634
-5|635|635
-5|636|636
-5|637|637
-5|638|638
-5|639|639
-5|640|640
-5|641|641
-5|642|642
-5|643|643
-5|644|644
-5|645|645
-5|646|646
-5|647|647
-5|648|648
-5|649|649
-5|650|650
-5|651|651
-5|652|652
-5|653|653
-5|654|654
-5|655|655
-5|656|656
-5|657|657
-5|658|658
-5|659|659
-5|660|660
-5|661|661
-5|662|662
-5|663|663
-5|664|664
-5|665|665
-5|666|666
-5|667|667
-5|668|668
-5|669|669
-5|670|670
-5|671|671
-5|672|672
-5|673|673
-5|674|674
-5|675|675
-5|676|676
-5|677|677
-5|678|678
-5|679|679
-5|680|680
-5|681|681
-5|682|682
-5|683|683
-5|684|684
-5|685|685
-5|686|686
-5|687|687
-5|688|688
-5|689|689
-5|690|690
-5|691|691
-5|692|692
-5|693|693
-5|694|694
-5|695|695
-5|696|696
-5|697|697
-5|698|698
-5|699|699
-5|700|700
-5|701|701
-5|702|702
-5|703|703
-5|704|704
-5|705|705
-5|706|706
-5|707|707
-5|708|708
-5|709|709
-5|710|710
-5|711|711
-5|712|712
-5|713|713
-5|714|714
-5|715|715
-5|716|716
-5|717|717
-5|718|718
-5|719|719
-5|720|720
-5|721|721
-5|722|722
-5|723|723
-5|724|724
-5|725|725
-5|726|726
-5|727|727
-5|728|728
-5|729|729
-5|730|730
-5|731|731
-5|732|732
-5|733|733
-5|734|734
-5|735|735
-5|736|736
-5|737|737
-5|738|738
-5|739|739
-5|740|740
-5|741|741
-5|742|742
-5|743|743
-5|744|744
-5|745|745
-5|746|746
-5|747|747
-5|748|748
-5|749|749
-5|750|750
-5|751|751
-5|752|752
-5|753|753
-5|754|754
-5|755|755
-5|756|756
-5|757|757
-5|758|758
-5|759|759
-5|760|760
-5|761|761
-5|762|762
-5|763|763
-5|764|764
-5|765|765
-5|766|766
-5|767|767
-5|768|768
-5|769|769
-5|770|770
-5|771|771
-5|772|772
-5|773|773
-5|774|774
-5|775|775
-5|776|776
-5|777|777
-5|778|778
-5|779|779
-5|780|780
-5|781|781
-5|782|782
-5|783|783
-5|784|784
-5|785|785
-5|786|786
-5|787|787
-5|788|788
-5|789|789
-5|790|790
-5|791|791
-5|792|792
-5|793|793
-5|794|794
-5|795|795
-5|796|796
-5|797|797
-5|798|798
-5|799|799
-5|800|800
-5|801|801
-5|802|802
-5|803|803
-5|804|804
-5|805|805
-5|806|806
-5|807|807
-5|808|808
-5|809|809
-5|810|810
-5|811|811
-5|812|812
-5|813|813
-5|814|814
-5|815|815
-5|816|816
-5|817|817
-5|818|818
-5|819|819
-5|820|820
-5|821|821
-5|822|822
-5|823|823
-5|824|824
-5|825|825
-5|826|826
-5|827|827
-5|828|828
-5|829|829
-5|830|830
-5|831|831
-5|832|832
-5|833|833
-5|834|834
-5|835|835
-5|836|836
-5|837|837
-5|838|838
-5|839|839
-5|840|840
-5|841|841
-5|842|842
-5|843|843
-5|844|844
-5|845|845
-5|846|846
-5|847|847
-5|848|848
-5|849|849
-5|850|850
-5|851|851
-5|852|852
-5|853|853
-5|854|854
-5|855|855
-5|856|856
-5|857|857
-5|858|858
-5|859|859
-5|860|860
-5|861|861
-5|862|862
-5|863|863
-5|864|864
-5|865|865
-5|866|866
-5|867|867
-5|868|868
-5|869|869
-5|870|870
-5|871|871
-5|872|872
-5|873|873
-5|874|874
-5|875|875
-5|876|876
-5|877|877
-5|878|878
-5|879|879
-5|880|880
-5|881|881
-5|882|882
-5|883|883
-5|884|884
-5|885|885
-5|886|886
-5|887|887
-5|888|888
-5|889|889
-5|890|890
-5|891|891
-5|892|892
-5|893|893
-5|894|894
-5|895|895
-5|896|896
-5|897|897
-5|898|898
-5|899|899
-5|900|900
-5|901|901
-5|902|902
-5|903|903
-5|904|904
-5|905|905
-5|906|906
-5|907|907
-5|908|908
-5|909|909
-5|910|910
-5|911|911
-5|912|912
-5|913|913
-5|914|914
-5|915|915
-5|916|916
-5|917|917
-5|918|918
-5|919|919
-5|920|920
-5|921|921
-5|922|922
-5|923|923
-5|924|924
-5|925|925
-5|926|926
-5|927|927
-5|928|928
-5|929|929
-5|930|930
-5|931|931
-5|932|932
-5|933|933
-5|934|934
-5|935|935
-5|936|936
-5|937|937
-5|938|938
-5|939|939
-5|940|940
-5|941|941
-5|942|942
-5|943|943
-5|944|944
-5|945|945
-5|946|946
-5|947|947
-5|948|948
-5|949|949
-5|950|950
-5|951|951
-5|952|952
-5|953|953
-5|954|954
-5|955|955
-5|956|956
-5|957|957
-5|958|958
-5|959|959
-5|960|960
-5|961|961
-5|962|962
-5|963|963
-5|964|964
-5|965|965
-5|966|966
-5|967|967
-5|968|968
-5|969|969
-5|970|970
-5|971|971
-5|972|972
-5|973|973
-5|974|974
-5|975|975
-5|976|976
-5|977|977
-5|978|978
-5|979|979
-5|980|980
-5|981|981
-5|982|982
-5|983|983
-5|984|984
-5|985|985
-5|986|986
-5|987|987
-5|988|988
-5|989|989
-5|990|990
-5|991|991
-5|992|992
-5|993|993
-5|994|994
-5|995|995
-5|996|996
-5|997|997
-5|998|998
-5|999|999
-5|1000|1000
-6|1|1
-6|2|2
-6|3|3
-6|4|4
-6|5|5
-6|6|6
-6|7|7
-6|8|8
-6|9|9
-6|10|10
-6|11|11
-6|12|12
-6|13|13
-6|14|14
-6|15|15
-6|16|16
-6|17|17
-6|18|18
-6|19|19
-6|20|20
-6|21|21
-6|22|22
-6|23|23
-6|24|24
-6|25|25
-6|26|26
-6|27|27
-6|28|28
-6|29|29
-6|30|30
-6|31|31
-6|32|32
-6|33|33
-6|34|34
-6|35|35
-6|36|36
-6|37|37
-6|38|38
-6|39|39
-6|40|40
-6|41|41
-6|42|42
-6|43|43
-6|44|44
-6|45|45
-6|46|46
-6|47|47
-6|48|48
-6|49|49
-6|50|50
-6|51|51
-6|52|52
-6|53|53
-6|54|54
-6|55|55
-6|56|56
-6|57|57
-6|58|58
-6|59|59
-6|60|60
-6|61|61
-6|62|62
-6|63|63
-6|64|64
-6|65|65
-6|66|66
-6|67|67
-6|68|68
-6|69|69
-6|70|70
-6|71|71
-6|72|72
-6|73|73
-6|74|74
-6|75|75
-6|76|76
-6|77|77
-6|78|78
-6|79|79
-6|80|80
-6|81|81
-6|82|82
-6|83|83
-6|84|84
-6|85|85
-6|86|86
-6|87|87
-6|88|88
-6|89|89
-6|90|90
-6|91|91
-6|92|92
-6|93|93
-6|94|94
-6|95|95
-6|96|96
-6|97|97
-6|98|98
-6|99|99
-6|100|100
-6|101|101
-6|102|102
-6|103|103
-6|104|104
-6|105|105
-6|106|106
-6|107|107
-6|108|108
-6|109|109
-6|110|110
-6|111|111
-6|112|112
-6|113|113
-6|114|114
-6|115|115
-6|116|116
-6|117|117
-6|118|118
-6|119|119
-6|120|120
-6|121|121
-6|122|122
-6|123|123
-6|124|124
-6|125|125
-6|126|126
-6|127|127
-6|128|128
-6|129|129
-6|130|130
-6|131|131
-6|132|132
-6|133|133
-6|134|134
-6|135|135
-6|136|136
-6|137|137
-6|138|138
-6|139|139
-6|140|140
-6|141|141
-6|142|142
-6|143|143
-6|144|144
-6|145|145
-6|146|146
-6|147|147
-6|148|148
-6|149|149
-6|150|150
-6|151|151
-6|152|152
-6|153|153
-6|154|154
-6|155|155
-6|156|156
-6|157|157
-6|158|158
-6|159|159
-6|160|160
-6|161|161
-6|162|162
-6|163|163
-6|164|164
-6|165|165
-6|166|166
-6|167|167
-6|168|168
-6|169|169
-6|170|170
-6|171|171
-6|172|172
-6|173|173
-6|174|174
-6|175|175
-6|176|176
-6|177|177
-6|178|178
-6|179|179
-6|180|180
-6|181|181
-6|182|182
-6|183|183
-6|184|184
-6|185|185
-6|186|186
-6|187|187
-6|188|188
-6|189|189
-6|190|190
-6|191|191
-6|192|192
-6|193|193
-6|194|194
-6|195|195
-6|196|196
-6|197|197
-6|198|198
-6|199|199
-6|200|200
-6|201|201
-6|202|202
-6|203|203
-6|204|204
-6|205|205
-6|206|206
-6|207|207
-6|208|208
-6|209|209
-6|210|210
-6|211|211
-6|212|212
-6|213|213
-6|214|214
-6|215|215
-6|216|216
-6|217|217
-6|218|218
-6|219|219
-6|220|220
-6|221|221
-6|222|222
-6|223|223
-6|224|224
-6|225|225
-6|226|226
-6|227|227
-6|228|228
-6|229|229
-6|230|230
-6|231|231
-6|232|232
-6|233|233
-6|234|234
-6|235|235
-6|236|236
-6|237|237
-6|238|238
-6|239|239
-6|240|240
-6|241|241
-6|242|242
-6|243|243
-6|244|244
-6|245|245
-6|246|246
-6|247|247
-6|248|248
-6|249|249
-6|250|250
-6|251|251
-6|252|252
-6|253|253
-6|254|254
-6|255|255
-6|256|256
-6|257|257
-6|258|258
-6|259|259
-6|260|260
-6|261|261
-6|262|262
-6|263|263
-6|264|264
-6|265|265
-6|266|266
-6|267|267
-6|268|268
-6|269|269
-6|270|270
-6|271|271
-6|272|272
-6|273|273
-6|274|274
-6|275|275
-6|276|276
-6|277|277
-6|278|278
-6|279|279
-6|280|280
-6|281|281
-6|282|282
-6|283|283
-6|284|284
-6|285|285
-6|286|286
-6|287|287
-6|288|288
-6|289|289
-6|290|290
-6|291|291
-6|292|292
-6|293|293
-6|294|294
-6|295|295
-6|296|296
-6|297|297
-6|298|298
-6|299|299
-6|300|300
-6|301|301
-6|302|302
-6|303|303
-6|304|304
-6|305|305
-6|306|306
-6|307|307
-6|308|308
-6|309|309
-6|310|310
-6|311|311
-6|312|312
-6|313|313
-6|314|314
-6|315|315
-6|316|316
-6|317|317
-6|318|318
-6|319|319
-6|320|320
-6|321|321
-6|322|322
-6|323|323
-6|324|324
-6|325|325
-6|326|326
-6|327|327
-6|328|328
-6|329|329
-6|330|330
-6|331|331
-6|332|332
-6|333|333
-6|334|334
-6|335|335
-6|336|336
-6|337|337
-6|338|338
-6|339|339
-6|340|340
-6|341|341
-6|342|342
-6|343|343
-6|344|344
-6|345|345
-6|346|346
-6|347|347
-6|348|348
-6|349|349
-6|350|350
-6|351|351
-6|352|352
-6|353|353
-6|354|354
-6|355|355
-6|356|356
-6|357|357
-6|358|358
-6|359|359
-6|360|360
-6|361|361
-6|362|362
-6|363|363
-6|364|364
-6|365|365
-6|366|366
-6|367|367
-6|368|368
-6|369|369
-6|370|370
-6|371|371
-6|372|372
-6|373|373
-6|374|374
-6|375|375
-6|376|376
-6|377|377
-6|378|378
-6|379|379
-6|380|380
-6|381|381
-6|382|382
-6|383|383
-6|384|384
-6|385|385
-6|386|386
-6|387|387
-6|388|388
-6|389|389
-6|390|390
-6|391|391
-6|392|392
-6|393|393
-6|394|394
-6|395|395
-6|396|396
-6|397|397
-6|398|398
-6|399|399
-6|400|400
-6|401|401
-6|402|402
-6|403|403
-6|404|404
-6|405|405
-6|406|406
-6|407|407
-6|408|408
-6|409|409
-6|410|410
-6|411|411
-6|412|412
-6|413|413
-6|414|414
-6|415|415
-6|416|416
-6|417|417
-6|418|418
-6|419|419
-6|420|420
-6|421|421
-6|422|422
-6|423|423
-6|424|424
-6|425|425
-6|426|426
-6|427|427
-6|428|428
-6|429|429
-6|430|430
-6|431|431
-6|432|432
-6|433|433
-6|434|434
-6|435|435
-6|436|436
-6|437|437
-6|438|438
-6|439|439
-6|440|440
-6|441|441
-6|442|442
-6|443|443
-6|444|444
-6|445|445
-6|446|446
-6|447|447
-6|448|448
-6|449|449
-6|450|450
-6|451|451
-6|452|452
-6|453|453
-6|454|454
-6|455|455
-6|456|456
-6|457|457
-6|458|458
-6|459|459
-6|460|460
-6|461|461
-6|462|462
-6|463|463
-6|464|464
-6|465|465
-6|466|466
-6|467|467
-6|468|468
-6|469|469
-6|470|470
-6|471|471
-6|472|472
-6|473|473
-6|474|474
-6|475|475
-6|476|476
-6|477|477
-6|478|478
-6|479|479
-6|480|480
-6|481|481
-6|482|482
-6|483|483
-6|484|484
-6|485|485
-6|486|486
-6|487|487
-6|488|488
-6|489|489
-6|490|490
-6|491|491
-6|492|492
-6|493|493
-6|494|494
-6|495|495
-6|496|496
-6|497|497
-6|498|498
-6|499|499
-6|500|500
-6|501|501
-6|502|502
-6|503|503
-6|504|504
-6|505|505
-6|506|506
-6|507|507
-6|508|508
-6|509|509
-6|510|510
-6|511|511
-6|512|512
-6|513|513
-6|514|514
-6|515|515
-6|516|516
-6|517|517
-6|518|518
-6|519|519
-6|520|520
-6|521|521
-6|522|522
-6|523|523
-6|524|524
-6|525|525
-6|526|526
-6|527|527
-6|528|528
-6|529|529
-6|530|530
-6|531|531
-6|532|532
-6|533|533
-6|534|534
-6|535|535
-6|536|536
-6|537|537
-6|538|538
-6|539|539
-6|540|540
-6|541|541
-6|542|542
-6|543|543
-6|544|544
-6|545|545
-6|546|546
-6|547|547
-6|548|548
-6|549|549
-6|550|550
-6|551|551
-6|552|552
-6|553|553
-6|554|554
-6|555|555
-6|556|556
-6|557|557
-6|558|558
-6|559|559
-6|560|560
-6|561|561
-6|562|562
-6|563|563
-6|564|564
-6|565|565
-6|566|566
-6|567|567
-6|568|568
-6|569|569
-6|570|570
-6|571|571
-6|572|572
-6|573|573
-6|574|574
-6|575|575
-6|576|576
-6|577|577
-6|578|578
-6|579|579
-6|580|580
-6|581|581
-6|582|582
-6|583|583
-6|584|584
-6|585|585
-6|586|586
-6|587|587
-6|588|588
-6|589|589
-6|590|590
-6|591|591
-6|592|592
-6|593|593
-6|594|594
-6|595|595
-6|596|596
-6|597|597
-6|598|598
-6|599|599
-6|600|600
-6|601|601
-6|602|602
-6|603|603
-6|604|604
-6|605|605
-6|606|606
-6|607|607
-6|608|608
-6|609|609
-6|610|610
-6|611|611
-6|612|612
-6|613|613
-6|614|614
-6|615|615
-6|616|616
-6|617|617
-6|618|618
-6|619|619
-6|620|620
-6|621|621
-6|622|622
-6|623|623
-6|624|624
-6|625|625
-6|626|626
-6|627|627
-6|628|628
-6|629|629
-6|630|630
-6|631|631
-6|632|632
-6|633|633
-6|634|634
-6|635|635
-6|636|636
-6|637|637
-6|638|638
-6|639|639
-6|640|640
-6|641|641
-6|642|642
-6|643|643
-6|644|644
-6|645|645
-6|646|646
-6|647|647
-6|648|648
-6|649|649
-6|650|650
-6|651|651
-6|652|652
-6|653|653
-6|654|654
-6|655|655
-6|656|656
-6|657|657
-6|658|658
-6|659|659
-6|660|660
-6|661|661
-6|662|662
-6|663|663
-6|664|664
-6|665|665
-6|666|666
-6|667|667
-6|668|668
-6|669|669
-6|670|670
-6|671|671
-6|672|672
-6|673|673
-6|674|674
-6|675|675
-6|676|676
-6|677|677
-6|678|678
-6|679|679
-6|680|680
-6|681|681
-6|682|682
-6|683|683
-6|684|684
-6|685|685
-6|686|686
-6|687|687
-6|688|688
-6|689|689
-6|690|690
-6|691|691
-6|692|692
-6|693|693
-6|694|694
-6|695|695
-6|696|696
-6|697|697
-6|698|698
-6|699|699
-6|700|700
-6|701|701
-6|702|702
-6|703|703
-6|704|704
-6|705|705
-6|706|706
-6|707|707
-6|708|708
-6|709|709
-6|710|710
-6|711|711
-6|712|712
-6|713|713
-6|714|714
-6|715|715
-6|716|716
-6|717|717
-6|718|718
-6|719|719
-6|720|720
-6|721|721
-6|722|722
-6|723|723
-6|724|724
-6|725|725
-6|726|726
-6|727|727
-6|728|728
-6|729|729
-6|730|730
-6|731|731
-6|732|732
-6|733|733
-6|734|734
-6|735|735
-6|736|736
-6|737|737
-6|738|738
-6|739|739
-6|740|740
-6|741|741
-6|742|742
-6|743|743
-6|744|744
-6|745|745
-6|746|746
-6|747|747
-6|748|748
-6|749|749
-6|750|750
-6|751|751
-6|752|752
-6|753|753
-6|754|754
-6|755|755
-6|756|756
-6|757|757
-6|758|758
-6|759|759
-6|760|760
-6|761|761
-6|762|762
-6|763|763
-6|764|764
-6|765|765
-6|766|766
-6|767|767
-6|768|768
-6|769|769
-6|770|770
-6|771|771
-6|772|772
-6|773|773
-6|774|774
-6|775|775
-6|776|776
-6|777|777
-6|778|778
-6|779|779
-6|780|780
-6|781|781
-6|782|782
-6|783|783
-6|784|784
-6|785|785
-6|786|786
-6|787|787
-6|788|788
-6|789|789
-6|790|790
-6|791|791
-6|792|792
-6|793|793
-6|794|794
-6|795|795
-6|796|796
-6|797|797
-6|798|798
-6|799|799
-6|800|800
-6|801|801
-6|802|802
-6|803|803
-6|804|804
-6|805|805
-6|806|806
-6|807|807
-6|808|808
-6|809|809
-6|810|810
-6|811|811
-6|812|812
-6|813|813
-6|814|814
-6|815|815
-6|816|816
-6|817|817
-6|818|818
-6|819|819
-6|820|820
-6|821|821
-6|822|822
-6|823|823
-6|824|824
-6|825|825
-6|826|826
-6|827|827
-6|828|828
-6|829|829
-6|830|830
-6|831|831
-6|832|832
-6|833|833
-6|834|834
-6|835|835
-6|836|836
-6|837|837
-6|838|838
-6|839|839
-6|840|840
-6|841|841
-6|842|842
-6|843|843
-6|844|844
-6|845|845
-6|846|846
-6|847|847
-6|848|848
-6|849|849
-6|850|850
-6|851|851
-6|852|852
-6|853|853
-6|854|854
-6|855|855
-6|856|856
-6|857|857
-6|858|858
-6|859|859
-6|860|860
-6|861|861
-6|862|862
-6|863|863
-6|864|864
-6|865|865
-6|866|866
-6|867|867
-6|868|868
-6|869|869
-6|870|870
-6|871|871
-6|872|872
-6|873|873
-6|874|874
-6|875|875
-6|876|876
-6|877|877
-6|878|878
-6|879|879
-6|880|880
-6|881|881
-6|882|882
-6|883|883
-6|884|884
-6|885|885
-6|886|886
-6|887|887
-6|888|888
-6|889|889
-6|890|890
-6|891|891
-6|892|892
-6|893|893
-6|894|894
-6|895|895
-6|896|896
-6|897|897
-6|898|898
-6|899|899
-6|900|900
-6|901|901
-6|902|902
-6|903|903
-6|904|904
-6|905|905
-6|906|906
-6|907|907
-6|908|908
-6|909|909
-6|910|910
-6|911|911
-6|912|912
-6|913|913
-6|914|914
-6|915|915
-6|916|916
-6|917|917
-6|918|918
-6|919|919
-6|920|920
-6|921|921
-6|922|922
-6|923|923
-6|924|924
-6|925|925
-6|926|926
-6|927|927
-6|928|928
-6|929|929
-6|930|930
-6|931|931
-6|932|932
-6|933|933
-6|934|934
-6|935|935
-6|936|936
-6|937|937
-6|938|938
-6|939|939
-6|940|940
-6|941|941
-6|942|942
-6|943|943
-6|944|944
-6|945|945
-6|946|946
-6|947|947
-6|948|948
-6|949|949
-6|950|950
-6|951|951
-6|952|952
-6|953|953
-6|954|954
-6|955|955
-6|956|956
-6|957|957
-6|958|958
-6|959|959
-6|960|960
-6|961|961
-6|962|962
-6|963|963
-6|964|964
-6|965|965
-6|966|966
-6|967|967
-6|968|968
-6|969|969
-6|970|970
-6|971|971
-6|972|972
-6|973|973
-6|974|974
-6|975|975
-6|976|976
-6|977|977
-6|978|978
-6|979|979
-6|980|980
-6|981|981
-6|982|982
-6|983|983
-6|984|984
-6|985|985
-6|986|986
-6|987|987
-6|988|988
-6|989|989
-6|990|990
-6|991|991
-6|992|992
-6|993|993
-6|994|994
-6|995|995
-6|996|996
-6|997|997
-6|998|998
-6|999|999
-6|1000|1000
-7|1|1
-7|2|2
-7|3|3
-7|4|4
-7|5|5
-7|6|6
-7|7|7
-7|8|8
-7|9|9
-7|10|10
-7|11|11
-7|12|12
-7|13|13
-7|14|14
-7|15|15
-7|16|16
-7|17|17
-7|18|18
-7|19|19
-7|20|20
-7|21|21
-7|22|22
-7|23|23
-7|24|24
-7|25|25
-7|26|26
-7|27|27
-7|28|28
-7|29|29
-7|30|30
-7|31|31
-7|32|32
-7|33|33
-7|34|34
-7|35|35
-7|36|36
-7|37|37
-7|38|38
-7|39|39
-7|40|40
-7|41|41
-7|42|42
-7|43|43
-7|44|44
-7|45|45
-7|46|46
-7|47|47
-7|48|48
-7|49|49
-7|50|50
-7|51|51
-7|52|52
-7|53|53
-7|54|54
-7|55|55
-7|56|56
-7|57|57
-7|58|58
-7|59|59
-7|60|60
-7|61|61
-7|62|62
-7|63|63
-7|64|64
-7|65|65
-7|66|66
-7|67|67
-7|68|68
-7|69|69
-7|70|70
-7|71|71
-7|72|72
-7|73|73
-7|74|74
-7|75|75
-7|76|76
-7|77|77
-7|78|78
-7|79|79
-7|80|80
-7|81|81
-7|82|82
-7|83|83
-7|84|84
-7|85|85
-7|86|86
-7|87|87
-7|88|88
-7|89|89
-7|90|90
-7|91|91
-7|92|92
-7|93|93
-7|94|94
-7|95|95
-7|96|96
-7|97|97
-7|98|98
-7|99|99
-7|100|100
-7|101|101
-7|102|102
-7|103|103
-7|104|104
-7|105|105
-7|106|106
-7|107|107
-7|108|108
-7|109|109
-7|110|110
-7|111|111
-7|112|112
-7|113|113
-7|114|114
-7|115|115
-7|116|116
-7|117|117
-7|118|118
-7|119|119
-7|120|120
-7|121|121
-7|122|122
-7|123|123
-7|124|124
-7|125|125
-7|126|126
-7|127|127
-7|128|128
-7|129|129
-7|130|130
-7|131|131
-7|132|132
-7|133|133
-7|134|134
-7|135|135
-7|136|136
-7|137|137
-7|138|138
-7|139|139
-7|140|140
-7|141|141
-7|142|142
-7|143|143
-7|144|144
-7|145|145
-7|146|146
-7|147|147
-7|148|148
-7|149|149
-7|150|150
-7|151|151
-7|152|152
-7|153|153
-7|154|154
-7|155|155
-7|156|156
-7|157|157
-7|158|158
-7|159|159
-7|160|160
-7|161|161
-7|162|162
-7|163|163
-7|164|164
-7|165|165
-7|166|166
-7|167|167
-7|168|168
-7|169|169
-7|170|170
-7|171|171
-7|172|172
-7|173|173
-7|174|174
-7|175|175
-7|176|176
-7|177|177
-7|178|178
-7|179|179
-7|180|180
-7|181|181
-7|182|182
-7|183|183
-7|184|184
-7|185|185
-7|186|186
-7|187|187
-7|188|188
-7|189|189
-7|190|190
-7|191|191
-7|192|192
-7|193|193
-7|194|194
-7|195|195
-7|196|196
-7|197|197
-7|198|198
-7|199|199
-7|200|200
-7|201|201
-7|202|202
-7|203|203
-7|204|204
-7|205|205
-7|206|206
-7|207|207
-7|208|208
-7|209|209
-7|210|210
-7|211|211
-7|212|212
-7|213|213
-7|214|214
-7|215|215
-7|216|216
-7|217|217
-7|218|218
-7|219|219
-7|220|220
-7|221|221
-7|222|222
-7|223|223
-7|224|224
-7|225|225
-7|226|226
-7|227|227
-7|228|228
-7|229|229
-7|230|230
-7|231|231
-7|232|232
-7|233|233
-7|234|234
-7|235|235
-7|236|236
-7|237|237
-7|238|238
-7|239|239
-7|240|240
-7|241|241
-7|242|242
-7|243|243
-7|244|244
-7|245|245
-7|246|246
-7|247|247
-7|248|248
-7|249|249
-7|250|250
-7|251|251
-7|252|252
-7|253|253
-7|254|254
-7|255|255
-7|256|256
-7|257|257
-7|258|258
-7|259|259
-7|260|260
-7|261|261
-7|262|262
-7|263|263
-7|264|264
-7|265|265
-7|266|266
-7|267|267
-7|268|268
-7|269|269
-7|270|270
-7|271|271
-7|272|272
-7|273|273
-7|274|274
-7|275|275
-7|276|276
-7|277|277
-7|278|278
-7|279|279
-7|280|280
-7|281|281
-7|282|282
-7|283|283
-7|284|284
-7|285|285
-7|286|286
-7|287|287
-7|288|288
-7|289|289
-7|290|290
-7|291|291
-7|292|292
-7|293|293
-7|294|294
-7|295|295
-7|296|296
-7|297|297
-7|298|298
-7|299|299
-7|300|300
-7|301|301
-7|302|302
-7|303|303
-7|304|304
-7|305|305
-7|306|306
-7|307|307
-7|308|308
-7|309|309
-7|310|310
-7|311|311
-7|312|312
-7|313|313
-7|314|314
-7|315|315
-7|316|316
-7|317|317
-7|318|318
-7|319|319
-7|320|320
-7|321|321
-7|322|322
-7|323|323
-7|324|324
-7|325|325
-7|326|326
-7|327|327
-7|328|328
-7|329|329
-7|330|330
-7|331|331
-7|332|332
-7|333|333
-7|334|334
-7|335|335
-7|336|336
-7|337|337
-7|338|338
-7|339|339
-7|340|340
-7|341|341
-7|342|342
-7|343|343
-7|344|344
-7|345|345
-7|346|346
-7|347|347
-7|348|348
-7|349|349
-7|350|350
-7|351|351
-7|352|352
-7|353|353
-7|354|354
-7|355|355
-7|356|356
-7|357|357
-7|358|358
-7|359|359
-7|360|360
-7|361|361
-7|362|362
-7|363|363
-7|364|364
-7|365|365
-7|366|366
-7|367|367
-7|368|368
-7|369|369
-7|370|370
-7|371|371
-7|372|372
-7|373|373
-7|374|374
-7|375|375
-7|376|376
-7|377|377
-7|378|378
-7|379|379
-7|380|380
-7|381|381
-7|382|382
-7|383|383
-7|384|384
-7|385|385
-7|386|386
-7|387|387
-7|388|388
-7|389|389
-7|390|390
-7|391|391
-7|392|392
-7|393|393
-7|394|394
-7|395|395
-7|396|396
-7|397|397
-7|398|398
-7|399|399
-7|400|400
-7|401|401
-7|402|402
-7|403|403
-7|404|404
-7|405|405
-7|406|406
-7|407|407
-7|408|408
-7|409|409
-7|410|410
-7|411|411
-7|412|412
-7|413|413
-7|414|414
-7|415|415
-7|416|416
-7|417|417
-7|418|418
-7|419|419
-7|420|420
-7|421|421
-7|422|422
-7|423|423
-7|424|424
-7|425|425
-7|426|426
-7|427|427
-7|428|428
-7|429|429
-7|430|430
-7|431|431
-7|432|432
-7|433|433
-7|434|434
-7|435|435
-7|436|436
-7|437|437
-7|438|438
-7|439|439
-7|440|440
-7|441|441
-7|442|442
-7|443|443
-7|444|444
-7|445|445
-7|446|446
-7|447|447
-7|448|448
-7|449|449
-7|450|450
-7|451|451
-7|452|452
-7|453|453
-7|454|454
-7|455|455
-7|456|456
-7|457|457
-7|458|458
-7|459|459
-7|460|460
-7|461|461
-7|462|462
-7|463|463
-7|464|464
-7|465|465
-7|466|466
-7|467|467
-7|468|468
-7|469|469
-7|470|470
-7|471|471
-7|472|472
-7|473|473
-7|474|474
-7|475|475
-7|476|476
-7|477|477
-7|478|478
-7|479|479
-7|480|480
-7|481|481
-7|482|482
-7|483|483
-7|484|484
-7|485|485
-7|486|486
-7|487|487
-7|488|488
-7|489|489
-7|490|490
-7|491|491
-7|492|492
-7|493|493
-7|494|494
-7|495|495
-7|496|496
-7|497|497
-7|498|498
-7|499|499
-7|500|500
-7|501|501
-7|502|502
-7|503|503
-7|504|504
-7|505|505
-7|506|506
-7|507|507
-7|508|508
-7|509|509
-7|510|510
-7|511|511
-7|512|512
-7|513|513
-7|514|514
-7|515|515
-7|516|516
-7|517|517
-7|518|518
-7|519|519
-7|520|520
-7|521|521
-7|522|522
-7|523|523
-7|524|524
-7|525|525
-7|526|526
-7|527|527
-7|528|528
-7|529|529
-7|530|530
-7|531|531
-7|532|532
-7|533|533
-7|534|534
-7|535|535
-7|536|536
-7|537|537
-7|538|538
-7|539|539
-7|540|540
-7|541|541
-7|542|542
-7|543|543
-7|544|544
-7|545|545
-7|546|546
-7|547|547
-7|548|548
-7|549|549
-7|550|550
-7|551|551
-7|552|552
-7|553|553
-7|554|554
-7|555|555
-7|556|556
-7|557|557
-7|558|558
-7|559|559
-7|560|560
-7|561|561
-7|562|562
-7|563|563
-7|564|564
-7|565|565
-7|566|566
-7|567|567
-7|568|568
-7|569|569
-7|570|570
-7|571|571
-7|572|572
-7|573|573
-7|574|574
-7|575|575
-7|576|576
-7|577|577
-7|578|578
-7|579|579
-7|580|580
-7|581|581
-7|582|582
-7|583|583
-7|584|584
-7|585|585
-7|586|586
-7|587|587
-7|588|588
-7|589|589
-7|590|590
-7|591|591
-7|592|592
-7|593|593
-7|594|594
-7|595|595
-7|596|596
-7|597|597
-7|598|598
-7|599|599
-7|600|600
-7|601|601
-7|602|602
-7|603|603
-7|604|604
-7|605|605
-7|606|606
-7|607|607
-7|608|608
-7|609|609
-7|610|610
-7|611|611
-7|612|612
-7|613|613
-7|614|614
-7|615|615
-7|616|616
-7|617|617
-7|618|618
-7|619|619
-7|620|620
-7|621|621
-7|622|622
-7|623|623
-7|624|624
-7|625|625
-7|626|626
-7|627|627
-7|628|628
-7|629|629
-7|630|630
-7|631|631
-7|632|632
-7|633|633
-7|634|634
-7|635|635
-7|636|636
-7|637|637
-7|638|638
-7|639|639
-7|640|640
-7|641|641
-7|642|642
-7|643|643
-7|644|644
-7|645|645
-7|646|646
-7|647|647
-7|648|648
-7|649|649
-7|650|650
-7|651|651
-7|652|652
-7|653|653
-7|654|654
-7|655|655
-7|656|656
-7|657|657
-7|658|658
-7|659|659
-7|660|660
-7|661|661
-7|662|662
-7|663|663
-7|664|664
-7|665|665
-7|666|666
-7|667|667
-7|668|668
-7|669|669
-7|670|670
-7|671|671
-7|672|672
-7|673|673
-7|674|674
-7|675|675
-7|676|676
-7|677|677
-7|678|678
-7|679|679
-7|680|680
-7|681|681
-7|682|682
-7|683|683
-7|684|684
-7|685|685
-7|686|686
-7|687|687
-7|688|688
-7|689|689
-7|690|690
-7|691|691
-7|692|692
-7|693|693
-7|694|694
-7|695|695
-7|696|696
-7|697|697
-7|698|698
-7|699|699
-7|700|700
-7|701|701
-7|702|702
-7|703|703
-7|704|704
-7|705|705
-7|706|706
-7|707|707
-7|708|708
-7|709|709
-7|710|710
-7|711|711
-7|712|712
-7|713|713
-7|714|714
-7|715|715
-7|716|716
-7|717|717
-7|718|718
-7|719|719
-7|720|720
-7|721|721
-7|722|722
-7|723|723
-7|724|724
-7|725|725
-7|726|726
-7|727|727
-7|728|728
-7|729|729
-7|730|730
-7|731|731
-7|732|732
-7|733|733
-7|734|734
-7|735|735
-7|736|736
-7|737|737
-7|738|738
-7|739|739
-7|740|740
-7|741|741
-7|742|742
-7|743|743
-7|744|744
-7|745|745
-7|746|746
-7|747|747
-7|748|748
-7|749|749
-7|750|750
-7|751|751
-7|752|752
-7|753|753
-7|754|754
-7|755|755
-7|756|756
-7|757|757
-7|758|758
-7|759|759
-7|760|760
-7|761|761
-7|762|762
-7|763|763
-7|764|764
-7|765|765
-7|766|766
-7|767|767
-7|768|768
-7|769|769
-7|770|770
-7|771|771
-7|772|772
-7|773|773
-7|774|774
-7|775|775
-7|776|776
-7|777|777
-7|778|778
-7|779|779
-7|780|780
-7|781|781
-7|782|782
-7|783|783
-7|784|784
-7|785|785
-7|786|786
-7|787|787
-7|788|788
-7|789|789
-7|790|790
-7|791|791
-7|792|792
-7|793|793
-7|794|794
-7|795|795
-7|796|796
-7|797|797
-7|798|798
-7|799|799
-7|800|800
-7|801|801
-7|802|802
-7|803|803
-7|804|804
-7|805|805
-7|806|806
-7|807|807
-7|808|808
-7|809|809
-7|810|810
-7|811|811
-7|812|812
-7|813|813
-7|814|814
-7|815|815
-7|816|816
-7|817|817
-7|818|818
-7|819|819
-7|820|820
-7|821|821
-7|822|822
-7|823|823
-7|824|824
-7|825|825
-7|826|826
-7|827|827
-7|828|828
-7|829|829
-7|830|830
-7|831|831
-7|832|832
-7|833|833
-7|834|834
-7|835|835
-7|836|836
-7|837|837
-7|838|838
-7|839|839
-7|840|840
-7|841|841
-7|842|842
-7|843|843
-7|844|844
-7|845|845
-7|846|846
-7|847|847
-7|848|848
-7|849|849
-7|850|850
-7|851|851
-7|852|852
-7|853|853
-7|854|854
-7|855|855
-7|856|856
-7|857|857
-7|858|858
-7|859|859
-7|860|860
-7|861|861
-7|862|862
-7|863|863
-7|864|864
-7|865|865
-7|866|866
-7|867|867
-7|868|868
-7|869|869
-7|870|870
-7|871|871
-7|872|872
-7|873|873
-7|874|874
-7|875|875
-7|876|876
-7|877|877
-7|878|878
-7|879|879
-7|880|880
-7|881|881
-7|882|882
-7|883|883
-7|884|884
-7|885|885
-7|886|886
-7|887|887
-7|888|888
-7|889|889
-7|890|890
-7|891|891
-7|892|892
-7|893|893
-7|894|894
-7|895|895
-7|896|896
-7|897|897
-7|898|898
-7|899|899
-7|900|900
-7|901|901
-7|902|902
-7|903|903
-7|904|904
-7|905|905
-7|906|906
-7|907|907
-7|908|908
-7|909|909
-7|910|910
-7|911|911
-7|912|912
-7|913|913
-7|914|914
-7|915|915
-7|916|916
-7|917|917
-7|918|918
-7|919|919
-7|920|920
-7|921|921
-7|922|922
-7|923|923
-7|924|924
-7|925|925
-7|926|926
-7|927|927
-7|928|928
-7|929|929
-7|930|930
-7|931|931
-7|932|932
-7|933|933
-7|934|934
-7|935|935
-7|936|936
-7|937|937
-7|938|938
-7|939|939
-7|940|940
-7|941|941
-7|942|942
-7|943|943
-7|944|944
-7|945|945
-7|946|946
-7|947|947
-7|948|948
-7|949|949
-7|950|950
-7|951|951
-7|952|952
-7|953|953
-7|954|954
-7|955|955
-7|956|956
-7|957|957
-7|958|958
-7|959|959
-7|960|960
-7|961|961
-7|962|962
-7|963|963
-7|964|964
-7|965|965
-7|966|966
-7|967|967
-7|968|968
-7|969|969
-7|970|970
-7|971|971
-7|972|972
-7|973|973
-7|974|974
-7|975|975
-7|976|976
-7|977|977
-7|978|978
-7|979|979
-7|980|980
-7|981|981
-7|982|982
-7|983|983
-7|984|984
-7|985|985
-7|986|986
-7|987|987
-7|988|988
-7|989|989
-7|990|990
-7|991|991
-7|992|992
-7|993|993
-7|994|994
-7|995|995
-7|996|996
-7|997|997
-7|998|998
-7|999|999
-7|1000|1000
-8|1|1
-8|2|2
-8|3|3
-8|4|4
-8|5|5
-8|6|6
-8|7|7
-8|8|8
-8|9|9
-8|10|10
-8|11|11
-8|12|12
-8|13|13
-8|14|14
-8|15|15
-8|16|16
-8|17|17
-8|18|18
-8|19|19
-8|20|20
-8|21|21
-8|22|22
-8|23|23
-8|24|24
-8|25|25
-8|26|26
-8|27|27
-8|28|28
-8|29|29
-8|30|30
-8|31|31
-8|32|32
-8|33|33
-8|34|34
-8|35|35
-8|36|36
-8|37|37
-8|38|38
-8|39|39
-8|40|40
-8|41|41
-8|42|42
-8|43|43
-8|44|44
-8|45|45
-8|46|46
-8|47|47
-8|48|48
-8|49|49
-8|50|50
-8|51|51
-8|52|52
-8|53|53
-8|54|54
-8|55|55
-8|56|56
-8|57|57
-8|58|58
-8|59|59
-8|60|60
-8|61|61
-8|62|62
-8|63|63
-8|64|64
-8|65|65
-8|66|66
-8|67|67
-8|68|68
-8|69|69
-8|70|70
-8|71|71
-8|72|72
-8|73|73
-8|74|74
-8|75|75
-8|76|76
-8|77|77
-8|78|78
-8|79|79
-8|80|80
-8|81|81
-8|82|82
-8|83|83
-8|84|84
-8|85|85
-8|86|86
-8|87|87
-8|88|88
-8|89|89
-8|90|90
-8|91|91
-8|92|92
-8|93|93
-8|94|94
-8|95|95
-8|96|96
-8|97|97
-8|98|98
-8|99|99
-8|100|100
-8|101|101
-8|102|102
-8|103|103
-8|104|104
-8|105|105
-8|106|106
-8|107|107
-8|108|108
-8|109|109
-8|110|110
-8|111|111
-8|112|112
-8|113|113
-8|114|114
-8|115|115
-8|116|116
-8|117|117
-8|118|118
-8|119|119
-8|120|120
-8|121|121
-8|122|122
-8|123|123
-8|124|124
-8|125|125
-8|126|126
-8|127|127
-8|128|128
-8|129|129
-8|130|130
-8|131|131
-8|132|132
-8|133|133
-8|134|134
-8|135|135
-8|136|136
-8|137|137
-8|138|138
-8|139|139
-8|140|140
-8|141|141
-8|142|142
-8|143|143
-8|144|144
-8|145|145
-8|146|146
-8|147|147
-8|148|148
-8|149|149
-8|150|150
-8|151|151
-8|152|152
-8|153|153
-8|154|154
-8|155|155
-8|156|156
-8|157|157
-8|158|158
-8|159|159
-8|160|160
-8|161|161
-8|162|162
-8|163|163
-8|164|164
-8|165|165
-8|166|166
-8|167|167
-8|168|168
-8|169|169
-8|170|170
-8|171|171
-8|172|172
-8|173|173
-8|174|174
-8|175|175
-8|176|176
-8|177|177
-8|178|178
-8|179|179
-8|180|180
-8|181|181
-8|182|182
-8|183|183
-8|184|184
-8|185|185
-8|186|186
-8|187|187
-8|188|188
-8|189|189
-8|190|190
-8|191|191
-8|192|192
-8|193|193
-8|194|194
-8|195|195
-8|196|196
-8|197|197
-8|198|198
-8|199|199
-8|200|200
-8|201|201
-8|202|202
-8|203|203
-8|204|204
-8|205|205
-8|206|206
-8|207|207
-8|208|208
-8|209|209
-8|210|210
-8|211|211
-8|212|212
-8|213|213
-8|214|214
-8|215|215
-8|216|216
-8|217|217
-8|218|218
-8|219|219
-8|220|220
-8|221|221
-8|222|222
-8|223|223
-8|224|224
-8|225|225
-8|226|226
-8|227|227
-8|228|228
-8|229|229
-8|230|230
-8|231|231
-8|232|232
-8|233|233
-8|234|234
-8|235|235
-8|236|236
-8|237|237
-8|238|238
-8|239|239
-8|240|240
-8|241|241
-8|242|242
-8|243|243
-8|244|244
-8|245|245
-8|246|246
-8|247|247
-8|248|248
-8|249|249
-8|250|250
-8|251|251
-8|252|252
-8|253|253
-8|254|254
-8|255|255
-8|256|256
-8|257|257
-8|258|258
-8|259|259
-8|260|260
-8|261|261
-8|262|262
-8|263|263
-8|264|264
-8|265|265
-8|266|266
-8|267|267
-8|268|268
-8|269|269
-8|270|270
-8|271|

<TRUNCATED>


[3/6] incubator-griffin git commit: remove stale docs

Posted by gu...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/data/gen-es-data.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/data/gen-es-data.sh b/docker/griffin_demo/prep/data/gen-es-data.sh
deleted file mode 100755
index 93606c9..0000000
--- a/docker/griffin_demo/prep/data/gen-es-data.sh
+++ /dev/null
@@ -1,79 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493951823461, "total": 8927368, "matched": 8861175}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493955423461, "total": 9757306, "matched": 9753493}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493959023461, "total": 8614285, "matched": 8559842}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493962623461, "total": 8043288, "matched": 8034775}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493966223461, "total": 9360576, "matched": 9288744}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493969823461, "total": 8079795, "matched": 8078190}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493973423461, "total": 9479698, "matched": 9476094}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493977023461, "total": 8543483, "matched": 8524897}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493980623461, "total": 9449484, "matched": 9412128}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493984223461, "total": 9791098, "matched": 9735685}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493987823461, "total": 9194117, "matched": 9164237}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493991423461, "total": 9186464, "matched": 9183768}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493995023461, "total": 9429018, "matched": 9375324}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1493998623461, "total": 8740571, "matched": 8733743}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1494002223461, "total": 8495330, "matched": 8461814}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1494005823461, "total": 8054780, "matched": 8001438}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1494009423461, "total": 8029660, "matched": 7979653}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1494013023461, "total": 8705272, "matched": 8627610}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1494016623461, "total": 8704313, "matched": 8684186}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "viewitem_hourly", "tmst": 1494020223461, "total": 8957171, "matched": 8868013}'
-
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493951823461, "total": 1067347, "matched": 1067346}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493955423461, "total": 1007213, "matched": 999576}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493959023461, "total": 1086389, "matched": 1083336}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493962623461, "total": 1071258, "matched": 1066583}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493966223461, "total": 1080928, "matched": 1080255}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493969823461, "total": 1012984, "matched": 1004201}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493973423461, "total": 1090650, "matched": 1090445}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493977023461, "total": 1056846, "matched": 1048078}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493980623461, "total": 1088940, "matched": 1079003}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493984223461, "total": 1056905, "matched": 1048087}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493987823461, "total": 1034134, "matched": 1030302}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493991423461, "total": 1024511, "matched": 1020197}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493995023461, "total": 1048833, "matched": 1047890}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1493998623461, "total": 1063914, "matched": 1060807}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1494002223461, "total": 1090843, "matched": 1089507}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1494005823461, "total": 1015360, "matched": 1012678}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1494009423461, "total": 1040409, "matched": 1039279}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1494013023461, "total": 1063349, "matched": 1055783}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1494016623461, "total": 1031706, "matched": 1028600}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "search_hourly", "tmst": 1494020223461, "total": 1066126, "matched": 1062413}'
-
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493951823461, "total": 23224, "matched": 23028}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493955423461, "total": 29988, "matched": 29876}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493959023461, "total": 20840, "matched": 20687}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493962623461, "total": 20679, "matched": 20674}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493966223461, "total": 22713, "matched": 22623}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493969823461, "total": 24865, "matched": 24619}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493973423461, "total": 22017, "matched": 21818}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493977023461, "total": 25047, "matched": 25005}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493980623461, "total": 25149, "matched": 25033}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493984223461, "total": 25653, "matched": 25438}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493987823461, "total": 25829, "matched": 25815}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493991423461, "total": 25550, "matched": 25518}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493995023461, "total": 22669, "matched": 22656}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1493998623461, "total": 27805, "matched": 27668}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1494002223461, "total": 20237, "matched": 20103}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1494005823461, "total": 23782, "matched": 23551}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1494009423461, "total": 22540, "matched": 22323}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1494013023461, "total": 27692, "matched": 27691}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1494016623461, "total": 27558, "matched": 27539}'
-curl -XPOST 'http://127.0.0.1:9200/griffin/accuracy' -d '{"name": "buy_hourly", "tmst": 1494020223461, "total": 22951, "matched": 22934}'

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/data/gen-hive-data.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/data/gen-hive-data.sh b/docker/griffin_demo/prep/data/gen-hive-data.sh
deleted file mode 100755
index 479ee65..0000000
--- a/docker/griffin_demo/prep/data/gen-hive-data.sh
+++ /dev/null
@@ -1,46 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-#create table
-hive -f create-table.hql
-echo "create table done"
-
-#current hour
-cur_date=`date +%Y%m%d%H`
-dt=${cur_date:0:8}
-hour=${cur_date:8:2}
-partition_date="dt='$dt',hour='$hour'"
-sed s/PARTITION_DATE/$partition_date/ ./insert-data.hql.template > insert-data.hql
-hive -f insert-data.hql
-echo "insert data [$partition_date] done"
-
-#next hours
-set +e
-while true
-do
-  cur_date=`date +%Y%m%d%H`
-  next_date=`date -d "+1hour" '+%Y%m%d%H'`
-  dt=${next_date:0:8}
-  hour=${next_date:8:2}
-  partition_date="dt='$dt',hour='$hour'"
-  sed s/PARTITION_DATE/$partition_date/ ./insert-data.hql.template > insert-data.hql
-  hive -f insert-data.hql
-  echo "insert data [$partition_date] done"
-  sleep 3600
-done
-set -e

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/data/init-demo-data.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/data/init-demo-data.sh b/docker/griffin_demo/prep/data/init-demo-data.sh
deleted file mode 100755
index 76323db..0000000
--- a/docker/griffin_demo/prep/data/init-demo-data.sh
+++ /dev/null
@@ -1,22 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-sleep 30
-
-nohup ./gen-es-data.sh > gen-es.log &
-nohup ./add-measure.sh > add-measure.log &

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/data/insert-data.hql.template
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/data/insert-data.hql.template b/docker/griffin_demo/prep/data/insert-data.hql.template
deleted file mode 100644
index 0b24fe6..0000000
--- a/docker/griffin_demo/prep/data/insert-data.hql.template
+++ /dev/null
@@ -1,18 +0,0 @@
-# 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.
-
-
-LOAD DATA LOCAL INPATH 'demo_src' INTO TABLE demo_src PARTITION (PARTITION_DATE);
-LOAD DATA LOCAL INPATH 'demo_tgt' INTO TABLE demo_tgt PARTITION (PARTITION_DATE);

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/jar/griffin-measure.jar.placeholder
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/jar/griffin-measure.jar.placeholder b/docker/griffin_demo/prep/jar/griffin-measure.jar.placeholder
deleted file mode 100644
index e556dc9..0000000
--- a/docker/griffin_demo/prep/jar/griffin-measure.jar.placeholder
+++ /dev/null
@@ -1,15 +0,0 @@
-# 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.
-

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/job/config.json
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/job/config.json b/docker/griffin_demo/prep/job/config.json
deleted file mode 100644
index 9d09ef1..0000000
--- a/docker/griffin_demo/prep/job/config.json
+++ /dev/null
@@ -1,27 +0,0 @@
-{
-  "name": "avr_accu",
-  "type": "accuracy",
-
-  "source": {
-    "type": "hive",
-    "version": "1.2",
-    "config": {
-      "database": "default",
-      "table.name": "demo_src"
-    }
-  },
-
-  "target": {
-    "type": "hive",
-    "version": "1.2",
-    "config": {
-      "database": "default",
-      "table.name": "demo_tgt"
-    }
-  },
-
-  "evaluateRule": {
-    "sampleRatio": 1,
-    "rules": "$source.id = $target.id AND $source.age = $target.age AND $source.desc = $target.desc"
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/job/env.json.template
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/job/env.json.template b/docker/griffin_demo/prep/job/env.json.template
deleted file mode 100644
index 78870c6..0000000
--- a/docker/griffin_demo/prep/job/env.json.template
+++ /dev/null
@@ -1,27 +0,0 @@
-{
-  "spark": {
-    "log.level": "INFO",
-    "checkpoint.dir": "hdfs:///griffin/checkpoint",
-    "config": {}
-  },
-
-  "persist": [
-    {
-      "type": "hdfs",
-      "config": {
-        "path": "hdfs:///griffin/persist"
-      }
-    },
-    {
-      "type": "http",
-      "config": {
-        "method": "post",
-        "api": "http://HOSTNAME:9200/griffin/accuracy"
-      }
-    }
-  ],
-
-  "cleaner": {
-
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/prepare.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/prepare.sh b/docker/griffin_demo/prep/prepare.sh
deleted file mode 100755
index d11ec02..0000000
--- a/docker/griffin_demo/prep/prepare.sh
+++ /dev/null
@@ -1,36 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-hadoop fs -mkdir /griffin
-hadoop fs -mkdir /griffin/json
-hadoop fs -mkdir /griffin/persist
-hadoop fs -mkdir /griffin/checkpoint
-
-hadoop fs -mkdir /griffin/data
-hadoop fs -mkdir /griffin/data/batch
-
-#jar file
-hadoop fs -put jar/griffin-measure.jar /griffin/
-
-#data
-
-#service
-
-#job
-#hadoop fs -put job/env.json /griffin/json/
-hadoop fs -put job/config.json /griffin/json/

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/service/config/application.properties.template
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/service/config/application.properties.template b/docker/griffin_demo/prep/service/config/application.properties.template
deleted file mode 100644
index 2c4f3c9..0000000
--- a/docker/griffin_demo/prep/service/config/application.properties.template
+++ /dev/null
@@ -1,40 +0,0 @@
-
-
-# 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.
-
-
-spring.datasource.url= jdbc:mysql://HOSTNAME:3306/quartz
-spring.datasource.username =griffin
-spring.datasource.password =123456
-
-spring.datasource.driver-class-name=com.mysql.jdbc.Driver
-
-## Hibernate ddl auto (validate,create, create-drop, update)
-
-spring.jpa.hibernate.ddl-auto = create-drop
-spring.jpa.show-sql=true
-spring.jpa.properties.hibernate.dialect=org.hibernate.dialect.MySQL5Dialect
-#
-#
-## Naming strategy
-spring.jpa.hibernate.naming-strategy = org.hibernate.cfg.ImprovedNamingStrategy
-
-# hive metastore
-hive.metastore.uris = thrift://HOSTNAME:9083
-hive.metastore.dbname = default
-
-# kafka schema registry
-kafka.schema.registry.url = http://HOSTNAME:8181

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/service/service.jar.placeholder
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/service/service.jar.placeholder b/docker/griffin_demo/prep/service/service.jar.placeholder
deleted file mode 100644
index e69de29..0000000

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/Dockerfile
----------------------------------------------------------------------
diff --git a/docker/griffin_env/Dockerfile b/docker/griffin_env/Dockerfile
deleted file mode 100644
index 224efe8..0000000
--- a/docker/griffin_env/Dockerfile
+++ /dev/null
@@ -1,86 +0,0 @@
-# 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.
-
-FROM ubuntu:14.04
-MAINTAINER org.apache.griffin
-
-#install wget, ssh, unzip
-RUN apt-get update && apt-get install wget -y && apt-get install openssh-client openssh-server -y && apt-get install unzip -y
-RUN mkdir /apache 
-WORKDIR /apache
-ADD prep /apache
-
-EXPOSE 2122
-
-#java
-RUN ./software-install.sh
-ADD conf /apache/conf
-RUN ./dir.sh && ./software-config.sh
-ENV JAVA_HOME /apache/jdk
-ENV HADOOP_HOME /apache/hadoop
-ENV HADOOP_INSTALL $HADOOP_HOME
-ENV HADOOP_MAPRED_HOME $HADOOP_HOME
-ENV HADOOP_COMMON_HOME $HADOOP_HOME
-ENV HADOOP_HDFS_HOME $HADOOP_HOME
-ENV YARN_HOME $HADOOP_HOME
-ENV HADOOP_COMMON_LIB_NATIVE_DIR $HADOOP_HOME/lib/native
-ENV SCALA_HOME /apache/scala
-ENV SPARK_HOME /apache/spark
-ENV HIVE_HOME /apache/hive
-ENV HADOOP_USER_CLASSPATH_FIRST true
-ENV LIVY_HOME /apache/livy
-
-ENV PATH $JAVA_HOME/bin:$PATH:$HADOOP_HOME/bin:$HADOOP_HOME/sbin:$SCALA_HOME/bin:$SPARK_HOME/bin:$HIVE_HOME/bin:$LIVY_HOME/bin
-
-EXPOSE 3306
-EXPOSE 9000 10020
-EXPOSE 50010 50020 50070 50075 50090
-EXPOSE 19888
-EXPOSE 8030 8031 8032 8033 8040 8042 8088
-EXPOSE 49707
-EXPOSE 9083 27017 6066
-EXPOSE 8080
-EXPOSE 8998
-EXPOSE 9200
-
-#ssh without password
-ENV HOME /root
-WORKDIR /root
-RUN ssh-keygen -q -N "" -t rsa -f /root/.ssh/id_rsa && cp /root/.ssh/id_rsa.pub /root/.ssh/authorized_keys
-ADD ssh_config /root/.ssh/config
-RUN chmod 600 /root/.ssh/config && chown root:root /root/.ssh/config
-RUN sed  -i "/^[^#]*UsePAM/ s/.*/#&/"  /etc/ssh/sshd_config && echo "UsePAM no" >> /etc/ssh/sshd_config && echo "Port 2122" >> /etc/ssh/sshd_config
-
-#CURL
-RUN apt-get install curl -y
-
-#mysql init
-RUN DEBIAN_FRONTEND=noninteractive apt-get install mysql-server -y && DEBIAN_FRONTEND=noninteractive apt-get install libmysql-java -y
-RUN ln -s /usr/share/java/mysql-connector-java.jar $HIVE_HOME/lib/mysql-connector-java.jar && ln -s /usr/share/java/mysql.jar $HIVE_HOME/lib/mysql.jar
-RUN cd /apache/conf/mysql && cp bind_0.cnf /etc/mysql/conf.d/bind_0.cnf && ./mysql-init.sh
-
-#bootstrap
-ADD bootstrap.sh /etc/
-RUN chmod 755 /etc/bootstrap.sh
-
-#initial
-RUN hdfs namenode -format
-RUN /etc/bootstrap.sh && /apache/hdfs_file.sh && rm /apache/*.sh
-
-#bootstrap-all
-ADD bootstrap-all.sh /etc/
-RUN chmod 755 /etc/bootstrap-all.sh
-
-ENTRYPOINT ["/etc/bootstrap-all.sh"]

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/bootstrap-all.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_env/bootstrap-all.sh b/docker/griffin_env/bootstrap-all.sh
deleted file mode 100755
index e44b8bf..0000000
--- a/docker/griffin_env/bootstrap-all.sh
+++ /dev/null
@@ -1,56 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-
-$HADOOP_HOME/etc/hadoop/hadoop-env.sh
-rm /tmp/*.pid
-
-cd $HADOOP_HOME/share/hadoop/common ; for cp in ${ACP//,/ }; do  echo == $cp; curl -LO $cp ; done; cd -
-
-service mysql start
-
-sed s/HOSTNAME/$HOSTNAME/ $HADOOP_HOME/etc/hadoop/core-site.xml.template > $HADOOP_HOME/etc/hadoop/core-site.xml
-sed s/HOSTNAME/$HOSTNAME/ $HADOOP_HOME/etc/hadoop/yarn-site.xml.template > $HADOOP_HOME/etc/hadoop/yarn-site.xml
-sed s/HOSTNAME/$HOSTNAME/ $HADOOP_HOME/etc/hadoop/mapred-site.xml.template > $HADOOP_HOME/etc/hadoop/mapred-site.xml
-
-sed s/HOSTNAME/$HOSTNAME/ $HIVE_HOME/conf/hive-site.xml.template > $HIVE_HOME/conf/hive-site.xml
-
-/etc/init.d/ssh start
-
-start-dfs.sh
-start-yarn.sh
-mr-jobhistory-daemon.sh start historyserver
-
-
-$HADOOP_HOME/bin/hdfs dfsadmin -safemode wait
-
-
-hadoop fs -mkdir -p /home/spark_conf
-hadoop fs -put $HIVE_HOME/conf/hive-site.xml /home/spark_conf/
-echo "spark.yarn.dist.files		hdfs:///home/spark_conf/hive-site.xml" >> $SPARK_HOME/conf/spark-defaults.conf
-
-
-$SPARK_HOME/sbin/start-all.sh
-
-nohup hive --service metastore > metastore.log &
-
-nohup livy-server > livy.log &
-
-service elasticsearch start
-
-/bin/bash -c "bash"

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/bootstrap.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_env/bootstrap.sh b/docker/griffin_env/bootstrap.sh
deleted file mode 100755
index 7549572..0000000
--- a/docker/griffin_env/bootstrap.sh
+++ /dev/null
@@ -1,41 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-
-$HADOOP_HOME/etc/hadoop/hadoop-env.sh
-rm /tmp/*.pid
-
-cd $HADOOP_HOME/share/hadoop/common ; for cp in ${ACP//,/ }; do  echo == $cp; curl -LO $cp ; done; cd -
-
-service mysql start
-
-sed s/HOSTNAME/$HOSTNAME/ $HADOOP_HOME/etc/hadoop/core-site.xml.template > $HADOOP_HOME/etc/hadoop/core-site.xml
-sed s/HOSTNAME/$HOSTNAME/ $HADOOP_HOME/etc/hadoop/yarn-site.xml.template > $HADOOP_HOME/etc/hadoop/yarn-site.xml
-sed s/HOSTNAME/$HOSTNAME/ $HADOOP_HOME/etc/hadoop/mapred-site.xml.template > $HADOOP_HOME/etc/hadoop/mapred-site.xml
-
-sed s/HOSTNAME/$HOSTNAME/ $HIVE_HOME/conf/hive-site.xml.template > $HIVE_HOME/conf/hive-site.xml
-
-/etc/init.d/ssh start
-
-start-dfs.sh
-start-yarn.sh
-mr-jobhistory-daemon.sh start historyserver
-
-$HADOOP_HOME/bin/hdfs dfsadmin -safemode leave
-
-
-/bin/bash -c "bash"

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/elasticsearch/elasticsearch
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/elasticsearch/elasticsearch b/docker/griffin_env/conf/elasticsearch/elasticsearch
deleted file mode 100755
index 1380967..0000000
--- a/docker/griffin_env/conf/elasticsearch/elasticsearch
+++ /dev/null
@@ -1,223 +0,0 @@
-#!/bin/bash
-# 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.
-
-
-#
-# /etc/init.d/elasticsearch -- startup script for Elasticsearch
-#
-### BEGIN INIT INFO
-# Provides:          elasticsearch
-# Required-Start:    $network $remote_fs $named
-# Required-Stop:     $network $remote_fs $named
-# Default-Start:     2 3 4 5
-# Default-Stop:      0 1 6
-# Short-Description: Starts elasticsearch
-# Description:       Starts elasticsearch using start-stop-daemon
-### END INIT INFO
-
-#PATH=/bin:/usr/bin:/sbin:/usr/sbin
-PATH=$PATH
-NAME=elasticsearch
-DESC="Elasticsearch Server"
-DEFAULT=/etc/default/$NAME
-
-if [ `id -u` -ne 0 ]; then
-	echo "You need root privileges to run this script"
-	exit 1
-fi
-
-
-. /lib/lsb/init-functions
-
-if [ -r /etc/default/rcS ]; then
-	. /etc/default/rcS
-fi
-
-
-# The following variables can be overwritten in $DEFAULT
-
-# Run Elasticsearch as this user ID and group ID
-ES_USER=elasticsearch
-ES_GROUP=elasticsearch
-
-# Directory where the Elasticsearch binary distribution resides
-ES_HOME=/usr/share/$NAME
-
-# Additional Java OPTS
-#ES_JAVA_OPTS=
-
-# Maximum number of open files
-MAX_OPEN_FILES=65536
-
-# Maximum amount of locked memory
-#MAX_LOCKED_MEMORY=
-
-# Elasticsearch log directory
-LOG_DIR=/var/log/$NAME
-
-# Elasticsearch data directory
-DATA_DIR=/var/lib/$NAME
-
-# Elasticsearch configuration directory
-CONF_DIR=/etc/$NAME
-
-# Maximum number of VMA (Virtual Memory Areas) a process can own
-MAX_MAP_COUNT=262144
-
-# Elasticsearch PID file directory
-PID_DIR="/var/run/elasticsearch"
-
-# End of variables that can be overwritten in $DEFAULT
-
-# overwrite settings from default file
-if [ -f "$DEFAULT" ]; then
-	. "$DEFAULT"
-fi
-
-# CONF_FILE setting was removed
-if [ ! -z "$CONF_FILE" ]; then
-    echo "CONF_FILE setting is no longer supported. elasticsearch.yml must be placed in the config directory and cannot be renamed."
-    exit 1
-fi
-
-# Define other required variables
-PID_FILE="$PID_DIR/$NAME.pid"
-DAEMON=$ES_HOME/bin/elasticsearch
-DAEMON_OPTS="-d -p $PID_FILE -Edefault.path.logs=$LOG_DIR -Edefault.path.data=$DATA_DIR -Edefault.path.conf=$CONF_DIR"
-
-export ES_JAVA_OPTS
-export JAVA_HOME
-export ES_INCLUDE
-export ES_JVM_OPTIONS
-
-# export unsupported variables so bin/elasticsearch can reject them and inform the user these are unsupported
-if test -n "$ES_MIN_MEM"; then export ES_MIN_MEM; fi
-if test -n "$ES_MAX_MEM"; then export ES_MAX_MEM; fi
-if test -n "$ES_HEAP_SIZE"; then export ES_HEAP_SIZE; fi
-if test -n "$ES_HEAP_NEWSIZE"; then export ES_HEAP_NEWSIZE; fi
-if test -n "$ES_DIRECT_SIZE"; then export ES_DIRECT_SIZE; fi
-if test -n "$ES_USE_IPV4"; then export ES_USE_IPV4; fi
-if test -n "$ES_GC_OPTS"; then export ES_GC_OPTS; fi
-if test -n "$ES_GC_LOG_FILE"; then export ES_GC_LOG_FILE; fi
-
-if [ ! -x "$DAEMON" ]; then
-	echo "The elasticsearch startup script does not exists or it is not executable, tried: $DAEMON"
-	exit 1
-fi
-
-checkJava() {
-	if [ -x "$JAVA_HOME/bin/java" ]; then
-		JAVA="$JAVA_HOME/bin/java"
-	else
-		JAVA=`which java`
-	fi
-
-	if [ ! -x "$JAVA" ]; then
-		echo "Could not find any executable java binary. Please install java in your PATH or set JAVA_HOME"
-		exit 1
-	fi
-}
-
-case "$1" in
-  start)
-	checkJava
-
-	log_daemon_msg "Starting $DESC"
-
-	pid=`pidofproc -p $PID_FILE elasticsearch`
-	if [ -n "$pid" ] ; then
-		log_begin_msg "Already running."
-		log_end_msg 0
-		exit 0
-	fi
-
-	# Ensure that the PID_DIR exists (it is cleaned at OS startup time)
-	if [ -n "$PID_DIR" ] && [ ! -e "$PID_DIR" ]; then
-		mkdir -p "$PID_DIR" && chown "$ES_USER":"$ES_GROUP" "$PID_DIR"
-	fi
-	if [ -n "$PID_FILE" ] && [ ! -e "$PID_FILE" ]; then
-		touch "$PID_FILE" && chown "$ES_USER":"$ES_GROUP" "$PID_FILE"
-	fi
-
-	if [ -n "$MAX_OPEN_FILES" ]; then
-		ulimit -n $MAX_OPEN_FILES
-	fi
-
-	if [ -n "$MAX_LOCKED_MEMORY" ]; then
-		ulimit -l $MAX_LOCKED_MEMORY
-	fi
-
-	if [ -n "$MAX_MAP_COUNT" -a -f /proc/sys/vm/max_map_count ]; then
-		sysctl -q -w vm.max_map_count=$MAX_MAP_COUNT
-	fi
-
-	# Start Daemon
-	start-stop-daemon -d $ES_HOME --start --user "$ES_USER" -c "$ES_USER" --pidfile "$PID_FILE" --exec $DAEMON -- $DAEMON_OPTS
-	return=$?
-	if [ $return -eq 0 ]; then
-		i=0
-		timeout=10
-		# Wait for the process to be properly started before exiting
-		until { kill -0 `cat "$PID_FILE"`; } >/dev/null 2>&1
-		do
-			sleep 1
-			i=$(($i + 1))
-			if [ $i -gt $timeout ]; then
-				log_end_msg 1
-				exit 1
-			fi
-		done
-	fi
-	log_end_msg $return
-	exit $return
-	;;
-  stop)
-	log_daemon_msg "Stopping $DESC"
-
-	if [ -f "$PID_FILE" ]; then
-		start-stop-daemon --stop --pidfile "$PID_FILE" \
-			--user "$ES_USER" \
-			--quiet \
-			--retry forever/TERM/20 > /dev/null
-		if [ $? -eq 1 ]; then
-			log_progress_msg "$DESC is not running but pid file exists, cleaning up"
-		elif [ $? -eq 3 ]; then
-			PID="`cat $PID_FILE`"
-			log_failure_msg "Failed to stop $DESC (pid $PID)"
-			exit 1
-		fi
-		rm -f "$PID_FILE"
-	else
-		log_progress_msg "(not running)"
-	fi
-	log_end_msg 0
-	;;
-  status)
-	status_of_proc -p $PID_FILE elasticsearch elasticsearch && exit 0 || exit $?
-	;;
-  restart|force-reload)
-	if [ -f "$PID_FILE" ]; then
-		$0 stop
-	fi
-	$0 start
-	;;
-  *)
-	log_success_msg "Usage: $0 {start|stop|restart|force-reload|status}"
-	exit 1
-	;;
-esac
-
-exit 0

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/elasticsearch/elasticsearch.yml
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/elasticsearch/elasticsearch.yml b/docker/griffin_env/conf/elasticsearch/elasticsearch.yml
deleted file mode 100644
index ec4f79b..0000000
--- a/docker/griffin_env/conf/elasticsearch/elasticsearch.yml
+++ /dev/null
@@ -1,29 +0,0 @@
-
-
-# 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.
-
-
-network.host: 0.0.0.0
-http.cors.enabled: true
-http.cors.allow-origin: "*"
-node.name: "griffin"
-cluster.name: griffin-elas
-path.data: /data/elasticsearch
-
-indices.fielddata.cache.size: 40%
-indices.breaker.fielddata.limit: 60%
-indices.breaker.request.limit: 40%
-indices.breaker.total.limit: 70%

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/hadoop/core-site.xml.template
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/hadoop/core-site.xml.template b/docker/griffin_env/conf/hadoop/core-site.xml.template
deleted file mode 100644
index 1a4cc8d..0000000
--- a/docker/griffin_env/conf/hadoop/core-site.xml.template
+++ /dev/null
@@ -1,29 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-<!--
-  Licensed 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. See accompanying LICENSE file.
--->
-
-<!-- Put site-specific property overrides in this file. -->
-
-<configuration>
-<property>
-        <name>fs.defaultFS</name>
-        <value>hdfs://HOSTNAME:9000</value>
-    </property>
-	<property>
-		<name>hadoop.tmp.dir</name>
-		<value>file:///data/hadoop-data/tmp</value>
-		<description>Abase for other temporary directories.</description>
-	</property>
-</configuration>

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/hadoop/hadoop-env.sh
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/hadoop/hadoop-env.sh b/docker/griffin_env/conf/hadoop/hadoop-env.sh
deleted file mode 100644
index 099391d..0000000
--- a/docker/griffin_env/conf/hadoop/hadoop-env.sh
+++ /dev/null
@@ -1,99 +0,0 @@
-# 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.
-
-# Set Hadoop-specific environment variables here.
-
-# The only required environment variable is JAVA_HOME.  All others are
-# optional.  When running a distributed configuration it is best to
-# set JAVA_HOME in this file, so that it is correctly defined on
-# remote nodes.
-
-# The java implementation to use.
-#export JAVA_HOME=${JAVA_HOME}
-export JAVA_HOME=/apache/jdk
-
-# The jsvc implementation to use. Jsvc is required to run secure datanodes
-# that bind to privileged ports to provide authentication of data transfer
-# protocol.  Jsvc is not required if SASL is configured for authentication of
-# data transfer protocol using non-privileged ports.
-#export JSVC_HOME=${JSVC_HOME}
-
-export HADOOP_CONF_DIR=${HADOOP_CONF_DIR:-"/etc/hadoop"}
-
-# Extra Java CLASSPATH elements.  Automatically insert capacity-scheduler.
-for f in $HADOOP_HOME/contrib/capacity-scheduler/*.jar; do
-  if [ "$HADOOP_CLASSPATH" ]; then
-    export HADOOP_CLASSPATH=$HADOOP_CLASSPATH:$f
-  else
-    export HADOOP_CLASSPATH=$f
-  fi
-done
-
-# The maximum amount of heap to use, in MB. Default is 1000.
-#export HADOOP_HEAPSIZE=
-#export HADOOP_NAMENODE_INIT_HEAPSIZE=""
-
-# Extra Java runtime options.  Empty by default.
-export HADOOP_OPTS="$HADOOP_OPTS -Djava.net.preferIPv4Stack=true"
-
-# Command specific options appended to HADOOP_OPTS when specified
-export HADOOP_NAMENODE_OPTS="-Dhadoop.security.logger=${HADOOP_SECURITY_LOGGER:-INFO,RFAS} -Dhdfs.audit.logger=${HDFS_AUDIT_LOGGER:-INFO,NullAppender} $HADOOP_NAMENODE_OPTS"
-export HADOOP_DATANODE_OPTS="-Dhadoop.security.logger=ERROR,RFAS $HADOOP_DATANODE_OPTS"
-
-export HADOOP_SECONDARYNAMENODE_OPTS="-Dhadoop.security.logger=${HADOOP_SECURITY_LOGGER:-INFO,RFAS} -Dhdfs.audit.logger=${HDFS_AUDIT_LOGGER:-INFO,NullAppender} $HADOOP_SECONDARYNAMENODE_OPTS"
-
-export HADOOP_NFS3_OPTS="$HADOOP_NFS3_OPTS"
-export HADOOP_PORTMAP_OPTS="-Xmx512m $HADOOP_PORTMAP_OPTS"
-
-# The following applies to multiple commands (fs, dfs, fsck, distcp etc)
-export HADOOP_CLIENT_OPTS="-Xmx512m $HADOOP_CLIENT_OPTS"
-#HADOOP_JAVA_PLATFORM_OPTS="-XX:-UsePerfData $HADOOP_JAVA_PLATFORM_OPTS"
-
-# On secure datanodes, user to run the datanode as after dropping privileges.
-# This **MUST** be uncommented to enable secure HDFS if using privileged ports
-# to provide authentication of data transfer protocol.  This **MUST NOT** be
-# defined if SASL is configured for authentication of data transfer protocol
-# using non-privileged ports.
-export HADOOP_SECURE_DN_USER=${HADOOP_SECURE_DN_USER}
-
-# Where log files are stored.  $HADOOP_HOME/logs by default.
-#export HADOOP_LOG_DIR=${HADOOP_LOG_DIR}/$USER
-
-# Where log files are stored in the secure data environment.
-export HADOOP_SECURE_DN_LOG_DIR=${HADOOP_LOG_DIR}/${HADOOP_HDFS_USER}
-
-###
-# HDFS Mover specific parameters
-###
-# Specify the JVM options to be used when starting the HDFS Mover.
-# These options will be appended to the options specified as HADOOP_OPTS
-# and therefore may override any similar flags set in HADOOP_OPTS
-#
-# export HADOOP_MOVER_OPTS=""
-
-###
-# Advanced Users Only!
-###
-
-# The directory where pid files are stored. /tmp by default.
-# NOTE: this should be set to a directory that can only be written to by 
-#       the user that will run the hadoop daemons.  Otherwise there is the
-#       potential for a symlink attack.
-export HADOOP_PID_DIR=${HADOOP_PID_DIR}
-export HADOOP_SECURE_DN_PID_DIR=${HADOOP_PID_DIR}
-
-# A string representing this instance of hadoop. $USER by default.
-export HADOOP_IDENT_STRING=$USER

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/hadoop/hdfs-site.xml
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/hadoop/hdfs-site.xml b/docker/griffin_env/conf/hadoop/hdfs-site.xml
deleted file mode 100644
index 8caff3c..0000000
--- a/docker/griffin_env/conf/hadoop/hdfs-site.xml
+++ /dev/null
@@ -1,44 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-<!--
-  Licensed 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. See accompanying LICENSE file.
--->
-
-<!-- Put site-specific property overrides in this file. -->
-
-<configuration>
-<property>
-        <name>dfs.replication</name>
-        <value>1</value>
-    </property>
-    <property>
-        <name>dfs.name.dir</name>
-        <value>file:///data/hadoop-data/nn</value>
-    </property>
-    <property>
-        <name>dfs.data.dir</name>
-        <value>file:///data/hadoop-data/dn</value>
-    </property>
-    <property>
-        <name>dfs.namenode.checkpoint.dir</name>
-        <value>file:///data/hadoop-data/snn</value>
-    </property>
-	<property>
-		<name>dfs.datanode.use.datanode.hostname</name>
-		<value>false</value>
-	</property>
-	<property>
-		<name>dfs.namenode.datanode.registration.ip-hostname-check</name>
-		<value>false</value>
-	</property>
-</configuration>

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/hadoop/mapred-site.xml.template
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/hadoop/mapred-site.xml.template b/docker/griffin_env/conf/hadoop/mapred-site.xml.template
deleted file mode 100644
index a7d7b45..0000000
--- a/docker/griffin_env/conf/hadoop/mapred-site.xml.template
+++ /dev/null
@@ -1,32 +0,0 @@
-<?xml version="1.0"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-<!--
-  Licensed 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. See accompanying LICENSE file.
--->
-
-<!-- Put site-specific property overrides in this file. -->
-
-<configuration>
-<property>
-        <name>mapreduce.framework.name</name>
-        <value>yarn</value>
-    </property>
-	<property>
-		<name>mapreduce.jobhistory.address </name>
-		<value>HOSTNAME:10020</value>
-	</property>
-	<property>
-		<name>mapreduce.jobhistory.webapp.address</name>
-		<value>HOSTNAME:19888</value>
-	</property>
-</configuration>

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/hadoop/slaves
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/hadoop/slaves b/docker/griffin_env/conf/hadoop/slaves
deleted file mode 100644
index 2fbb50c..0000000
--- a/docker/griffin_env/conf/hadoop/slaves
+++ /dev/null
@@ -1 +0,0 @@
-localhost

http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/hadoop/yarn-site.xml.template
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/hadoop/yarn-site.xml.template b/docker/griffin_env/conf/hadoop/yarn-site.xml.template
deleted file mode 100644
index 109bc4d..0000000
--- a/docker/griffin_env/conf/hadoop/yarn-site.xml.template
+++ /dev/null
@@ -1,65 +0,0 @@
-<?xml version="1.0"?>
-<!--
-  Licensed 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. See accompanying LICENSE file.
--->
-<configuration>
-
-<!-- Site specific YARN configuration properties -->
-
-<property>
-        <name>yarn.resourcemanager.hostname</name>
-        <value>HOSTNAME</value>
-    </property>
-    <property>
-        <name>yarn.nodemanager.aux-services</name>
-        <value>mapreduce_shuffle</value>
-    </property>
-    <property>
-        <name>yarn.nodemanager.aux-services.mapreduce.shuffle.class</name>
-        <value>org.apache.hadoop.mapred.ShuffleHandler</value>
-    </property>
-	<property>
-		<name>yarn.nodemanager.log-dirs</name>
-		<value>/tmp/logs</value>
-	</property>
-	<property>
-		<name>yarn.log-aggregation-enable</name>
-		<value>true</value>
-	</property>
-	<property>
-		<name>yarn.nodemanager.remote-app-log-dir</name>
-		<value>/yarn-logs/logs</value>
-	</property>
-	<property>
-		<name>yarn.nodemanager.remote-app-log-dir-suffix</name>
-		<value>logs</value>
-	</property>
-	<property>
-		<name>yarn.log-aggregation.retain-seconds</name>
-		<value>360000</value>
-    </property>
-	<property>
-		<name>yarn.log.server.url</name>
-		<value>http://HOSTNAME:19888/jobhistory/logs</value>
-    </property>
-<!-- for java 8 -->
-<property>
-    <name>yarn.nodemanager.pmem-check-enabled</name>
-    <value>false</value>
-</property>
-
-<property>
-    <name>yarn.nodemanager.vmem-check-enabled</name>
-    <value>false</value>
-</property>
-</configuration>


[5/6] incubator-griffin git commit: remove stale docs

Posted by gu...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_demo/prep/data/demo_src
----------------------------------------------------------------------
diff --git a/docker/griffin_demo/prep/data/demo_src b/docker/griffin_demo/prep/data/demo_src
deleted file mode 100644
index f7c1b64..0000000
--- a/docker/griffin_demo/prep/data/demo_src
+++ /dev/null
@@ -1,125000 +0,0 @@
-0|1|1
-0|2|2
-0|3|3
-0|4|4
-0|5|5
-0|6|6
-0|7|7
-0|8|8
-0|9|9
-0|10|10
-0|11|11
-0|12|12
-0|13|13
-0|14|14
-0|15|15
-0|16|16
-0|17|17
-0|18|18
-0|19|19
-0|20|20
-0|21|21
-0|22|22
-0|23|23
-0|24|24
-0|25|25
-0|26|26
-0|27|27
-0|28|28
-0|29|29
-0|30|30
-0|31|31
-0|32|32
-0|33|33
-0|34|34
-0|35|35
-0|36|36
-0|37|37
-0|38|38
-0|39|39
-0|40|40
-0|41|41
-0|42|42
-0|43|43
-0|44|44
-0|45|45
-0|46|46
-0|47|47
-0|48|48
-0|49|49
-0|50|50
-0|51|51
-0|52|52
-0|53|53
-0|54|54
-0|55|55
-0|56|56
-0|57|57
-0|58|58
-0|59|59
-0|60|60
-0|61|61
-0|62|62
-0|63|63
-0|64|64
-0|65|65
-0|66|66
-0|67|67
-0|68|68
-0|69|69
-0|70|70
-0|71|71
-0|72|72
-0|73|73
-0|74|74
-0|75|75
-0|76|76
-0|77|77
-0|78|78
-0|79|79
-0|80|80
-0|81|81
-0|82|82
-0|83|83
-0|84|84
-0|85|85
-0|86|86
-0|87|87
-0|88|88
-0|89|89
-0|90|90
-0|91|91
-0|92|92
-0|93|93
-0|94|94
-0|95|95
-0|96|96
-0|97|97
-0|98|98
-0|99|99
-0|100|100
-0|101|101
-0|102|102
-0|103|103
-0|104|104
-0|105|105
-0|106|106
-0|107|107
-0|108|108
-0|109|109
-0|110|110
-0|111|111
-0|112|112
-0|113|113
-0|114|114
-0|115|115
-0|116|116
-0|117|117
-0|118|118
-0|119|119
-0|120|120
-0|121|121
-0|122|122
-0|123|123
-0|124|124
-0|125|125
-0|126|126
-0|127|127
-0|128|128
-0|129|129
-0|130|130
-0|131|131
-0|132|132
-0|133|133
-0|134|134
-0|135|135
-0|136|136
-0|137|137
-0|138|138
-0|139|139
-0|140|140
-0|141|141
-0|142|142
-0|143|143
-0|144|144
-0|145|145
-0|146|146
-0|147|147
-0|148|148
-0|149|149
-0|150|150
-0|151|151
-0|152|152
-0|153|153
-0|154|154
-0|155|155
-0|156|156
-0|157|157
-0|158|158
-0|159|159
-0|160|160
-0|161|161
-0|162|162
-0|163|163
-0|164|164
-0|165|165
-0|166|166
-0|167|167
-0|168|168
-0|169|169
-0|170|170
-0|171|171
-0|172|172
-0|173|173
-0|174|174
-0|175|175
-0|176|176
-0|177|177
-0|178|178
-0|179|179
-0|180|180
-0|181|181
-0|182|182
-0|183|183
-0|184|184
-0|185|185
-0|186|186
-0|187|187
-0|188|188
-0|189|189
-0|190|190
-0|191|191
-0|192|192
-0|193|193
-0|194|194
-0|195|195
-0|196|196
-0|197|197
-0|198|198
-0|199|199
-0|200|200
-0|201|201
-0|202|202
-0|203|203
-0|204|204
-0|205|205
-0|206|206
-0|207|207
-0|208|208
-0|209|209
-0|210|210
-0|211|211
-0|212|212
-0|213|213
-0|214|214
-0|215|215
-0|216|216
-0|217|217
-0|218|218
-0|219|219
-0|220|220
-0|221|221
-0|222|222
-0|223|223
-0|224|224
-0|225|225
-0|226|226
-0|227|227
-0|228|228
-0|229|229
-0|230|230
-0|231|231
-0|232|232
-0|233|233
-0|234|234
-0|235|235
-0|236|236
-0|237|237
-0|238|238
-0|239|239
-0|240|240
-0|241|241
-0|242|242
-0|243|243
-0|244|244
-0|245|245
-0|246|246
-0|247|247
-0|248|248
-0|249|249
-0|250|250
-0|251|251
-0|252|252
-0|253|253
-0|254|254
-0|255|255
-0|256|256
-0|257|257
-0|258|258
-0|259|259
-0|260|260
-0|261|261
-0|262|262
-0|263|263
-0|264|264
-0|265|265
-0|266|266
-0|267|267
-0|268|268
-0|269|269
-0|270|270
-0|271|271
-0|272|272
-0|273|273
-0|274|274
-0|275|275
-0|276|276
-0|277|277
-0|278|278
-0|279|279
-0|280|280
-0|281|281
-0|282|282
-0|283|283
-0|284|284
-0|285|285
-0|286|286
-0|287|287
-0|288|288
-0|289|289
-0|290|290
-0|291|291
-0|292|292
-0|293|293
-0|294|294
-0|295|295
-0|296|296
-0|297|297
-0|298|298
-0|299|299
-0|300|300
-0|301|301
-0|302|302
-0|303|303
-0|304|304
-0|305|305
-0|306|306
-0|307|307
-0|308|308
-0|309|309
-0|310|310
-0|311|311
-0|312|312
-0|313|313
-0|314|314
-0|315|315
-0|316|316
-0|317|317
-0|318|318
-0|319|319
-0|320|320
-0|321|321
-0|322|322
-0|323|323
-0|324|324
-0|325|325
-0|326|326
-0|327|327
-0|328|328
-0|329|329
-0|330|330
-0|331|331
-0|332|332
-0|333|333
-0|334|334
-0|335|335
-0|336|336
-0|337|337
-0|338|338
-0|339|339
-0|340|340
-0|341|341
-0|342|342
-0|343|343
-0|344|344
-0|345|345
-0|346|346
-0|347|347
-0|348|348
-0|349|349
-0|350|350
-0|351|351
-0|352|352
-0|353|353
-0|354|354
-0|355|355
-0|356|356
-0|357|357
-0|358|358
-0|359|359
-0|360|360
-0|361|361
-0|362|362
-0|363|363
-0|364|364
-0|365|365
-0|366|366
-0|367|367
-0|368|368
-0|369|369
-0|370|370
-0|371|371
-0|372|372
-0|373|373
-0|374|374
-0|375|375
-0|376|376
-0|377|377
-0|378|378
-0|379|379
-0|380|380
-0|381|381
-0|382|382
-0|383|383
-0|384|384
-0|385|385
-0|386|386
-0|387|387
-0|388|388
-0|389|389
-0|390|390
-0|391|391
-0|392|392
-0|393|393
-0|394|394
-0|395|395
-0|396|396
-0|397|397
-0|398|398
-0|399|399
-0|400|400
-0|401|401
-0|402|402
-0|403|403
-0|404|404
-0|405|405
-0|406|406
-0|407|407
-0|408|408
-0|409|409
-0|410|410
-0|411|411
-0|412|412
-0|413|413
-0|414|414
-0|415|415
-0|416|416
-0|417|417
-0|418|418
-0|419|419
-0|420|420
-0|421|421
-0|422|422
-0|423|423
-0|424|424
-0|425|425
-0|426|426
-0|427|427
-0|428|428
-0|429|429
-0|430|430
-0|431|431
-0|432|432
-0|433|433
-0|434|434
-0|435|435
-0|436|436
-0|437|437
-0|438|438
-0|439|439
-0|440|440
-0|441|441
-0|442|442
-0|443|443
-0|444|444
-0|445|445
-0|446|446
-0|447|447
-0|448|448
-0|449|449
-0|450|450
-0|451|451
-0|452|452
-0|453|453
-0|454|454
-0|455|455
-0|456|456
-0|457|457
-0|458|458
-0|459|459
-0|460|460
-0|461|461
-0|462|462
-0|463|463
-0|464|464
-0|465|465
-0|466|466
-0|467|467
-0|468|468
-0|469|469
-0|470|470
-0|471|471
-0|472|472
-0|473|473
-0|474|474
-0|475|475
-0|476|476
-0|477|477
-0|478|478
-0|479|479
-0|480|480
-0|481|481
-0|482|482
-0|483|483
-0|484|484
-0|485|485
-0|486|486
-0|487|487
-0|488|488
-0|489|489
-0|490|490
-0|491|491
-0|492|492
-0|493|493
-0|494|494
-0|495|495
-0|496|496
-0|497|497
-0|498|498
-0|499|499
-0|500|500
-0|501|501
-0|502|502
-0|503|503
-0|504|504
-0|505|505
-0|506|506
-0|507|507
-0|508|508
-0|509|509
-0|510|510
-0|511|511
-0|512|512
-0|513|513
-0|514|514
-0|515|515
-0|516|516
-0|517|517
-0|518|518
-0|519|519
-0|520|520
-0|521|521
-0|522|522
-0|523|523
-0|524|524
-0|525|525
-0|526|526
-0|527|527
-0|528|528
-0|529|529
-0|530|530
-0|531|531
-0|532|532
-0|533|533
-0|534|534
-0|535|535
-0|536|536
-0|537|537
-0|538|538
-0|539|539
-0|540|540
-0|541|541
-0|542|542
-0|543|543
-0|544|544
-0|545|545
-0|546|546
-0|547|547
-0|548|548
-0|549|549
-0|550|550
-0|551|551
-0|552|552
-0|553|553
-0|554|554
-0|555|555
-0|556|556
-0|557|557
-0|558|558
-0|559|559
-0|560|560
-0|561|561
-0|562|562
-0|563|563
-0|564|564
-0|565|565
-0|566|566
-0|567|567
-0|568|568
-0|569|569
-0|570|570
-0|571|571
-0|572|572
-0|573|573
-0|574|574
-0|575|575
-0|576|576
-0|577|577
-0|578|578
-0|579|579
-0|580|580
-0|581|581
-0|582|582
-0|583|583
-0|584|584
-0|585|585
-0|586|586
-0|587|587
-0|588|588
-0|589|589
-0|590|590
-0|591|591
-0|592|592
-0|593|593
-0|594|594
-0|595|595
-0|596|596
-0|597|597
-0|598|598
-0|599|599
-0|600|600
-0|601|601
-0|602|602
-0|603|603
-0|604|604
-0|605|605
-0|606|606
-0|607|607
-0|608|608
-0|609|609
-0|610|610
-0|611|611
-0|612|612
-0|613|613
-0|614|614
-0|615|615
-0|616|616
-0|617|617
-0|618|618
-0|619|619
-0|620|620
-0|621|621
-0|622|622
-0|623|623
-0|624|624
-0|625|625
-0|626|626
-0|627|627
-0|628|628
-0|629|629
-0|630|630
-0|631|631
-0|632|632
-0|633|633
-0|634|634
-0|635|635
-0|636|636
-0|637|637
-0|638|638
-0|639|639
-0|640|640
-0|641|641
-0|642|642
-0|643|643
-0|644|644
-0|645|645
-0|646|646
-0|647|647
-0|648|648
-0|649|649
-0|650|650
-0|651|651
-0|652|652
-0|653|653
-0|654|654
-0|655|655
-0|656|656
-0|657|657
-0|658|658
-0|659|659
-0|660|660
-0|661|661
-0|662|662
-0|663|663
-0|664|664
-0|665|665
-0|666|666
-0|667|667
-0|668|668
-0|669|669
-0|670|670
-0|671|671
-0|672|672
-0|673|673
-0|674|674
-0|675|675
-0|676|676
-0|677|677
-0|678|678
-0|679|679
-0|680|680
-0|681|681
-0|682|682
-0|683|683
-0|684|684
-0|685|685
-0|686|686
-0|687|687
-0|688|688
-0|689|689
-0|690|690
-0|691|691
-0|692|692
-0|693|693
-0|694|694
-0|695|695
-0|696|696
-0|697|697
-0|698|698
-0|699|699
-0|700|700
-0|701|701
-0|702|702
-0|703|703
-0|704|704
-0|705|705
-0|706|706
-0|707|707
-0|708|708
-0|709|709
-0|710|710
-0|711|711
-0|712|712
-0|713|713
-0|714|714
-0|715|715
-0|716|716
-0|717|717
-0|718|718
-0|719|719
-0|720|720
-0|721|721
-0|722|722
-0|723|723
-0|724|724
-0|725|725
-0|726|726
-0|727|727
-0|728|728
-0|729|729
-0|730|730
-0|731|731
-0|732|732
-0|733|733
-0|734|734
-0|735|735
-0|736|736
-0|737|737
-0|738|738
-0|739|739
-0|740|740
-0|741|741
-0|742|742
-0|743|743
-0|744|744
-0|745|745
-0|746|746
-0|747|747
-0|748|748
-0|749|749
-0|750|750
-0|751|751
-0|752|752
-0|753|753
-0|754|754
-0|755|755
-0|756|756
-0|757|757
-0|758|758
-0|759|759
-0|760|760
-0|761|761
-0|762|762
-0|763|763
-0|764|764
-0|765|765
-0|766|766
-0|767|767
-0|768|768
-0|769|769
-0|770|770
-0|771|771
-0|772|772
-0|773|773
-0|774|774
-0|775|775
-0|776|776
-0|777|777
-0|778|778
-0|779|779
-0|780|780
-0|781|781
-0|782|782
-0|783|783
-0|784|784
-0|785|785
-0|786|786
-0|787|787
-0|788|788
-0|789|789
-0|790|790
-0|791|791
-0|792|792
-0|793|793
-0|794|794
-0|795|795
-0|796|796
-0|797|797
-0|798|798
-0|799|799
-0|800|800
-0|801|801
-0|802|802
-0|803|803
-0|804|804
-0|805|805
-0|806|806
-0|807|807
-0|808|808
-0|809|809
-0|810|810
-0|811|811
-0|812|812
-0|813|813
-0|814|814
-0|815|815
-0|816|816
-0|817|817
-0|818|818
-0|819|819
-0|820|820
-0|821|821
-0|822|822
-0|823|823
-0|824|824
-0|825|825
-0|826|826
-0|827|827
-0|828|828
-0|829|829
-0|830|830
-0|831|831
-0|832|832
-0|833|833
-0|834|834
-0|835|835
-0|836|836
-0|837|837
-0|838|838
-0|839|839
-0|840|840
-0|841|841
-0|842|842
-0|843|843
-0|844|844
-0|845|845
-0|846|846
-0|847|847
-0|848|848
-0|849|849
-0|850|850
-0|851|851
-0|852|852
-0|853|853
-0|854|854
-0|855|855
-0|856|856
-0|857|857
-0|858|858
-0|859|859
-0|860|860
-0|861|861
-0|862|862
-0|863|863
-0|864|864
-0|865|865
-0|866|866
-0|867|867
-0|868|868
-0|869|869
-0|870|870
-0|871|871
-0|872|872
-0|873|873
-0|874|874
-0|875|875
-0|876|876
-0|877|877
-0|878|878
-0|879|879
-0|880|880
-0|881|881
-0|882|882
-0|883|883
-0|884|884
-0|885|885
-0|886|886
-0|887|887
-0|888|888
-0|889|889
-0|890|890
-0|891|891
-0|892|892
-0|893|893
-0|894|894
-0|895|895
-0|896|896
-0|897|897
-0|898|898
-0|899|899
-0|900|900
-0|901|901
-0|902|902
-0|903|903
-0|904|904
-0|905|905
-0|906|906
-0|907|907
-0|908|908
-0|909|909
-0|910|910
-0|911|911
-0|912|912
-0|913|913
-0|914|914
-0|915|915
-0|916|916
-0|917|917
-0|918|918
-0|919|919
-0|920|920
-0|921|921
-0|922|922
-0|923|923
-0|924|924
-0|925|925
-0|926|926
-0|927|927
-0|928|928
-0|929|929
-0|930|930
-0|931|931
-0|932|932
-0|933|933
-0|934|934
-0|935|935
-0|936|936
-0|937|937
-0|938|938
-0|939|939
-0|940|940
-0|941|941
-0|942|942
-0|943|943
-0|944|944
-0|945|945
-0|946|946
-0|947|947
-0|948|948
-0|949|949
-0|950|950
-0|951|951
-0|952|952
-0|953|953
-0|954|954
-0|955|955
-0|956|956
-0|957|957
-0|958|958
-0|959|959
-0|960|960
-0|961|961
-0|962|962
-0|963|963
-0|964|964
-0|965|965
-0|966|966
-0|967|967
-0|968|968
-0|969|969
-0|970|970
-0|971|971
-0|972|972
-0|973|973
-0|974|974
-0|975|975
-0|976|976
-0|977|977
-0|978|978
-0|979|979
-0|980|980
-0|981|981
-0|982|982
-0|983|983
-0|984|984
-0|985|985
-0|986|986
-0|987|987
-0|988|988
-0|989|989
-0|990|990
-0|991|991
-0|992|992
-0|993|993
-0|994|994
-0|995|995
-0|996|996
-0|997|997
-0|998|998
-0|999|999
-0|1000|1000
-1|1|1
-1|2|2
-1|3|3
-1|4|4
-1|5|5
-1|6|6
-1|7|7
-1|8|8
-1|9|9
-1|10|10
-1|11|11
-1|12|12
-1|13|13
-1|14|14
-1|15|15
-1|16|16
-1|17|17
-1|18|18
-1|19|19
-1|20|20
-1|21|21
-1|22|22
-1|23|23
-1|24|24
-1|25|25
-1|26|26
-1|27|27
-1|28|28
-1|29|29
-1|30|30
-1|31|31
-1|32|32
-1|33|33
-1|34|34
-1|35|35
-1|36|36
-1|37|37
-1|38|38
-1|39|39
-1|40|40
-1|41|41
-1|42|42
-1|43|43
-1|44|44
-1|45|45
-1|46|46
-1|47|47
-1|48|48
-1|49|49
-1|50|50
-1|51|51
-1|52|52
-1|53|53
-1|54|54
-1|55|55
-1|56|56
-1|57|57
-1|58|58
-1|59|59
-1|60|60
-1|61|61
-1|62|62
-1|63|63
-1|64|64
-1|65|65
-1|66|66
-1|67|67
-1|68|68
-1|69|69
-1|70|70
-1|71|71
-1|72|72
-1|73|73
-1|74|74
-1|75|75
-1|76|76
-1|77|77
-1|78|78
-1|79|79
-1|80|80
-1|81|81
-1|82|82
-1|83|83
-1|84|84
-1|85|85
-1|86|86
-1|87|87
-1|88|88
-1|89|89
-1|90|90
-1|91|91
-1|92|92
-1|93|93
-1|94|94
-1|95|95
-1|96|96
-1|97|97
-1|98|98
-1|99|99
-1|100|100
-1|101|101
-1|102|102
-1|103|103
-1|104|104
-1|105|105
-1|106|106
-1|107|107
-1|108|108
-1|109|109
-1|110|110
-1|111|111
-1|112|112
-1|113|113
-1|114|114
-1|115|115
-1|116|116
-1|117|117
-1|118|118
-1|119|119
-1|120|120
-1|121|121
-1|122|122
-1|123|123
-1|124|124
-1|125|125
-1|126|126
-1|127|127
-1|128|128
-1|129|129
-1|130|130
-1|131|131
-1|132|132
-1|133|133
-1|134|134
-1|135|135
-1|136|136
-1|137|137
-1|138|138
-1|139|139
-1|140|140
-1|141|141
-1|142|142
-1|143|143
-1|144|144
-1|145|145
-1|146|146
-1|147|147
-1|148|148
-1|149|149
-1|150|150
-1|151|151
-1|152|152
-1|153|153
-1|154|154
-1|155|155
-1|156|156
-1|157|157
-1|158|158
-1|159|159
-1|160|160
-1|161|161
-1|162|162
-1|163|163
-1|164|164
-1|165|165
-1|166|166
-1|167|167
-1|168|168
-1|169|169
-1|170|170
-1|171|171
-1|172|172
-1|173|173
-1|174|174
-1|175|175
-1|176|176
-1|177|177
-1|178|178
-1|179|179
-1|180|180
-1|181|181
-1|182|182
-1|183|183
-1|184|184
-1|185|185
-1|186|186
-1|187|187
-1|188|188
-1|189|189
-1|190|190
-1|191|191
-1|192|192
-1|193|193
-1|194|194
-1|195|195
-1|196|196
-1|197|197
-1|198|198
-1|199|199
-1|200|200
-1|201|201
-1|202|202
-1|203|203
-1|204|204
-1|205|205
-1|206|206
-1|207|207
-1|208|208
-1|209|209
-1|210|210
-1|211|211
-1|212|212
-1|213|213
-1|214|214
-1|215|215
-1|216|216
-1|217|217
-1|218|218
-1|219|219
-1|220|220
-1|221|221
-1|222|222
-1|223|223
-1|224|224
-1|225|225
-1|226|226
-1|227|227
-1|228|228
-1|229|229
-1|230|230
-1|231|231
-1|232|232
-1|233|233
-1|234|234
-1|235|235
-1|236|236
-1|237|237
-1|238|238
-1|239|239
-1|240|240
-1|241|241
-1|242|242
-1|243|243
-1|244|244
-1|245|245
-1|246|246
-1|247|247
-1|248|248
-1|249|249
-1|250|250
-1|251|251
-1|252|252
-1|253|253
-1|254|254
-1|255|255
-1|256|256
-1|257|257
-1|258|258
-1|259|259
-1|260|260
-1|261|261
-1|262|262
-1|263|263
-1|264|264
-1|265|265
-1|266|266
-1|267|267
-1|268|268
-1|269|269
-1|270|270
-1|271|271
-1|272|272
-1|273|273
-1|274|274
-1|275|275
-1|276|276
-1|277|277
-1|278|278
-1|279|279
-1|280|280
-1|281|281
-1|282|282
-1|283|283
-1|284|284
-1|285|285
-1|286|286
-1|287|287
-1|288|288
-1|289|289
-1|290|290
-1|291|291
-1|292|292
-1|293|293
-1|294|294
-1|295|295
-1|296|296
-1|297|297
-1|298|298
-1|299|299
-1|300|300
-1|301|301
-1|302|302
-1|303|303
-1|304|304
-1|305|305
-1|306|306
-1|307|307
-1|308|308
-1|309|309
-1|310|310
-1|311|311
-1|312|312
-1|313|313
-1|314|314
-1|315|315
-1|316|316
-1|317|317
-1|318|318
-1|319|319
-1|320|320
-1|321|321
-1|322|322
-1|323|323
-1|324|324
-1|325|325
-1|326|326
-1|327|327
-1|328|328
-1|329|329
-1|330|330
-1|331|331
-1|332|332
-1|333|333
-1|334|334
-1|335|335
-1|336|336
-1|337|337
-1|338|338
-1|339|339
-1|340|340
-1|341|341
-1|342|342
-1|343|343
-1|344|344
-1|345|345
-1|346|346
-1|347|347
-1|348|348
-1|349|349
-1|350|350
-1|351|351
-1|352|352
-1|353|353
-1|354|354
-1|355|355
-1|356|356
-1|357|357
-1|358|358
-1|359|359
-1|360|360
-1|361|361
-1|362|362
-1|363|363
-1|364|364
-1|365|365
-1|366|366
-1|367|367
-1|368|368
-1|369|369
-1|370|370
-1|371|371
-1|372|372
-1|373|373
-1|374|374
-1|375|375
-1|376|376
-1|377|377
-1|378|378
-1|379|379
-1|380|380
-1|381|381
-1|382|382
-1|383|383
-1|384|384
-1|385|385
-1|386|386
-1|387|387
-1|388|388
-1|389|389
-1|390|390
-1|391|391
-1|392|392
-1|393|393
-1|394|394
-1|395|395
-1|396|396
-1|397|397
-1|398|398
-1|399|399
-1|400|400
-1|401|401
-1|402|402
-1|403|403
-1|404|404
-1|405|405
-1|406|406
-1|407|407
-1|408|408
-1|409|409
-1|410|410
-1|411|411
-1|412|412
-1|413|413
-1|414|414
-1|415|415
-1|416|416
-1|417|417
-1|418|418
-1|419|419
-1|420|420
-1|421|421
-1|422|422
-1|423|423
-1|424|424
-1|425|425
-1|426|426
-1|427|427
-1|428|428
-1|429|429
-1|430|430
-1|431|431
-1|432|432
-1|433|433
-1|434|434
-1|435|435
-1|436|436
-1|437|437
-1|438|438
-1|439|439
-1|440|440
-1|441|441
-1|442|442
-1|443|443
-1|444|444
-1|445|445
-1|446|446
-1|447|447
-1|448|448
-1|449|449
-1|450|450
-1|451|451
-1|452|452
-1|453|453
-1|454|454
-1|455|455
-1|456|456
-1|457|457
-1|458|458
-1|459|459
-1|460|460
-1|461|461
-1|462|462
-1|463|463
-1|464|464
-1|465|465
-1|466|466
-1|467|467
-1|468|468
-1|469|469
-1|470|470
-1|471|471
-1|472|472
-1|473|473
-1|474|474
-1|475|475
-1|476|476
-1|477|477
-1|478|478
-1|479|479
-1|480|480
-1|481|481
-1|482|482
-1|483|483
-1|484|484
-1|485|485
-1|486|486
-1|487|487
-1|488|488
-1|489|489
-1|490|490
-1|491|491
-1|492|492
-1|493|493
-1|494|494
-1|495|495
-1|496|496
-1|497|497
-1|498|498
-1|499|499
-1|500|500
-1|501|501
-1|502|502
-1|503|503
-1|504|504
-1|505|505
-1|506|506
-1|507|507
-1|508|508
-1|509|509
-1|510|510
-1|511|511
-1|512|512
-1|513|513
-1|514|514
-1|515|515
-1|516|516
-1|517|517
-1|518|518
-1|519|519
-1|520|520
-1|521|521
-1|522|522
-1|523|523
-1|524|524
-1|525|525
-1|526|526
-1|527|527
-1|528|528
-1|529|529
-1|530|530
-1|531|531
-1|532|532
-1|533|533
-1|534|534
-1|535|535
-1|536|536
-1|537|537
-1|538|538
-1|539|539
-1|540|540
-1|541|541
-1|542|542
-1|543|543
-1|544|544
-1|545|545
-1|546|546
-1|547|547
-1|548|548
-1|549|549
-1|550|550
-1|551|551
-1|552|552
-1|553|553
-1|554|554
-1|555|555
-1|556|556
-1|557|557
-1|558|558
-1|559|559
-1|560|560
-1|561|561
-1|562|562
-1|563|563
-1|564|564
-1|565|565
-1|566|566
-1|567|567
-1|568|568
-1|569|569
-1|570|570
-1|571|571
-1|572|572
-1|573|573
-1|574|574
-1|575|575
-1|576|576
-1|577|577
-1|578|578
-1|579|579
-1|580|580
-1|581|581
-1|582|582
-1|583|583
-1|584|584
-1|585|585
-1|586|586
-1|587|587
-1|588|588
-1|589|589
-1|590|590
-1|591|591
-1|592|592
-1|593|593
-1|594|594
-1|595|595
-1|596|596
-1|597|597
-1|598|598
-1|599|599
-1|600|600
-1|601|601
-1|602|602
-1|603|603
-1|604|604
-1|605|605
-1|606|606
-1|607|607
-1|608|608
-1|609|609
-1|610|610
-1|611|611
-1|612|612
-1|613|613
-1|614|614
-1|615|615
-1|616|616
-1|617|617
-1|618|618
-1|619|619
-1|620|620
-1|621|621
-1|622|622
-1|623|623
-1|624|624
-1|625|625
-1|626|626
-1|627|627
-1|628|628
-1|629|629
-1|630|630
-1|631|631
-1|632|632
-1|633|633
-1|634|634
-1|635|635
-1|636|636
-1|637|637
-1|638|638
-1|639|639
-1|640|640
-1|641|641
-1|642|642
-1|643|643
-1|644|644
-1|645|645
-1|646|646
-1|647|647
-1|648|648
-1|649|649
-1|650|650
-1|651|651
-1|652|652
-1|653|653
-1|654|654
-1|655|655
-1|656|656
-1|657|657
-1|658|658
-1|659|659
-1|660|660
-1|661|661
-1|662|662
-1|663|663
-1|664|664
-1|665|665
-1|666|666
-1|667|667
-1|668|668
-1|669|669
-1|670|670
-1|671|671
-1|672|672
-1|673|673
-1|674|674
-1|675|675
-1|676|676
-1|677|677
-1|678|678
-1|679|679
-1|680|680
-1|681|681
-1|682|682
-1|683|683
-1|684|684
-1|685|685
-1|686|686
-1|687|687
-1|688|688
-1|689|689
-1|690|690
-1|691|691
-1|692|692
-1|693|693
-1|694|694
-1|695|695
-1|696|696
-1|697|697
-1|698|698
-1|699|699
-1|700|700
-1|701|701
-1|702|702
-1|703|703
-1|704|704
-1|705|705
-1|706|706
-1|707|707
-1|708|708
-1|709|709
-1|710|710
-1|711|711
-1|712|712
-1|713|713
-1|714|714
-1|715|715
-1|716|716
-1|717|717
-1|718|718
-1|719|719
-1|720|720
-1|721|721
-1|722|722
-1|723|723
-1|724|724
-1|725|725
-1|726|726
-1|727|727
-1|728|728
-1|729|729
-1|730|730
-1|731|731
-1|732|732
-1|733|733
-1|734|734
-1|735|735
-1|736|736
-1|737|737
-1|738|738
-1|739|739
-1|740|740
-1|741|741
-1|742|742
-1|743|743
-1|744|744
-1|745|745
-1|746|746
-1|747|747
-1|748|748
-1|749|749
-1|750|750
-1|751|751
-1|752|752
-1|753|753
-1|754|754
-1|755|755
-1|756|756
-1|757|757
-1|758|758
-1|759|759
-1|760|760
-1|761|761
-1|762|762
-1|763|763
-1|764|764
-1|765|765
-1|766|766
-1|767|767
-1|768|768
-1|769|769
-1|770|770
-1|771|771
-1|772|772
-1|773|773
-1|774|774
-1|775|775
-1|776|776
-1|777|777
-1|778|778
-1|779|779
-1|780|780
-1|781|781
-1|782|782
-1|783|783
-1|784|784
-1|785|785
-1|786|786
-1|787|787
-1|788|788
-1|789|789
-1|790|790
-1|791|791
-1|792|792
-1|793|793
-1|794|794
-1|795|795
-1|796|796
-1|797|797
-1|798|798
-1|799|799
-1|800|800
-1|801|801
-1|802|802
-1|803|803
-1|804|804
-1|805|805
-1|806|806
-1|807|807
-1|808|808
-1|809|809
-1|810|810
-1|811|811
-1|812|812
-1|813|813
-1|814|814
-1|815|815
-1|816|816
-1|817|817
-1|818|818
-1|819|819
-1|820|820
-1|821|821
-1|822|822
-1|823|823
-1|824|824
-1|825|825
-1|826|826
-1|827|827
-1|828|828
-1|829|829
-1|830|830
-1|831|831
-1|832|832
-1|833|833
-1|834|834
-1|835|835
-1|836|836
-1|837|837
-1|838|838
-1|839|839
-1|840|840
-1|841|841
-1|842|842
-1|843|843
-1|844|844
-1|845|845
-1|846|846
-1|847|847
-1|848|848
-1|849|849
-1|850|850
-1|851|851
-1|852|852
-1|853|853
-1|854|854
-1|855|855
-1|856|856
-1|857|857
-1|858|858
-1|859|859
-1|860|860
-1|861|861
-1|862|862
-1|863|863
-1|864|864
-1|865|865
-1|866|866
-1|867|867
-1|868|868
-1|869|869
-1|870|870
-1|871|871
-1|872|872
-1|873|873
-1|874|874
-1|875|875
-1|876|876
-1|877|877
-1|878|878
-1|879|879
-1|880|880
-1|881|881
-1|882|882
-1|883|883
-1|884|884
-1|885|885
-1|886|886
-1|887|887
-1|888|888
-1|889|889
-1|890|890
-1|891|891
-1|892|892
-1|893|893
-1|894|894
-1|895|895
-1|896|896
-1|897|897
-1|898|898
-1|899|899
-1|900|900
-1|901|901
-1|902|902
-1|903|903
-1|904|904
-1|905|905
-1|906|906
-1|907|907
-1|908|908
-1|909|909
-1|910|910
-1|911|911
-1|912|912
-1|913|913
-1|914|914
-1|915|915
-1|916|916
-1|917|917
-1|918|918
-1|919|919
-1|920|920
-1|921|921
-1|922|922
-1|923|923
-1|924|924
-1|925|925
-1|926|926
-1|927|927
-1|928|928
-1|929|929
-1|930|930
-1|931|931
-1|932|932
-1|933|933
-1|934|934
-1|935|935
-1|936|936
-1|937|937
-1|938|938
-1|939|939
-1|940|940
-1|941|941
-1|942|942
-1|943|943
-1|944|944
-1|945|945
-1|946|946
-1|947|947
-1|948|948
-1|949|949
-1|950|950
-1|951|951
-1|952|952
-1|953|953
-1|954|954
-1|955|955
-1|956|956
-1|957|957
-1|958|958
-1|959|959
-1|960|960
-1|961|961
-1|962|962
-1|963|963
-1|964|964
-1|965|965
-1|966|966
-1|967|967
-1|968|968
-1|969|969
-1|970|970
-1|971|971
-1|972|972
-1|973|973
-1|974|974
-1|975|975
-1|976|976
-1|977|977
-1|978|978
-1|979|979
-1|980|980
-1|981|981
-1|982|982
-1|983|983
-1|984|984
-1|985|985
-1|986|986
-1|987|987
-1|988|988
-1|989|989
-1|990|990
-1|991|991
-1|992|992
-1|993|993
-1|994|994
-1|995|995
-1|996|996
-1|997|997
-1|998|998
-1|999|999
-1|1000|1000
-2|1|1
-2|2|2
-2|3|3
-2|4|4
-2|5|5
-2|6|6
-2|7|7
-2|8|8
-2|9|9
-2|10|10
-2|11|11
-2|12|12
-2|13|13
-2|14|14
-2|15|15
-2|16|16
-2|17|17
-2|18|18
-2|19|19
-2|20|20
-2|21|21
-2|22|22
-2|23|23
-2|24|24
-2|25|25
-2|26|26
-2|27|27
-2|28|28
-2|29|29
-2|30|30
-2|31|31
-2|32|32
-2|33|33
-2|34|34
-2|35|35
-2|36|36
-2|37|37
-2|38|38
-2|39|39
-2|40|40
-2|41|41
-2|42|42
-2|43|43
-2|44|44
-2|45|45
-2|46|46
-2|47|47
-2|48|48
-2|49|49
-2|50|50
-2|51|51
-2|52|52
-2|53|53
-2|54|54
-2|55|55
-2|56|56
-2|57|57
-2|58|58
-2|59|59
-2|60|60
-2|61|61
-2|62|62
-2|63|63
-2|64|64
-2|65|65
-2|66|66
-2|67|67
-2|68|68
-2|69|69
-2|70|70
-2|71|71
-2|72|72
-2|73|73
-2|74|74
-2|75|75
-2|76|76
-2|77|77
-2|78|78
-2|79|79
-2|80|80
-2|81|81
-2|82|82
-2|83|83
-2|84|84
-2|85|85
-2|86|86
-2|87|87
-2|88|88
-2|89|89
-2|90|90
-2|91|91
-2|92|92
-2|93|93
-2|94|94
-2|95|95
-2|96|96
-2|97|97
-2|98|98
-2|99|99
-2|100|100
-2|101|101
-2|102|102
-2|103|103
-2|104|104
-2|105|105
-2|106|106
-2|107|107
-2|108|108
-2|109|109
-2|110|110
-2|111|111
-2|112|112
-2|113|113
-2|114|114
-2|115|115
-2|116|116
-2|117|117
-2|118|118
-2|119|119
-2|120|120
-2|121|121
-2|122|122
-2|123|123
-2|124|124
-2|125|125
-2|126|126
-2|127|127
-2|128|128
-2|129|129
-2|130|130
-2|131|131
-2|132|132
-2|133|133
-2|134|134
-2|135|135
-2|136|136
-2|137|137
-2|138|138
-2|139|139
-2|140|140
-2|141|141
-2|142|142
-2|143|143
-2|144|144
-2|145|145
-2|146|146
-2|147|147
-2|148|148
-2|149|149
-2|150|150
-2|151|151
-2|152|152
-2|153|153
-2|154|154
-2|155|155
-2|156|156
-2|157|157
-2|158|158
-2|159|159
-2|160|160
-2|161|161
-2|162|162
-2|163|163
-2|164|164
-2|165|165
-2|166|166
-2|167|167
-2|168|168
-2|169|169
-2|170|170
-2|171|171
-2|172|172
-2|173|173
-2|174|174
-2|175|175
-2|176|176
-2|177|177
-2|178|178
-2|179|179
-2|180|180
-2|181|181
-2|182|182
-2|183|183
-2|184|184
-2|185|185
-2|186|186
-2|187|187
-2|188|188
-2|189|189
-2|190|190
-2|191|191
-2|192|192
-2|193|193
-2|194|194
-2|195|195
-2|196|196
-2|197|197
-2|198|198
-2|199|199
-2|200|200
-2|201|201
-2|202|202
-2|203|203
-2|204|204
-2|205|205
-2|206|206
-2|207|207
-2|208|208
-2|209|209
-2|210|210
-2|211|211
-2|212|212
-2|213|213
-2|214|214
-2|215|215
-2|216|216
-2|217|217
-2|218|218
-2|219|219
-2|220|220
-2|221|221
-2|222|222
-2|223|223
-2|224|224
-2|225|225
-2|226|226
-2|227|227
-2|228|228
-2|229|229
-2|230|230
-2|231|231
-2|232|232
-2|233|233
-2|234|234
-2|235|235
-2|236|236
-2|237|237
-2|238|238
-2|239|239
-2|240|240
-2|241|241
-2|242|242
-2|243|243
-2|244|244
-2|245|245
-2|246|246
-2|247|247
-2|248|248
-2|249|249
-2|250|250
-2|251|251
-2|252|252
-2|253|253
-2|254|254
-2|255|255
-2|256|256
-2|257|257
-2|258|258
-2|259|259
-2|260|260
-2|261|261
-2|262|262
-2|263|263
-2|264|264
-2|265|265
-2|266|266
-2|267|267
-2|268|268
-2|269|269
-2|270|270
-2|271|271
-2|272|272
-2|273|273
-2|274|274
-2|275|275
-2|276|276
-2|277|277
-2|278|278
-2|279|279
-2|280|280
-2|281|281
-2|282|282
-2|283|283
-2|284|284
-2|285|285
-2|286|286
-2|287|287
-2|288|288
-2|289|289
-2|290|290
-2|291|291
-2|292|292
-2|293|293
-2|294|294
-2|295|295
-2|296|296
-2|297|297
-2|298|298
-2|299|299
-2|300|300
-2|301|301
-2|302|302
-2|303|303
-2|304|304
-2|305|305
-2|306|306
-2|307|307
-2|308|308
-2|309|309
-2|310|310
-2|311|311
-2|312|312
-2|313|313
-2|314|314
-2|315|315
-2|316|316
-2|317|317
-2|318|318
-2|319|319
-2|320|320
-2|321|321
-2|322|322
-2|323|323
-2|324|324
-2|325|325
-2|326|326
-2|327|327
-2|328|328
-2|329|329
-2|330|330
-2|331|331
-2|332|332
-2|333|333
-2|334|334
-2|335|335
-2|336|336
-2|337|337
-2|338|338
-2|339|339
-2|340|340
-2|341|341
-2|342|342
-2|343|343
-2|344|344
-2|345|345
-2|346|346
-2|347|347
-2|348|348
-2|349|349
-2|350|350
-2|351|351
-2|352|352
-2|353|353
-2|354|354
-2|355|355
-2|356|356
-2|357|357
-2|358|358
-2|359|359
-2|360|360
-2|361|361
-2|362|362
-2|363|363
-2|364|364
-2|365|365
-2|366|366
-2|367|367
-2|368|368
-2|369|369
-2|370|370
-2|371|371
-2|372|372
-2|373|373
-2|374|374
-2|375|375
-2|376|376
-2|377|377
-2|378|378
-2|379|379
-2|380|380
-2|381|381
-2|382|382
-2|383|383
-2|384|384
-2|385|385
-2|386|386
-2|387|387
-2|388|388
-2|389|389
-2|390|390
-2|391|391
-2|392|392
-2|393|393
-2|394|394
-2|395|395
-2|396|396
-2|397|397
-2|398|398
-2|399|399
-2|400|400
-2|401|401
-2|402|402
-2|403|403
-2|404|404
-2|405|405
-2|406|406
-2|407|407
-2|408|408
-2|409|409
-2|410|410
-2|411|411
-2|412|412
-2|413|413
-2|414|414
-2|415|415
-2|416|416
-2|417|417
-2|418|418
-2|419|419
-2|420|420
-2|421|421
-2|422|422
-2|423|423
-2|424|424
-2|425|425
-2|426|426
-2|427|427
-2|428|428
-2|429|429
-2|430|430
-2|431|431
-2|432|432
-2|433|433
-2|434|434
-2|435|435
-2|436|436
-2|437|437
-2|438|438
-2|439|439
-2|440|440
-2|441|441
-2|442|442
-2|443|443
-2|444|444
-2|445|445
-2|446|446
-2|447|447
-2|448|448
-2|449|449
-2|450|450
-2|451|451
-2|452|452
-2|453|453
-2|454|454
-2|455|455
-2|456|456
-2|457|457
-2|458|458
-2|459|459
-2|460|460
-2|461|461
-2|462|462
-2|463|463
-2|464|464
-2|465|465
-2|466|466
-2|467|467
-2|468|468
-2|469|469
-2|470|470
-2|471|471
-2|472|472
-2|473|473
-2|474|474
-2|475|475
-2|476|476
-2|477|477
-2|478|478
-2|479|479
-2|480|480
-2|481|481
-2|482|482
-2|483|483
-2|484|484
-2|485|485
-2|486|486
-2|487|487
-2|488|488
-2|489|489
-2|490|490
-2|491|491
-2|492|492
-2|493|493
-2|494|494
-2|495|495
-2|496|496
-2|497|497
-2|498|498
-2|499|499
-2|500|500
-2|501|501
-2|502|502
-2|503|503
-2|504|504
-2|505|505
-2|506|506
-2|507|507
-2|508|508
-2|509|509
-2|510|510
-2|511|511
-2|512|512
-2|513|513
-2|514|514
-2|515|515
-2|516|516
-2|517|517
-2|518|518
-2|519|519
-2|520|520
-2|521|521
-2|522|522
-2|523|523
-2|524|524
-2|525|525
-2|526|526
-2|527|527
-2|528|528
-2|529|529
-2|530|530
-2|531|531
-2|532|532
-2|533|533
-2|534|534
-2|535|535
-2|536|536
-2|537|537
-2|538|538
-2|539|539
-2|540|540
-2|541|541
-2|542|542
-2|543|543
-2|544|544
-2|545|545
-2|546|546
-2|547|547
-2|548|548
-2|549|549
-2|550|550
-2|551|551
-2|552|552
-2|553|553
-2|554|554
-2|555|555
-2|556|556
-2|557|557
-2|558|558
-2|559|559
-2|560|560
-2|561|561
-2|562|562
-2|563|563
-2|564|564
-2|565|565
-2|566|566
-2|567|567
-2|568|568
-2|569|569
-2|570|570
-2|571|571
-2|572|572
-2|573|573
-2|574|574
-2|575|575
-2|576|576
-2|577|577
-2|578|578
-2|579|579
-2|580|580
-2|581|581
-2|582|582
-2|583|583
-2|584|584
-2|585|585
-2|586|586
-2|587|587
-2|588|588
-2|589|589
-2|590|590
-2|591|591
-2|592|592
-2|593|593
-2|594|594
-2|595|595
-2|596|596
-2|597|597
-2|598|598
-2|599|599
-2|600|600
-2|601|601
-2|602|602
-2|603|603
-2|604|604
-2|605|605
-2|606|606
-2|607|607
-2|608|608
-2|609|609
-2|610|610
-2|611|611
-2|612|612
-2|613|613
-2|614|614
-2|615|615
-2|616|616
-2|617|617
-2|618|618
-2|619|619
-2|620|620
-2|621|621
-2|622|622
-2|623|623
-2|624|624
-2|625|625
-2|626|626
-2|627|627
-2|628|628
-2|629|629
-2|630|630
-2|631|631
-2|632|632
-2|633|633
-2|634|634
-2|635|635
-2|636|636
-2|637|637
-2|638|638
-2|639|639
-2|640|640
-2|641|641
-2|642|642
-2|643|643
-2|644|644
-2|645|645
-2|646|646
-2|647|647
-2|648|648
-2|649|649
-2|650|650
-2|651|651
-2|652|652
-2|653|653
-2|654|654
-2|655|655
-2|656|656
-2|657|657
-2|658|658
-2|659|659
-2|660|660
-2|661|661
-2|662|662
-2|663|663
-2|664|664
-2|665|665
-2|666|666
-2|667|667
-2|668|668
-2|669|669
-2|670|670
-2|671|671
-2|672|672
-2|673|673
-2|674|674
-2|675|675
-2|676|676
-2|677|677
-2|678|678
-2|679|679
-2|680|680
-2|681|681
-2|682|682
-2|683|683
-2|684|684
-2|685|685
-2|686|686
-2|687|687
-2|688|688
-2|689|689
-2|690|690
-2|691|691
-2|692|692
-2|693|693
-2|694|694
-2|695|695
-2|696|696
-2|697|697
-2|698|698
-2|699|699
-2|700|700
-2|701|701
-2|702|702
-2|703|703
-2|704|704
-2|705|705
-2|706|706
-2|707|707
-2|708|708
-2|709|709
-2|710|710
-2|711|711
-2|712|712
-2|713|713
-2|714|714
-2|715|715
-2|716|716
-2|717|717
-2|718|718
-2|719|719
-2|720|720
-2|721|721
-2|722|722
-2|723|723
-2|724|724
-2|725|725
-2|726|726
-2|727|727
-2|728|728
-2|729|729
-2|730|730
-2|731|731
-2|732|732
-2|733|733
-2|734|734
-2|735|735
-2|736|736
-2|737|737
-2|738|738
-2|739|739
-2|740|740
-2|741|741
-2|742|742
-2|743|743
-2|744|744
-2|745|745
-2|746|746
-2|747|747
-2|748|748
-2|749|749
-2|750|750
-2|751|751
-2|752|752
-2|753|753
-2|754|754
-2|755|755
-2|756|756
-2|757|757
-2|758|758
-2|759|759
-2|760|760
-2|761|761
-2|762|762
-2|763|763
-2|764|764
-2|765|765
-2|766|766
-2|767|767
-2|768|768
-2|769|769
-2|770|770
-2|771|771
-2|772|772
-2|773|773
-2|774|774
-2|775|775
-2|776|776
-2|777|777
-2|778|778
-2|779|779
-2|780|780
-2|781|781
-2|782|782
-2|783|783
-2|784|784
-2|785|785
-2|786|786
-2|787|787
-2|788|788
-2|789|789
-2|790|790
-2|791|791
-2|792|792
-2|793|793
-2|794|794
-2|795|795
-2|796|796
-2|797|797
-2|798|798
-2|799|799
-2|800|800
-2|801|801
-2|802|802
-2|803|803
-2|804|804
-2|805|805
-2|806|806
-2|807|807
-2|808|808
-2|809|809
-2|810|810
-2|811|811
-2|812|812
-2|813|813
-2|814|814
-2|815|815
-2|816|816
-2|817|817
-2|818|818
-2|819|819
-2|820|820
-2|821|821
-2|822|822
-2|823|823
-2|824|824
-2|825|825
-2|826|826
-2|827|827
-2|828|828
-2|829|829
-2|830|830
-2|831|831
-2|832|832
-2|833|833
-2|834|834
-2|835|835
-2|836|836
-2|837|837
-2|838|838
-2|839|839
-2|840|840
-2|841|841
-2|842|842
-2|843|843
-2|844|844
-2|845|845
-2|846|846
-2|847|847
-2|848|848
-2|849|849
-2|850|850
-2|851|851
-2|852|852
-2|853|853
-2|854|854
-2|855|855
-2|856|856
-2|857|857
-2|858|858
-2|859|859
-2|860|860
-2|861|861
-2|862|862
-2|863|863
-2|864|864
-2|865|865
-2|866|866
-2|867|867
-2|868|868
-2|869|869
-2|870|870
-2|871|871
-2|872|872
-2|873|873
-2|874|874
-2|875|875
-2|876|876
-2|877|877
-2|878|878
-2|879|879
-2|880|880
-2|881|881
-2|882|882
-2|883|883
-2|884|884
-2|885|885
-2|886|886
-2|887|887
-2|888|888
-2|889|889
-2|890|890
-2|891|891
-2|892|892
-2|893|893
-2|894|894
-2|895|895
-2|896|896
-2|897|897
-2|898|898
-2|899|899
-2|900|900
-2|901|901
-2|902|902
-2|903|903
-2|904|904
-2|905|905
-2|906|906
-2|907|907
-2|908|908
-2|909|909
-2|910|910
-2|911|911
-2|912|912
-2|913|913
-2|914|914
-2|915|915
-2|916|916
-2|917|917
-2|918|918
-2|919|919
-2|920|920
-2|921|921
-2|922|922
-2|923|923
-2|924|924
-2|925|925
-2|926|926
-2|927|927
-2|928|928
-2|929|929
-2|930|930
-2|931|931
-2|932|932
-2|933|933
-2|934|934
-2|935|935
-2|936|936
-2|937|937
-2|938|938
-2|939|939
-2|940|940
-2|941|941
-2|942|942
-2|943|943
-2|944|944
-2|945|945
-2|946|946
-2|947|947
-2|948|948
-2|949|949
-2|950|950
-2|951|951
-2|952|952
-2|953|953
-2|954|954
-2|955|955
-2|956|956
-2|957|957
-2|958|958
-2|959|959
-2|960|960
-2|961|961
-2|962|962
-2|963|963
-2|964|964
-2|965|965
-2|966|966
-2|967|967
-2|968|968
-2|969|969
-2|970|970
-2|971|971
-2|972|972
-2|973|973
-2|974|974
-2|975|975
-2|976|976
-2|977|977
-2|978|978
-2|979|979
-2|980|980
-2|981|981
-2|982|982
-2|983|983
-2|984|984
-2|985|985
-2|986|986
-2|987|987
-2|988|988
-2|989|989
-2|990|990
-2|991|991
-2|992|992
-2|993|993
-2|994|994
-2|995|995
-2|996|996
-2|997|997
-2|998|998
-2|999|999
-2|1000|1000
-3|1|1
-3|2|2
-3|3|3
-3|4|4
-3|5|5
-3|6|6
-3|7|7
-3|8|8
-3|9|9
-3|10|10
-3|11|11
-3|12|12
-3|13|13
-3|14|14
-3|15|15
-3|16|16
-3|17|17
-3|18|18
-3|19|19
-3|20|20
-3|21|21
-3|22|22
-3|23|23
-3|24|24
-3|25|25
-3|26|26
-3|27|27
-3|28|28
-3|29|29
-3|30|30
-3|31|31
-3|32|32
-3|33|33
-3|34|34
-3|35|35
-3|36|36
-3|37|37
-3|38|38
-3|39|39
-3|40|40
-3|41|41
-3|42|42
-3|43|43
-3|44|44
-3|45|45
-3|46|46
-3|47|47
-3|48|48
-3|49|49
-3|50|50
-3|51|51
-3|52|52
-3|53|53
-3|54|54
-3|55|55
-3|56|56
-3|57|57
-3|58|58
-3|59|59
-3|60|60
-3|61|61
-3|62|62
-3|63|63
-3|64|64
-3|65|65
-3|66|66
-3|67|67
-3|68|68
-3|69|69
-3|70|70
-3|71|71
-3|72|72
-3|73|73
-3|74|74
-3|75|75
-3|76|76
-3|77|77
-3|78|78
-3|79|79
-3|80|80
-3|81|81
-3|82|82
-3|83|83
-3|84|84
-3|85|85
-3|86|86
-3|87|87
-3|88|88
-3|89|89
-3|90|90
-3|91|91
-3|92|92
-3|93|93
-3|94|94
-3|95|95
-3|96|96
-3|97|97
-3|98|98
-3|99|99
-3|100|100
-3|101|101
-3|102|102
-3|103|103
-3|104|104
-3|105|105
-3|106|106
-3|107|107
-3|108|108
-3|109|109
-3|110|110
-3|111|111
-3|112|112
-3|113|113
-3|114|114
-3|115|115
-3|116|116
-3|117|117
-3|118|118
-3|119|119
-3|120|120
-3|121|121
-3|122|122
-3|123|123
-3|124|124
-3|125|125
-3|126|126
-3|127|127
-3|128|128
-3|129|129
-3|130|130
-3|131|131
-3|132|132
-3|133|133
-3|134|134
-3|135|135
-3|136|136
-3|137|137
-3|138|138
-3|139|139
-3|140|140
-3|141|141
-3|142|142
-3|143|143
-3|144|144
-3|145|145
-3|146|146
-3|147|147
-3|148|148
-3|149|149
-3|150|150
-3|151|151
-3|152|152
-3|153|153
-3|154|154
-3|155|155
-3|156|156
-3|157|157
-3|158|158
-3|159|159
-3|160|160
-3|161|161
-3|162|162
-3|163|163
-3|164|164
-3|165|165
-3|166|166
-3|167|167
-3|168|168
-3|169|169
-3|170|170
-3|171|171
-3|172|172
-3|173|173
-3|174|174
-3|175|175
-3|176|176
-3|177|177
-3|178|178
-3|179|179
-3|180|180
-3|181|181
-3|182|182
-3|183|183
-3|184|184
-3|185|185
-3|186|186
-3|187|187
-3|188|188
-3|189|189
-3|190|190
-3|191|191
-3|192|192
-3|193|193
-3|194|194
-3|195|195
-3|196|196
-3|197|197
-3|198|198
-3|199|199
-3|200|200
-3|201|201
-3|202|202
-3|203|203
-3|204|204
-3|205|205
-3|206|206
-3|207|207
-3|208|208
-3|209|209
-3|210|210
-3|211|211
-3|212|212
-3|213|213
-3|214|214
-3|215|215
-3|216|216
-3|217|217
-3|218|218
-3|219|219
-3|220|220
-3|221|221
-3|222|222
-3|223|223
-3|224|224
-3|225|225
-3|226|226
-3|227|227
-3|228|228
-3|229|229
-3|230|230
-3|231|231
-3|232|232
-3|233|233
-3|234|234
-3|235|235
-3|236|236
-3|237|237
-3|238|238
-3|239|239
-3|240|240
-3|241|241
-3|242|242
-3|243|243
-3|244|244
-3|245|245
-3|246|246
-3|247|247
-3|248|248
-3|249|249
-3|250|250
-3|251|251
-3|252|252
-3|253|253
-3|254|254
-3|255|255
-3|256|256
-3|257|257
-3|258|258
-3|259|259
-3|260|260
-3|261|261
-3|262|262
-3|263|263
-3|264|264
-3|265|265
-3|266|266
-3|267|267
-3|268|268
-3|269|269
-3|270|270
-3|271|271
-3|272|272
-3|273|273
-3|274|274
-3|275|275
-3|276|276
-3|277|277
-3|278|278
-3|279|279
-3|280|280
-3|281|281
-3|282|282
-3|283|283
-3|284|284
-3|285|285
-3|286|286
-3|287|287
-3|288|288
-3|289|289
-3|290|290
-3|291|291
-3|292|292
-3|293|293
-3|294|294
-3|295|295
-3|296|296
-3|297|297
-3|298|298
-3|299|299
-3|300|300
-3|301|301
-3|302|302
-3|303|303
-3|304|304
-3|305|305
-3|306|306
-3|307|307
-3|308|308
-3|309|309
-3|310|310
-3|311|311
-3|312|312
-3|313|313
-3|314|314
-3|315|315
-3|316|316
-3|317|317
-3|318|318
-3|319|319
-3|320|320
-3|321|321
-3|322|322
-3|323|323
-3|324|324
-3|325|325
-3|326|326
-3|327|327
-3|328|328
-3|329|329
-3|330|330
-3|331|331
-3|332|332
-3|333|333
-3|334|334
-3|335|335
-3|336|336
-3|337|337
-3|338|338
-3|339|339
-3|340|340
-3|341|341
-3|342|342
-3|343|343
-3|344|344
-3|345|345
-3|346|346
-3|347|347
-3|348|348
-3|349|349
-3|350|350
-3|351|351
-3|352|352
-3|353|353
-3|354|354
-3|355|355
-3|356|356
-3|357|357
-3|358|358
-3|359|359
-3|360|360
-3|361|361
-3|362|362
-3|363|363
-3|364|364
-3|365|365
-3|366|366
-3|367|367
-3|368|368
-3|369|369
-3|370|370
-3|371|371
-3|372|372
-3|373|373
-3|374|374
-3|375|375
-3|376|376
-3|377|377
-3|378|378
-3|379|379
-3|380|380
-3|381|381
-3|382|382
-3|383|383
-3|384|384
-3|385|385
-3|386|386
-3|387|387
-3|388|388
-3|389|389
-3|390|390
-3|391|391
-3|392|392
-3|393|393
-3|394|394
-3|395|395
-3|396|396
-3|397|397
-3|398|398
-3|399|399
-3|400|400
-3|401|401
-3|402|402
-3|403|403
-3|404|404
-3|405|405
-3|406|406
-3|407|407
-3|408|408
-3|409|409
-3|410|410
-3|411|411
-3|412|412
-3|413|413
-3|414|414
-3|415|415
-3|416|416
-3|417|417
-3|418|418
-3|419|419
-3|420|420
-3|421|421
-3|422|422
-3|423|423
-3|424|424
-3|425|425
-3|426|426
-3|427|427
-3|428|428
-3|429|429
-3|430|430
-3|431|431
-3|432|432
-3|433|433
-3|434|434
-3|435|435
-3|436|436
-3|437|437
-3|438|438
-3|439|439
-3|440|440
-3|441|441
-3|442|442
-3|443|443
-3|444|444
-3|445|445
-3|446|446
-3|447|447
-3|448|448
-3|449|449
-3|450|450
-3|451|451
-3|452|452
-3|453|453
-3|454|454
-3|455|455
-3|456|456
-3|457|457
-3|458|458
-3|459|459
-3|460|460
-3|461|461
-3|462|462
-3|463|463
-3|464|464
-3|465|465
-3|466|466
-3|467|467
-3|468|468
-3|469|469
-3|470|470
-3|471|471
-3|472|472
-3|473|473
-3|474|474
-3|475|475
-3|476|476
-3|477|477
-3|478|478
-3|479|479
-3|480|480
-3|481|481
-3|482|482
-3|483|483
-3|484|484
-3|485|485
-3|486|486
-3|487|487
-3|488|488
-3|489|489
-3|490|490
-3|491|491
-3|492|492
-3|493|493
-3|494|494
-3|495|495
-3|496|496
-3|497|497
-3|498|498
-3|499|499
-3|500|500
-3|501|501
-3|502|502
-3|503|503
-3|504|504
-3|505|505
-3|506|506
-3|507|507
-3|508|508
-3|509|509
-3|510|510
-3|511|511
-3|512|512
-3|513|513
-3|514|514
-3|515|515
-3|516|516
-3|517|517
-3|518|518
-3|519|519
-3|520|520
-3|521|521
-3|522|522
-3|523|523
-3|524|524
-3|525|525
-3|526|526
-3|527|527
-3|528|528
-3|529|529
-3|530|530
-3|531|531
-3|532|532
-3|533|533
-3|534|534
-3|535|535
-3|536|536
-3|537|537
-3|538|538
-3|539|539
-3|540|540
-3|541|541
-3|542|542
-3|543|543
-3|544|544
-3|545|545
-3|546|546
-3|547|547
-3|548|548
-3|549|549
-3|550|550
-3|551|551
-3|552|552
-3|553|553
-3|554|554
-3|555|555
-3|556|556
-3|557|557
-3|558|558
-3|559|559
-3|560|560
-3|561|561
-3|562|562
-3|563|563
-3|564|564
-3|565|565
-3|566|566
-3|567|567
-3|568|568
-3|569|569
-3|570|570
-3|571|571
-3|572|572
-3|573|573
-3|574|574
-3|575|575
-3|576|576
-3|577|577
-3|578|578
-3|579|579
-3|580|580
-3|581|581
-3|582|582
-3|583|583
-3|584|584
-3|585|585
-3|586|586
-3|587|587
-3|588|588
-3|589|589
-3|590|590
-3|591|591
-3|592|592
-3|593|593
-3|594|594
-3|595|595
-3|596|596
-3|597|597
-3|598|598
-3|599|599
-3|600|600
-3|601|601
-3|602|602
-3|603|603
-3|604|604
-3|605|605
-3|606|606
-3|607|607
-3|608|608
-3|609|609
-3|610|610
-3|611|611
-3|612|612
-3|613|613
-3|614|614
-3|615|615
-3|616|616
-3|617|617
-3|618|618
-3|619|619
-3|620|620
-3|621|621
-3|622|622
-3|623|623
-3|624|624
-3|625|625
-3|626|626
-3|627|627
-3|628|628
-3|629|629
-3|630|630
-3|631|631
-3|632|632
-3|633|633
-3|634|634
-3|635|635
-3|636|636
-3|637|637
-3|638|638
-3|639|639
-3|640|640
-3|641|641
-3|642|642
-3|643|643
-3|644|644
-3|645|645
-3|646|646
-3|647|647
-3|648|648
-3|649|649
-3|650|650
-3|651|651
-3|652|652
-3|653|653
-3|654|654
-3|655|655
-3|656|656
-3|657|657
-3|658|658
-3|659|659
-3|660|660
-3|661|661
-3|662|662
-3|663|663
-3|664|664
-3|665|665
-3|666|666
-3|667|667
-3|668|668
-3|669|669
-3|670|670
-3|671|671
-3|672|672
-3|673|673
-3|674|674
-3|675|675
-3|676|676
-3|677|677
-3|678|678
-3|679|679
-3|680|680
-3|681|681
-3|682|682
-3|683|683
-3|684|684
-3|685|685
-3|686|686
-3|687|687
-3|688|688
-3|689|689
-3|690|690
-3|691|691
-3|692|692
-3|693|693
-3|694|694
-3|695|695
-3|696|696
-3|697|697
-3|698|698
-3|699|699
-3|700|700
-3|701|701
-3|702|702
-3|703|703
-3|704|704
-3|705|705
-3|706|706
-3|707|707
-3|708|708
-3|709|709
-3|710|710
-3|711|711
-3|712|712
-3|713|713
-3|714|714
-3|715|715
-3|716|716
-3|717|717
-3|718|718
-3|719|719
-3|720|720
-3|721|721
-3|722|722
-3|723|723
-3|724|724
-3|725|725
-3|726|726
-3|727|727
-3|728|728
-3|729|729
-3|730|730
-3|731|731
-3|732|732
-3|733|733
-3|734|734
-3|735|735
-3|736|736
-3|737|737
-3|738|738
-3|739|739
-3|740|740
-3|741|741
-3|742|742
-3|743|743
-3|744|744
-3|745|745
-3|746|746
-3|747|747
-3|748|748
-3|749|749
-3|750|750
-3|751|751
-3|752|752
-3|753|753
-3|754|754
-3|755|755
-3|756|756
-3|757|757
-3|758|758
-3|759|759
-3|760|760
-3|761|761
-3|762|762
-3|763|763
-3|764|764
-3|765|765
-3|766|766
-3|767|767
-3|768|768
-3|769|769
-3|770|770
-3|771|771
-3|772|772
-3|773|773
-3|774|774
-3|775|775
-3|776|776
-3|777|777
-3|778|778
-3|779|779
-3|780|780
-3|781|781
-3|782|782
-3|783|783
-3|784|784
-3|785|785
-3|786|786
-3|787|787
-3|788|788
-3|789|789
-3|790|790
-3|791|791
-3|792|792
-3|793|793
-3|794|794
-3|795|795
-3|796|796
-3|797|797
-3|798|798
-3|799|799
-3|800|800
-3|801|801
-3|802|802
-3|803|803
-3|804|804
-3|805|805
-3|806|806
-3|807|807
-3|808|808
-3|809|809
-3|810|810
-3|811|811
-3|812|812
-3|813|813
-3|814|814
-3|815|815
-3|816|816
-3|817|817
-3|818|818
-3|819|819
-3|820|820
-3|821|821
-3|822|822
-3|823|823
-3|824|824
-3|825|825
-3|826|826
-3|827|827
-3|828|828
-3|829|829
-3|830|830
-3|831|831
-3|832|832
-3|833|833
-3|834|834
-3|835|835
-3|836|836
-3|837|837
-3|838|838
-3|839|839
-3|840|840
-3|841|841
-3|842|842
-3|843|843
-3|844|844
-3|845|845
-3|846|846
-3|847|847
-3|848|848
-3|849|849
-3|850|850
-3|851|851
-3|852|852
-3|853|853
-3|854|854
-3|855|855
-3|856|856
-3|857|857
-3|858|858
-3|859|859
-3|860|860
-3|861|861
-3|862|862
-3|863|863
-3|864|864
-3|865|865
-3|866|866
-3|867|867
-3|868|868
-3|869|869
-3|870|870
-3|871|871
-3|872|872
-3|873|873
-3|874|874
-3|875|875
-3|876|876
-3|877|877
-3|878|878
-3|879|879
-3|880|880
-3|881|881
-3|882|882
-3|883|883
-3|884|884
-3|885|885
-3|886|886
-3|887|887
-3|888|888
-3|889|889
-3|890|890
-3|891|891
-3|892|892
-3|893|893
-3|894|894
-3|895|895
-3|896|896
-3|897|897
-3|898|898
-3|899|899
-3|900|900
-3|901|901
-3|902|902
-3|903|903
-3|904|904
-3|905|905
-3|906|906
-3|907|907
-3|908|908
-3|909|909
-3|910|910
-3|911|911
-3|912|912
-3|913|913
-3|914|914
-3|915|915
-3|916|916
-3|917|917
-3|918|918
-3|919|919
-3|920|920
-3|921|921
-3|922|922
-3|923|923
-3|924|924
-3|925|925
-3|926|926
-3|927|927
-3|928|928
-3|929|929
-3|930|930
-3|931|931
-3|932|932
-3|933|933
-3|934|934
-3|935|935
-3|936|936
-3|937|937
-3|938|938
-3|939|939
-3|940|940
-3|941|941
-3|942|942
-3|943|943
-3|944|944
-3|945|945
-3|946|946
-3|947|947
-3|948|948
-3|949|949
-3|950|950
-3|951|951
-3|952|952
-3|953|953
-3|954|954
-3|955|955
-3|956|956
-3|957|957
-3|958|958
-3|959|959
-3|960|960
-3|961|961
-3|962|962
-3|963|963
-3|964|964
-3|965|965
-3|966|966
-3|967|967
-3|968|968
-3|969|969
-3|970|970
-3|971|971
-3|972|972
-3|973|973
-3|974|974
-3|975|975
-3|976|976
-3|977|977
-3|978|978
-3|979|979
-3|980|980
-3|981|981
-3|982|982
-3|983|983
-3|984|984
-3|985|985
-3|986|986
-3|987|987
-3|988|988
-3|989|989
-3|990|990
-3|991|991
-3|992|992
-3|993|993
-3|994|994
-3|995|995
-3|996|996
-3|997|997
-3|998|998
-3|999|999
-3|1000|1000
-4|1|1
-4|2|2
-4|3|3
-4|4|4
-4|5|5
-4|6|6
-4|7|7
-4|8|8
-4|9|9
-4|10|10
-4|11|11
-4|12|12
-4|13|13
-4|14|14
-4|15|15
-4|16|16
-4|17|17
-4|18|18
-4|19|19
-4|20|20
-4|21|21
-4|22|22
-4|23|23
-4|24|24
-4|25|25
-4|26|26
-4|27|27
-4|28|28
-4|29|29
-4|30|30
-4|31|31
-4|32|32
-4|33|33
-4|34|34
-4|35|35
-4|36|36
-4|37|37
-4|38|38
-4|39|39
-4|40|40
-4|41|41
-4|42|42
-4|43|43
-4|44|44
-4|45|45
-4|46|46
-4|47|47
-4|48|48
-4|49|49
-4|50|50
-4|51|51
-4|52|52
-4|53|53
-4|54|54
-4|55|55
-4|56|56
-4|57|57
-4|58|58
-4|59|59
-4|60|60
-4|61|61
-4|62|62
-4|63|63
-4|64|64
-4|65|65
-4|66|66
-4|67|67
-4|68|68
-4|69|69
-4|70|70
-4|71|71
-4|72|72
-4|73|73
-4|74|74
-4|75|75
-4|76|76
-4|77|77
-4|78|78
-4|79|79
-4|80|80
-4|81|81
-4|82|82
-4|83|83
-4|84|84
-4|85|85
-4|86|86
-4|87|87
-4|88|88
-4|89|89
-4|90|90
-4|91|91
-4|92|92
-4|93|93
-4|94|94
-4|95|95
-4|96|96
-4|97|97
-4|98|98
-4|99|99
-4|100|100
-4|101|101
-4|102|102
-4|103|103
-4|104|104
-4|105|105
-4|106|106
-4|107|107
-4|108|108
-4|109|109
-4|110|110
-4|111|111
-4|112|112
-4|113|113
-4|114|114
-4|115|115
-4|116|116
-4|117|117
-4|118|118
-4|119|119
-4|120|120
-4|121|121
-4|122|122
-4|123|123
-4|124|124
-4|125|125
-4|126|126
-4|127|127
-4|128|128
-4|129|129
-4|130|130
-4|131|131
-4|132|132
-4|133|133
-4|134|134
-4|135|135
-4|136|136
-4|137|137
-4|138|138
-4|139|139
-4|140|140
-4|141|141
-4|142|142
-4|143|143
-4|144|144
-4|145|145
-4|146|146
-4|147|147
-4|148|148
-4|149|149
-4|150|150
-4|151|151
-4|152|152
-4|153|153
-4|154|154
-4|155|155
-4|156|156
-4|157|157
-4|158|158
-4|159|159
-4|160|160
-4|161|161
-4|162|162
-4|163|163
-4|164|164
-4|165|165
-4|166|166
-4|167|167
-4|168|168
-4|169|169
-4|170|170
-4|171|171
-4|172|172
-4|173|173
-4|174|174
-4|175|175
-4|176|176
-4|177|177
-4|178|178
-4|179|179
-4|180|180
-4|181|181
-4|182|182
-4|183|183
-4|184|184
-4|185|185
-4|186|186
-4|187|187
-4|188|188
-4|189|189
-4|190|190
-4|191|191
-4|192|192
-4|193|193
-4|194|194
-4|195|195
-4|196|196
-4|197|197
-4|198|198
-4|199|199
-4|200|200
-4|201|201
-4|202|202
-4|203|203
-4|204|204
-4|205|205
-4|206|206
-4|207|207
-4|208|208
-4|209|209
-4|210|210
-4|211|211
-4|212|212
-4|213|213
-4|214|214
-4|215|215
-4|216|216
-4|217|217
-4|218|218
-4|219|219
-4|220|220
-4|221|221
-4|222|222
-4|223|223
-4|224|224
-4|225|225
-4|226|226
-4|227|227
-4|228|228
-4|229|229
-4|230|230
-4|231|231
-4|232|232
-4|233|233
-4|234|234
-4|235|235
-4|236|236
-4|237|237
-4|238|238
-4|239|239
-4|240|240
-4|241|241
-4|242|242
-4|243|243
-4|244|244
-4|245|245
-4|246|246
-4|247|247
-4|248|248
-4|249|249
-4|250|250
-4|251|251
-4|252|252
-4|253|253
-4|254|254
-4|255|255
-4|256|256
-4|257|257
-4|258|258
-4|259|259
-4|260|260
-4|261|261
-4|262|262
-4|263|263
-4|264|264
-4|265|265
-4|266|266
-4|267|267
-4|268|268
-4|269|269
-4|270|270
-4|271|271
-4|272|272
-4|273|273
-4|274|274
-4|275|275
-4|276|276
-4|277|277
-4|278|278
-4|279|279
-4|280|280
-4|281|281
-4|282|282
-4|283|283
-4|284|284
-4|285|285
-4|286|286
-4|287|287
-4|288|288
-4|289|289
-4|290|290
-4|291|291
-4|292|292
-4|293|293
-4|294|294
-4|295|295
-4|296|296
-4|297|297
-4|298|298
-4|299|299
-4|300|300
-4|301|301
-4|302|302
-4|303|303
-4|304|304
-4|305|305
-4|306|306
-4|307|307
-4|308|308
-4|309|309
-4|310|310
-4|311|311
-4|312|312
-4|313|313
-4|314|314
-4|315|315
-4|316|316
-4|317|317
-4|318|318
-4|319|319
-4|320|320
-4|321|321
-4|322|322
-4|323|323
-4|324|324
-4|325|325
-4|326|326
-4|327|327
-4|328|328
-4|329|329
-4|330|330
-4|331|331
-4|332|332
-4|333|333
-4|334|334
-4|335|335
-4|336|336
-4|337|337
-4|338|338
-4|339|339
-4|340|340
-4|341|341
-4|342|342
-4|343|343
-4|344|344
-4|345|345
-4|346|346
-4|347|347
-4|348|348
-4|349|349
-4|350|350
-4|351|351
-4|352|352
-4|353|353
-4|354|354
-4|355|355
-4|356|356
-4|357|357
-4|358|358
-4|359|359
-4|360|360
-4|361|361
-4|362|362
-4|363|363
-4|364|364
-4|365|365
-4|366|366
-4|367|367
-4|368|368
-4|369|369
-4|370|370
-4|371|371
-4|372|372
-4|373|373
-4|374|374
-4|375|375
-4|376|376
-4|377|377
-4|378|378
-4|379|379
-4|380|380
-4|381|381
-4|382|382
-4|383|383
-4|384|384
-4|385|385
-4|386|386
-4|387|387
-4|388|388
-4|389|389
-4|390|390
-4|391|391
-4|392|392
-4|393|393
-4|394|394
-4|395|395
-4|396|396
-4|397|397
-4|398|398
-4|399|399
-4|400|400
-4|401|401
-4|402|402
-4|403|403
-4|404|404
-4|405|405
-4|406|406
-4|407|407
-4|408|408
-4|409|409
-4|410|410
-4|411|411
-4|412|412
-4|413|413
-4|414|414
-4|415|415
-4|416|416
-4|417|417
-4|418|418
-4|419|419
-4|420|420
-4|421|421
-4|422|422
-4|423|423
-4|424|424
-4|425|425
-4|426|426
-4|427|427
-4|428|428
-4|429|429
-4|430|430
-4|431|431
-4|432|432
-4|433|433
-4|434|434
-4|435|435
-4|436|436
-4|437|437
-4|438|438
-4|439|439
-4|440|440
-4|441|441
-4|442|442
-4|443|443
-4|444|444
-4|445|445
-4|446|446
-4|447|447
-4|448|448
-4|449|449
-4|450|450
-4|451|451
-4|452|452
-4|453|453
-4|454|454
-4|455|455
-4|456|456
-4|457|457
-4|458|458
-4|459|459
-4|460|460
-4|461|461
-4|462|462
-4|463|463
-4|464|464
-4|465|465
-4|466|466
-4|467|467
-4|468|468
-4|469|469
-4|470|470
-4|471|471
-4|472|472
-4|473|473
-4|474|474
-4|475|475
-4|476|476
-4|477|477
-4|478|478
-4|479|479
-4|480|480
-4|481|481
-4|482|482
-4|483|483
-4|484|484
-4|485|485
-4|486|486
-4|487|487
-4|488|488
-4|489|489
-4|490|490
-4|491|491
-4|492|492
-4|493|493
-4|494|494
-4|495|495
-4|496|496
-4|497|497
-4|498|498
-4|499|499
-4|500|500
-4|501|501
-4|502|502
-4|503|503
-4|504|504
-4|505|505
-4|506|506
-4|507|507
-4|508|508
-4|509|509
-4|510|510
-4|511|511
-4|512|512
-4|513|513
-4|514|514
-4|515|515
-4|516|516
-4|517|517
-4|518|518
-4|519|519
-4|520|520
-4|521|521
-4|522|522
-4|523|523
-4|524|524
-4|525|525
-4|526|526
-4|527|527
-4|528|528
-4|529|529
-4|530|530
-4|531|531
-4|532|532
-4|533|533
-4|534|534
-4|535|535
-4|536|536
-4|537|537
-4|538|538
-4|539|539
-4|540|540
-4|541|541
-4|542|542
-4|543|543
-4|544|544
-4|545|545
-4|546|546
-4|547|547
-4|548|548
-4|549|549
-4|550|550
-4|551|551
-4|552|552
-4|553|553
-4|554|554
-4|555|555
-4|556|556
-4|557|557
-4|558|558
-4|559|559
-4|560|560
-4|561|561
-4|562|562
-4|563|563
-4|564|564
-4|565|565
-4|566|566
-4|567|567
-4|568|568
-4|569|569
-4|570|570
-4|571|571
-4|572|572
-4|573|573
-4|574|574
-4|575|575
-4|576|576
-4|577|577
-4|578|578
-4|579|579
-4|580|580
-4|581|581
-4|582|582
-4|583|583
-4|584|584
-4|585|585
-4|586|586
-4|587|587
-4|588|588
-4|589|589
-4|590|590
-4|591|591
-4|592|592
-4|593|593
-4|594|594
-4|595|595
-4|596|596
-4|597|597
-4|598|598
-4|599|599
-4|600|600
-4|601|601
-4|602|602
-4|603|603
-4|604|604
-4|605|605
-4|606|606
-4|607|607
-4|608|608
-4|609|609
-4|610|610
-4|611|611
-4|612|612
-4|613|613
-4|614|614
-4|615|615
-4|616|616
-4|617|617
-4|618|618
-4|619|619
-4|620|620
-4|621|621
-4|622|622
-4|623|623
-4|624|624
-4|625|625
-4|626|626
-4|627|627
-4|628|628
-4|629|629
-4|630|630
-4|631|631
-4|632|632
-4|633|633
-4|634|634
-4|635|635
-4|636|636
-4|637|637
-4|638|638
-4|639|639
-4|640|640
-4|641|641
-4|642|642
-4|643|643
-4|644|644
-4|645|645
-4|646|646
-4|647|647
-4|648|648
-4|649|649
-4|650|650
-4|651|651
-4|652|652
-4|653|653
-4|654|654
-4|655|655
-4|656|656
-4|657|657
-4|658|658
-4|659|659
-4|660|660
-4|661|661
-4|662|662
-4|663|663
-4|664|664
-4|665|665
-4|666|666
-4|667|667
-4|668|668
-4|669|669
-4|670|670
-4|671|671
-4|672|672
-4|673|673
-4|674|674
-4|675|675
-4|676|676
-4|677|677
-4|678|678
-4|679|679
-4|680|680
-4|681|681
-4|682|682
-4|683|683
-4|684|684
-4|685|685
-4|686|686
-4|687|687
-4|688|688
-4|689|689
-4|690|690
-4|691|691
-4|692|692
-4|693|693
-4|694|694
-4|695|695
-4|696|696
-4|697|697
-4|698|698
-4|699|699
-4|700|700
-4|701|701
-4|702|702
-4|703|703
-4|704|704
-4|705|705
-4|706|706
-4|707|707
-4|708|708
-4|709|709
-4|710|710
-4|711|711
-4|712|712
-4|713|713
-4|714|714
-4|715|715
-4|716|716
-4|717|717
-4|718|718
-4|719|719
-4|720|720
-4|721|721
-4|722|722
-4|723|723
-4|724|724
-4|725|725
-4|726|726
-4|727|727
-4|728|728
-4|729|729
-4|730|730
-4|731|731
-4|732|732
-4|733|733
-4|734|734
-4|735|735
-4|736|736
-4|737|737
-4|738|738
-4|739|739
-4|740|740
-4|741|741
-4|742|742
-4|743|743
-4|744|744
-4|745|745
-4|746|746
-4|747|747
-4|748|748
-4|749|749
-4|750|750
-4|751|751
-4|752|752
-4|753|753
-4|754|754
-4|755|755
-4|756|756
-4|757|757
-4|758|758
-4|759|759
-4|760|760
-4|761|761
-4|762|762
-4|763|763
-4|764|764
-4|765|765
-4|766|766
-4|767|767
-4|768|768
-4|769|769
-4|770|770
-4|771|771
-4|772|772
-4|773|773
-4|774|774
-4|775|775
-4|776|776
-4|777|777
-4|778|778
-4|779|779
-4|780|780
-4|781|781
-4|782|782
-4|783|783
-4|784|784
-4|785|785
-4|786|786
-4|787|787
-4|788|788
-4|789|789
-4|790|790
-4|791|791
-4|792|792
-4|793|793
-4|794|794
-4|795|795
-4|796|796
-4|797|797
-4|798|798
-4|799|799
-4|800|800
-4|801|801
-4|802|802
-4|803|803
-4|804|804
-4|805|805
-4|806|806
-4|807|807
-4|808|808
-4|809|809
-4|810|810
-4|811|811
-4|812|812
-4|813|813
-4|814|814
-4|815|815
-4|816|816
-4|817|817
-4|818|818
-4|819|819
-4|820|820
-4|821|821
-4|822|822
-4|823|823
-4|824|824
-4|825|825
-4|826|826
-4|827|827
-4|828|828
-4|829|829
-4|830|830
-4|831|831
-4|832|832
-4|833|833
-4|834|834
-4|835|835
-4|836|836
-4|837|837
-4|838|838
-4|839|839
-4|840|840
-4|841|841
-4|842|842
-4|843|843
-4|844|844
-4|845|845
-4|846|846
-4|847|847
-4|848|848
-4|849|849
-4|850|850
-4|851|851
-4|852|852
-4|853|853
-4|854|854
-4|855|855
-4|856|856
-4|857|857
-4|858|858
-4|859|859
-4|860|860
-4|861|861
-4|862|862
-4|863|863
-4|864|864
-4|865|865
-4|866|866
-4|867|867
-4|868|868
-4|869|869
-4|870|870
-4|871|871
-4|872|872
-4|873|873
-4|874|874
-4|875|875
-4|876|876
-4|877|877
-4|878|878
-4|879|879
-4|880|880
-4|881|881
-4|882|882
-4|883|883
-4|884|884
-4|885|885
-4|886|886
-4|887|887
-4|888|888
-4|889|889
-4|890|890
-4|891|891
-4|892|892
-4|893|893
-4|894|894
-4|895|895
-4|896|896
-4|897|897
-4|898|898
-4|899|899
-4|900|900
-4|901|901
-4|902|902
-4|903|903
-4|904|904
-4|905|905
-4|906|906
-4|907|907
-4|908|908
-4|909|909
-4|910|910
-4|911|911
-4|912|912
-4|913|913
-4|914|914
-4|915|915
-4|916|916
-4|917|917
-4|918|918
-4|919|919
-4|920|920
-4|921|921
-4|922|922
-4|923|923
-4|924|924
-4|925|925
-4|926|926
-4|927|927
-4|928|928
-4|929|929
-4|930|930
-4|931|931
-4|932|932
-4|933|933
-4|934|934
-4|935|935
-4|936|936
-4|937|937
-4|938|938
-4|939|939
-4|940|940
-4|941|941
-4|942|942
-4|943|943
-4|944|944
-4|945|945
-4|946|946
-4|947|947
-4|948|948
-4|949|949
-4|950|950
-4|951|951
-4|952|952
-4|953|953
-4|954|954
-4|955|955
-4|956|956
-4|957|957
-4|958|958
-4|959|959
-4|960|960
-4|961|961
-4|962|962
-4|963|963
-4|964|964
-4|965|965
-4|966|966
-4|967|967
-4|968|968
-4|969|969
-4|970|970
-4|971|971
-4|972|972
-4|973|973
-4|974|974
-4|975|975
-4|976|976
-4|977|977
-4|978|978
-4|979|979
-4|980|980
-4|981|981
-4|982|982
-4|983|983
-4|984|984
-4|985|985
-4|986|986
-4|987|987
-4|988|988
-4|989|989
-4|990|990
-4|991|991
-4|992|992
-4|993|993
-4|994|994
-4|995|995
-4|996|996
-4|997|997
-4|998|998
-4|999|999
-4|1000|1000
-5|1|1
-5|2|2
-5|3|3
-5|4|4
-5|5|5
-5|6|6
-5|7|7
-5|8|8
-5|9|9
-5|10|10
-5|11|11
-5|12|12
-5|13|13
-5|14|14
-5|15|15
-5|16|16
-5|17|17
-5|18|18
-5|19|19
-5|20|20
-5|21|21
-5|22|22
-5|23|23
-5|24|24
-5|25|25
-5|26|26
-5|27|27
-5|28|28
-5|29|29
-5|30|30
-5|31|31
-5|32|32
-5|33|33
-5|34|34
-5|35|35
-5|36|36
-5|37|37
-5|38|38
-5|39|39
-5|40|40
-5|41|41
-5|42|42
-5|43|43
-5|44|44
-5|45|45
-5|46|46
-5|47|47
-5|48|48
-5|49|49
-5|50|50
-5|51|51
-5|52|52
-5|53|53
-5|54|54
-5|55|55
-5|56|56
-5|57|57
-5|58|58
-5|59|59
-5|60|60
-5|61|61
-5|62|62
-5|63|63
-5|64|64
-5|65|65
-5|66|66
-5|67|67
-5|68|68
-5|69|69
-5|70|70
-5|71|71
-5|72|72
-5|73|73
-5|74|74
-5|75|75
-5|76|76
-5|77|77
-5|78|78
-5|79|79
-5|80|80
-5|81|81
-5|82|82
-5|83|83
-5|84|84
-5|85|85
-5|86|86
-5|87|87
-5|88|88
-5|89|89
-5|90|90
-5|91|91
-5|92|92
-5|93|93
-5|94|94
-5|95|95
-5|96|96
-5|97|97
-5|98|98
-5|99|99
-5|100|100
-5|101|101
-5|102|102
-5|103|103
-5|104|104
-5|105|105
-5|106|106
-5|107|107
-5|108|108
-5|109|109
-5|110|110
-5|111|111
-5|112|112
-5|113|113
-5|114|114
-5|115|115
-5|116|116
-5|117|117
-5|118|118
-5|119|119
-5|120|120
-5|121|121
-5|122|122
-5|123|123
-5|124|124
-5|125|125
-5|126|126
-5|127|127
-5|128|128
-5|129|129
-5|130|130
-5|131|131
-5|132|132
-5|133|133
-5|134|134
-5|135|135
-5|136|136
-5|137|137
-5|138|138
-5|139|139
-5|140|140
-5|141|141
-5|142|142
-5|143|143
-5|144|144
-5|145|145
-5|146|146
-5|147|147
-5|148|148
-5|149|149
-5|150|150
-5|151|151
-5|152|152
-5|153|153
-5|154|154
-5|155|155
-5|156|156
-5|157|157
-5|158|158
-5|159|159
-5|160|160
-5|161|161
-5|162|162
-5|163|163
-5|164|164
-5|165|165
-5|166|166
-5|167|167
-5|168|168
-5|169|169
-5|170|170
-5|171|171
-5|172|172
-5|173|173
-5|174|174
-5|175|175
-5|176|176
-5|177|177
-5|178|178
-5|179|179
-5|180|180
-5|181|181
-5|182|182
-5|183|183
-5|184|184
-5|185|185
-5|186|186
-5|187|187
-5|188|188
-5|189|189
-5|190|190
-5|191|191
-5|192|192
-5|193|193
-5|194|194
-5|195|195
-5|196|196
-5|197|197
-5|198|198
-5|199|199
-5|200|200
-5|201|201
-5|202|202
-5|203|203
-5|204|204
-5|205|205
-5|206|206
-5|207|207
-5|208|208
-5|209|209
-5|210|210
-5|211|211
-5|212|212
-5|213|213
-5|214|214
-5|215|215
-5|216|216
-5|217|217
-5|218|218
-5|219|219
-5|220|220
-5|221|221
-5|222|222
-5|223|223
-5|224|224
-5|225|225
-5|226|226
-5|227|227
-5|228|228
-5|229|229
-5|230|230
-5|231|231
-5|232|232
-5|233|233
-5|234|234
-5|235|235
-5|236|236
-5|237|237
-5|238|238
-5|239|239
-5|240|240
-5|241|241
-5|242|242
-5|243|243
-5|244|244
-5|245|245
-5|246|246
-5|247|247
-5|248|248
-5|249|249
-5|250|250
-5|251|251
-5|252|252
-5|253|253
-5|254|254
-5|255|255
-5|256|256
-5|257|257
-5|258|258
-5|259|259
-5|260|260
-5|261|261
-5|262|262
-5|263|263
-5|264|264
-5|265|265
-5|266|266
-5|267|267
-5|268|268
-5|269|269
-5|270|270
-5|271|271
-5|272|272
-5|273|273
-5|274|274
-5|275|275
-5|276|276
-5|277|277
-5|278|278
-5|279|279
-5|280|280
-5|281|281
-5|282|282
-5|283|283
-5|284|284
-5|285|285
-5|286|286
-5|287|287
-5|288|288
-5|289|289
-5|290|290
-5|291|291
-5|292|292
-5|293|293
-5|294|294
-5|295|295
-5|296|296
-5|297|297
-5|298|298
-5|299|299
-5|300|300
-5|301|301
-5|302|302
-5|303|303
-5|304|304
-5|305|305
-5|306|306
-5|307|307
-5|308|308
-5|309|309
-5|310|310
-5|311|311
-5|312|312
-5|313|313
-5|314|314
-5|315|315
-5|316|316
-5|317|317
-5|318|318
-5|319|319
-5|320|320
-5|321|321
-5|322|322
-5|323|323
-5|324|324
-5|325|325
-5|326|326
-5|327|327
-5|328|328
-5|329|329
-5|330|330
-5|331|331
-5|332|332
-5|333|333
-5|334|334
-5|335|335
-5|336|336
-5|337|337
-5|338|338
-5|339|339
-5|340|340
-5|341|341
-5|342|342
-5|343|343
-5|344|344
-5|345|345
-5|346|346
-5|347|347
-5|348|348
-5|349|349
-5|350|350
-5|351|351
-5|352|352
-5|353|353
-5|354|354
-5|355|355
-5|356|356
-5|357|357
-5|358|358
-5|359|359
-5|360|360
-5|361|361
-5|362|362
-5|363|363
-5|364|364
-5|365|365
-5|366|366
-5|367|367
-5|368|368
-5|369|369
-5|370|370
-5|371|371
-5|372|372
-5|373|373
-5|374|374
-5|375|375
-5|376|376
-5|377|377
-5|378|378
-5|379|379
-5|380|380
-5|381|381
-5|382|382
-5|383|383
-5|384|384
-5|385|385
-5|386|386
-5|387|387
-5|388|388
-5|389|389
-5|390|390
-5|391|391
-5|392|392
-5|393|393
-5|394|394
-5|395|395
-5|396|396
-5|397|397
-5|398|398
-5|399|399
-5|400|400
-5|401|401
-5|402|402
-5|403|403
-5|404|404
-5|405|405
-5|406|406
-5|407|407
-5|408|408
-5|409|409
-5|410|410
-5|411|411
-5|412|412
-5|413|413
-5|414|414
-5|415|415
-5|416|416
-5|417|417
-5|418|418
-5|419|419
-5|420|420
-5|421|421
-5|422|422
-5|423|423
-5|424|424
-5|425|425
-5|426|426
-5|427|427
-5|428|428
-5|429|429
-5|430|430
-5|431|431
-5|432|432
-5|433|433
-5|434|434
-5|435|435
-5|436|436
-5|437|437
-5|438|438
-5|439|439
-5|440|440
-5|441|441
-5|442|442
-5|443|443
-5|444|444
-5|445|445
-5|446|446
-5|447|447
-5|448|448
-5|449|449
-5|450|450
-5|451|451
-5|452|452
-5|453|453
-5|454|454
-5|455|455
-5|456|456
-5|457|457
-5|458|458
-5|459|459
-5|460|460
-5|461|461
-5|462|462
-5|463|463
-5|464|464
-5|465|465
-5|466|466
-5|467|467
-5|468|468
-5|469|469
-5|470|470
-5|471|471
-5|472|472
-5|473|473
-5|474|474
-5|475|475
-5|476|476
-5|477|477
-5|478|478
-5|479|479
-5|480|480
-5|481|481
-5|482|482
-5|483|483
-5|484|484
-5|485|485
-5|486|486
-5|487|487
-5|488|488
-5|489|489
-5|490|490
-5|491|491
-5|492|492
-5|493|493
-5|494|494
-5|495|495
-5|496|496
-5|497|497
-5|498|498
-5|499|499
-5|500|500
-5|501|501
-5|502|502
-5|503|503
-5|504|504
-5|505|505
-5|506|506
-5|507|507
-5|508|508
-5|509|509
-5|510|510
-5|511|511
-5|512|512
-5|513|513
-5|514|514
-5|515|515
-5|516|516
-5|517|517
-5|518|518
-5|519|519
-5|520|520
-5|521|521
-5|522|522
-5|523|523
-5|524|524
-5|525|525
-5|526|526
-5|527|527
-5|528|528
-5|529|529
-5|530|530
-5|531|531
-5|532|532
-5|533|533
-5|534|534
-5|535|535
-5|536|536
-5|537|537
-5|538|538
-5|539|539
-5|540|540
-5|541|541
-5|542|542
-5|543|543
-5|544|544
-5|545|545
-5|546|546
-5|547|547
-5|548|548
-5|549|549
-5|550|550
-5|551|551
-5|552|552
-5|553|553
-5|554|554
-5|555|555
-5|556|556
-5|557|557
-5|558|558
-5|559|559
-5|560|560
-5|561|561
-5|562|562
-5|563|563
-5|564|564
-5|565|565
-5|566|566
-5|567|567
-5|568|568
-5|569|569
-5|570|570
-5|571|571
-5|572|572
-5|573|573
-5|574|574
-5|575|575
-5|576|576
-5|577|577
-5|578|578
-5|579|579
-5|580|580
-5|581|581
-5|582|582
-5|583|583
-5|584|584
-5|585|585
-5|586|586
-5|587|587
-5|588|588
-5|589|589
-5|590|590
-5|591|591
-5|592|592
-5|593|593
-5|594|594
-5|595|595
-5|596|596
-5|597|597
-5|598|598
-5|599|599
-5|600|600
-5|601|601
-5|602|602
-5|603|603
-5|604|604
-5|605|605
-5|606|606
-5|607|607
-5|608|608
-5|609|609
-5|610|610
-5|611|611
-5|612|612
-5|613|613
-5|614|614
-5|615|615
-5|616|616
-5|617|617
-5|618|618
-5|619|619
-5|620|620
-5|621|621
-5|622|622
-5|623|623
-5|624|624
-5|625|625
-5|626|626
-5|627|627
-5|628|628
-5|629|629
-5|630|630
-5|631|631
-5|632|632
-5|633|633
-5|634|634
-5|635|635
-5|636|636
-5|637|637
-5|638|638
-5|639|639
-5|640|640
-5|641|641
-5|642|642
-5|643|643
-5|644|644
-5|645|645
-5|646|646
-5|647|647
-5|648|648
-5|649|649
-5|650|650
-5|651|651
-5|652|652
-5|653|653
-5|654|654
-5|655|655
-5|656|656
-5|657|657
-5|658|658
-5|659|659
-5|660|660
-5|661|661
-5|662|662
-5|663|663
-5|664|664
-5|665|665
-5|666|666
-5|667|667
-5|668|668
-5|669|669
-5|670|670
-5|671|671
-5|672|672
-5|673|673
-5|674|674
-5|675|675
-5|676|676
-5|677|677
-5|678|678
-5|679|679
-5|680|680
-5|681|681
-5|682|682
-5|683|683
-5|684|684
-5|685|685
-5|686|686
-5|687|687
-5|688|688
-5|689|689
-5|690|690
-5|691|691
-5|692|692
-5|693|693
-5|694|694
-5|695|695
-5|696|696
-5|697|697
-5|698|698
-5|699|699
-5|700|700
-5|701|701
-5|702|702
-5|703|703
-5|704|704
-5|705|705
-5|706|706
-5|707|707
-5|708|708
-5|709|709
-5|710|710
-5|711|711
-5|712|712
-5|713|713
-5|714|714
-5|715|715
-5|716|716
-5|717|717
-5|718|718
-5|719|719
-5|720|720
-5|721|721
-5|722|722
-5|723|723
-5|724|724
-5|725|725
-5|726|726
-5|727|727
-5|728|728
-5|729|729
-5|730|730
-5|731|731
-5|732|732
-5|733|733
-5|734|734
-5|735|735
-5|736|736
-5|737|737
-5|738|738
-5|739|739
-5|740|740
-5|741|741
-5|742|742
-5|743|743
-5|744|744
-5|745|745
-5|746|746
-5|747|747
-5|748|748
-5|749|749
-5|750|750
-5|751|751
-5|752|752
-5|753|753
-5|754|754
-5|755|755
-5|756|756
-5|757|757
-5|758|758
-5|759|759
-5|760|760
-5|761|761
-5|762|762
-5|763|763
-5|764|764
-5|765|765
-5|766|766
-5|767|767
-5|768|768
-5|769|769
-5|770|770
-5|771|771
-5|772|772
-5|773|773
-5|774|774
-5|775|775
-5|776|776
-5|777|777
-5|778|778
-5|779|779
-5|780|780
-5|781|781
-5|782|782
-5|783|783
-5|784|784
-5|785|785
-5|786|786
-5|787|787
-5|788|788
-5|789|789
-5|790|790
-5|791|791
-5|792|792
-5|793|793
-5|794|794
-5|795|795
-5|796|796
-5|797|797
-5|798|798
-5|799|799
-5|800|800
-5|801|801
-5|802|802
-5|803|803
-5|804|804
-5|805|805
-5|806|806
-5|807|807
-5|808|808
-5|809|809
-5|810|810
-5|811|811
-5|812|812
-5|813|813
-5|814|814
-5|815|815
-5|816|816
-5|817|817
-5|818|818
-5|819|819
-5|820|820
-5|821|821
-5|822|822
-5|823|823
-5|824|824
-5|825|825
-5|826|826
-5|827|827
-5|828|828
-5|829|829
-5|830|830
-5|831|831
-5|832|832
-5|833|833
-5|834|834
-5|835|835
-5|836|836
-5|837|837
-5|838|838
-5|839|839
-5|840|840
-5|841|841
-5|842|842
-5|843|843
-5|844|844
-5|845|845
-5|846|846
-5|847|847
-5|848|848
-5|849|849
-5|850|850
-5|851|851
-5|852|852
-5|853|853
-5|854|854
-5|855|855
-5|856|856
-5|857|857
-5|858|858
-5|859|859
-5|860|860
-5|861|861
-5|862|862
-5|863|863
-5|864|864
-5|865|865
-5|866|866
-5|867|867
-5|868|868
-5|869|869
-5|870|870
-5|871|871
-5|872|872
-5|873|873
-5|874|874
-5|875|875
-5|876|876
-5|877|877
-5|878|878
-5|879|879
-5|880|880
-5|881|881
-5|882|882
-5|883|883
-5|884|884
-5|885|885
-5|886|886
-5|887|887
-5|888|888
-5|889|889
-5|890|890
-5|891|891
-5|892|892
-5|893|893
-5|894|894
-5|895|895
-5|896|896
-5|897|897
-5|898|898
-5|899|899
-5|900|900
-5|901|901
-5|902|902
-5|903|903
-5|904|904
-5|905|905
-5|906|906
-5|907|907
-5|908|908
-5|909|909
-5|910|910
-5|911|911
-5|912|912
-5|913|913
-5|914|914
-5|915|915
-5|916|916
-5|917|917
-5|918|918
-5|919|919
-5|920|920
-5|921|921
-5|922|922
-5|923|923
-5|924|924
-5|925|925
-5|926|926
-5|927|927
-5|928|928
-5|929|929
-5|930|930
-5|931|931
-5|932|932
-5|933|933
-5|934|934
-5|935|935
-5|936|936
-5|937|937
-5|938|938
-5|939|939
-5|940|940
-5|941|941
-5|942|942
-5|943|943
-5|944|944
-5|945|945
-5|946|946
-5|947|947
-5|948|948
-5|949|949
-5|950|950
-5|951|951
-5|952|952
-5|953|953
-5|954|954
-5|955|955
-5|956|956
-5|957|957
-5|958|958
-5|959|959
-5|960|960
-5|961|961
-5|962|962
-5|963|963
-5|964|964
-5|965|965
-5|966|966
-5|967|967
-5|968|968
-5|969|969
-5|970|970
-5|971|971
-5|972|972
-5|973|973
-5|974|974
-5|975|975
-5|976|976
-5|977|977
-5|978|978
-5|979|979
-5|980|980
-5|981|981
-5|982|982
-5|983|983
-5|984|984
-5|985|985
-5|986|986
-5|987|987
-5|988|988
-5|989|989
-5|990|990
-5|991|991
-5|992|992
-5|993|993
-5|994|994
-5|995|995
-5|996|996
-5|997|997
-5|998|998
-5|999|999
-5|1000|1000
-6|1|1
-6|2|2
-6|3|3
-6|4|4
-6|5|5
-6|6|6
-6|7|7
-6|8|8
-6|9|9
-6|10|10
-6|11|11
-6|12|12
-6|13|13
-6|14|14
-6|15|15
-6|16|16
-6|17|17
-6|18|18
-6|19|19
-6|20|20
-6|21|21
-6|22|22
-6|23|23
-6|24|24
-6|25|25
-6|26|26
-6|27|27
-6|28|28
-6|29|29
-6|30|30
-6|31|31
-6|32|32
-6|33|33
-6|34|34
-6|35|35
-6|36|36
-6|37|37
-6|38|38
-6|39|39
-6|40|40
-6|41|41
-6|42|42
-6|43|43
-6|44|44
-6|45|45
-6|46|46
-6|47|47
-6|48|48
-6|49|49
-6|50|50
-6|51|51
-6|52|52
-6|53|53
-6|54|54
-6|55|55
-6|56|56
-6|57|57
-6|58|58
-6|59|59
-6|60|60
-6|61|61
-6|62|62
-6|63|63
-6|64|64
-6|65|65
-6|66|66
-6|67|67
-6|68|68
-6|69|69
-6|70|70
-6|71|71
-6|72|72
-6|73|73
-6|74|74
-6|75|75
-6|76|76
-6|77|77
-6|78|78
-6|79|79
-6|80|80
-6|81|81
-6|82|82
-6|83|83
-6|84|84
-6|85|85
-6|86|86
-6|87|87
-6|88|88
-6|89|89
-6|90|90
-6|91|91
-6|92|92
-6|93|93
-6|94|94
-6|95|95
-6|96|96
-6|97|97
-6|98|98
-6|99|99
-6|100|100
-6|101|101
-6|102|102
-6|103|103
-6|104|104
-6|105|105
-6|106|106
-6|107|107
-6|108|108
-6|109|109
-6|110|110
-6|111|111
-6|112|112
-6|113|113
-6|114|114
-6|115|115
-6|116|116
-6|117|117
-6|118|118
-6|119|119
-6|120|120
-6|121|121
-6|122|122
-6|123|123
-6|124|124
-6|125|125
-6|126|126
-6|127|127
-6|128|128
-6|129|129
-6|130|130
-6|131|131
-6|132|132
-6|133|133
-6|134|134
-6|135|135
-6|136|136
-6|137|137
-6|138|138
-6|139|139
-6|140|140
-6|141|141
-6|142|142
-6|143|143
-6|144|144
-6|145|145
-6|146|146
-6|147|147
-6|148|148
-6|149|149
-6|150|150
-6|151|151
-6|152|152
-6|153|153
-6|154|154
-6|155|155
-6|156|156
-6|157|157
-6|158|158
-6|159|159
-6|160|160
-6|161|161
-6|162|162
-6|163|163
-6|164|164
-6|165|165
-6|166|166
-6|167|167
-6|168|168
-6|169|169
-6|170|170
-6|171|171
-6|172|172
-6|173|173
-6|174|174
-6|175|175
-6|176|176
-6|177|177
-6|178|178
-6|179|179
-6|180|180
-6|181|181
-6|182|182
-6|183|183
-6|184|184
-6|185|185
-6|186|186
-6|187|187
-6|188|188
-6|189|189
-6|190|190
-6|191|191
-6|192|192
-6|193|193
-6|194|194
-6|195|195
-6|196|196
-6|197|197
-6|198|198
-6|199|199
-6|200|200
-6|201|201
-6|202|202
-6|203|203
-6|204|204
-6|205|205
-6|206|206
-6|207|207
-6|208|208
-6|209|209
-6|210|210
-6|211|211
-6|212|212
-6|213|213
-6|214|214
-6|215|215
-6|216|216
-6|217|217
-6|218|218
-6|219|219
-6|220|220
-6|221|221
-6|222|222
-6|223|223
-6|224|224
-6|225|225
-6|226|226
-6|227|227
-6|228|228
-6|229|229
-6|230|230
-6|231|231
-6|232|232
-6|233|233
-6|234|234
-6|235|235
-6|236|236
-6|237|237
-6|238|238
-6|239|239
-6|240|240
-6|241|241
-6|242|242
-6|243|243
-6|244|244
-6|245|245
-6|246|246
-6|247|247
-6|248|248
-6|249|249
-6|250|250
-6|251|251
-6|252|252
-6|253|253
-6|254|254
-6|255|255
-6|256|256
-6|257|257
-6|258|258
-6|259|259
-6|260|260
-6|261|261
-6|262|262
-6|263|263
-6|264|264
-6|265|265
-6|266|266
-6|267|267
-6|268|268
-6|269|269
-6|270|270
-6|271|271
-6|272|272
-6|273|273
-6|274|274
-6|275|275
-6|276|276
-6|277|277
-6|278|278
-6|279|279
-6|280|280
-6|281|281
-6|282|282
-6|283|283
-6|284|284
-6|285|285
-6|286|286
-6|287|287
-6|288|288
-6|289|289
-6|290|290
-6|291|291
-6|292|292
-6|293|293
-6|294|294
-6|295|295
-6|296|296
-6|297|297
-6|298|298
-6|299|299
-6|300|300
-6|301|301
-6|302|302
-6|303|303
-6|304|304
-6|305|305
-6|306|306
-6|307|307
-6|308|308
-6|309|309
-6|310|310
-6|311|311
-6|312|312
-6|313|313
-6|314|314
-6|315|315
-6|316|316
-6|317|317
-6|318|318
-6|319|319
-6|320|320
-6|321|321
-6|322|322
-6|323|323
-6|324|324
-6|325|325
-6|326|326
-6|327|327
-6|328|328
-6|329|329
-6|330|330
-6|331|331
-6|332|332
-6|333|333
-6|334|334
-6|335|335
-6|336|336
-6|337|337
-6|338|338
-6|339|339
-6|340|340
-6|341|341
-6|342|342
-6|343|343
-6|344|344
-6|345|345
-6|346|346
-6|347|347
-6|348|348
-6|349|349
-6|350|350
-6|351|351
-6|352|352
-6|353|353
-6|354|354
-6|355|355
-6|356|356
-6|357|357
-6|358|358
-6|359|359
-6|360|360
-6|361|361
-6|362|362
-6|363|363
-6|364|364
-6|365|365
-6|366|366
-6|367|367
-6|368|368
-6|369|369
-6|370|370
-6|371|371
-6|372|372
-6|373|373
-6|374|374
-6|375|375
-6|376|376
-6|377|377
-6|378|378
-6|379|379
-6|380|380
-6|381|381
-6|382|382
-6|383|383
-6|384|384
-6|385|385
-6|386|386
-6|387|387
-6|388|388
-6|389|389
-6|390|390
-6|391|391
-6|392|392
-6|393|393
-6|394|394
-6|395|395
-6|396|396
-6|397|397
-6|398|398
-6|399|399
-6|400|400
-6|401|401
-6|402|402
-6|403|403
-6|404|404
-6|405|405
-6|406|406
-6|407|407
-6|408|408
-6|409|409
-6|410|410
-6|411|411
-6|412|412
-6|413|413
-6|414|414
-6|415|415
-6|416|416
-6|417|417
-6|418|418
-6|419|419
-6|420|420
-6|421|421
-6|422|422
-6|423|423
-6|424|424
-6|425|425
-6|426|426
-6|427|427
-6|428|428
-6|429|429
-6|430|430
-6|431|431
-6|432|432
-6|433|433
-6|434|434
-6|435|435
-6|436|436
-6|437|437
-6|438|438
-6|439|439
-6|440|440
-6|441|441
-6|442|442
-6|443|443
-6|444|444
-6|445|445
-6|446|446
-6|447|447
-6|448|448
-6|449|449
-6|450|450
-6|451|451
-6|452|452
-6|453|453
-6|454|454
-6|455|455
-6|456|456
-6|457|457
-6|458|458
-6|459|459
-6|460|460
-6|461|461
-6|462|462
-6|463|463
-6|464|464
-6|465|465
-6|466|466
-6|467|467
-6|468|468
-6|469|469
-6|470|470
-6|471|471
-6|472|472
-6|473|473
-6|474|474
-6|475|475
-6|476|476
-6|477|477
-6|478|478
-6|479|479
-6|480|480
-6|481|481
-6|482|482
-6|483|483
-6|484|484
-6|485|485
-6|486|486
-6|487|487
-6|488|488
-6|489|489
-6|490|490
-6|491|491
-6|492|492
-6|493|493
-6|494|494
-6|495|495
-6|496|496
-6|497|497
-6|498|498
-6|499|499
-6|500|500
-6|501|501
-6|502|502
-6|503|503
-6|504|504
-6|505|505
-6|506|506
-6|507|507
-6|508|508
-6|509|509
-6|510|510
-6|511|511
-6|512|512
-6|513|513
-6|514|514
-6|515|515
-6|516|516
-6|517|517
-6|518|518
-6|519|519
-6|520|520
-6|521|521
-6|522|522
-6|523|523
-6|524|524
-6|525|525
-6|526|526
-6|527|527
-6|528|528
-6|529|529
-6|530|530
-6|531|531
-6|532|532
-6|533|533
-6|534|534
-6|535|535
-6|536|536
-6|537|537
-6|538|538
-6|539|539
-6|540|540
-6|541|541
-6|542|542
-6|543|543
-6|544|544
-6|545|545
-6|546|546
-6|547|547
-6|548|548
-6|549|549
-6|550|550
-6|551|551
-6|552|552
-6|553|553
-6|554|554
-6|555|555
-6|556|556
-6|557|557
-6|558|558
-6|559|559
-6|560|560
-6|561|561
-6|562|562
-6|563|563
-6|564|564
-6|565|565
-6|566|566
-6|567|567
-6|568|568
-6|569|569
-6|570|570
-6|571|571
-6|572|572
-6|573|573
-6|574|574
-6|575|575
-6|576|576
-6|577|577
-6|578|578
-6|579|579
-6|580|580
-6|581|581
-6|582|582
-6|583|583
-6|584|584
-6|585|585
-6|586|586
-6|587|587
-6|588|588
-6|589|589
-6|590|590
-6|591|591
-6|592|592
-6|593|593
-6|594|594
-6|595|595
-6|596|596
-6|597|597
-6|598|598
-6|599|599
-6|600|600
-6|601|601
-6|602|602
-6|603|603
-6|604|604
-6|605|605
-6|606|606
-6|607|607
-6|608|608
-6|609|609
-6|610|610
-6|611|611
-6|612|612
-6|613|613
-6|614|614
-6|615|615
-6|616|616
-6|617|617
-6|618|618
-6|619|619
-6|620|620
-6|621|621
-6|622|622
-6|623|623
-6|624|624
-6|625|625
-6|626|626
-6|627|627
-6|628|628
-6|629|629
-6|630|630
-6|631|631
-6|632|632
-6|633|633
-6|634|634
-6|635|635
-6|636|636
-6|637|637
-6|638|638
-6|639|639
-6|640|640
-6|641|641
-6|642|642
-6|643|643
-6|644|644
-6|645|645
-6|646|646
-6|647|647
-6|648|648
-6|649|649
-6|650|650
-6|651|651
-6|652|652
-6|653|653
-6|654|654
-6|655|655
-6|656|656
-6|657|657
-6|658|658
-6|659|659
-6|660|660
-6|661|661
-6|662|662
-6|663|663
-6|664|664
-6|665|665
-6|666|666
-6|667|667
-6|668|668
-6|669|669
-6|670|670
-6|671|671
-6|672|672
-6|673|673
-6|674|674
-6|675|675
-6|676|676
-6|677|677
-6|678|678
-6|679|679
-6|680|680
-6|681|681
-6|682|682
-6|683|683
-6|684|684
-6|685|685
-6|686|686
-6|687|687
-6|688|688
-6|689|689
-6|690|690
-6|691|691
-6|692|692
-6|693|693
-6|694|694
-6|695|695
-6|696|696
-6|697|697
-6|698|698
-6|699|699
-6|700|700
-6|701|701
-6|702|702
-6|703|703
-6|704|704
-6|705|705
-6|706|706
-6|707|707
-6|708|708
-6|709|709
-6|710|710
-6|711|711
-6|712|712
-6|713|713
-6|714|714
-6|715|715
-6|716|716
-6|717|717
-6|718|718
-6|719|719
-6|720|720
-6|721|721
-6|722|722
-6|723|723
-6|724|724
-6|725|725
-6|726|726
-6|727|727
-6|728|728
-6|729|729
-6|730|730
-6|731|731
-6|732|732
-6|733|733
-6|734|734
-6|735|735
-6|736|736
-6|737|737
-6|738|738
-6|739|739
-6|740|740
-6|741|741
-6|742|742
-6|743|743
-6|744|744
-6|745|745
-6|746|746
-6|747|747
-6|748|748
-6|749|749
-6|750|750
-6|751|751
-6|752|752
-6|753|753
-6|754|754
-6|755|755
-6|756|756
-6|757|757
-6|758|758
-6|759|759
-6|760|760
-6|761|761
-6|762|762
-6|763|763
-6|764|764
-6|765|765
-6|766|766
-6|767|767
-6|768|768
-6|769|769
-6|770|770
-6|771|771
-6|772|772
-6|773|773
-6|774|774
-6|775|775
-6|776|776
-6|777|777
-6|778|778
-6|779|779
-6|780|780
-6|781|781
-6|782|782
-6|783|783
-6|784|784
-6|785|785
-6|786|786
-6|787|787
-6|788|788
-6|789|789
-6|790|790
-6|791|791
-6|792|792
-6|793|793
-6|794|794
-6|795|795
-6|796|796
-6|797|797
-6|798|798
-6|799|799
-6|800|800
-6|801|801
-6|802|802
-6|803|803
-6|804|804
-6|805|805
-6|806|806
-6|807|807
-6|808|808
-6|809|809
-6|810|810
-6|811|811
-6|812|812
-6|813|813
-6|814|814
-6|815|815
-6|816|816
-6|817|817
-6|818|818
-6|819|819
-6|820|820
-6|821|821
-6|822|822
-6|823|823
-6|824|824
-6|825|825
-6|826|826
-6|827|827
-6|828|828
-6|829|829
-6|830|830
-6|831|831
-6|832|832
-6|833|833
-6|834|834
-6|835|835
-6|836|836
-6|837|837
-6|838|838
-6|839|839
-6|840|840
-6|841|841
-6|842|842
-6|843|843
-6|844|844
-6|845|845
-6|846|846
-6|847|847
-6|848|848
-6|849|849
-6|850|850
-6|851|851
-6|852|852
-6|853|853
-6|854|854
-6|855|855
-6|856|856
-6|857|857
-6|858|858
-6|859|859
-6|860|860
-6|861|861
-6|862|862
-6|863|863
-6|864|864
-6|865|865
-6|866|866
-6|867|867
-6|868|868
-6|869|869
-6|870|870
-6|871|871
-6|872|872
-6|873|873
-6|874|874
-6|875|875
-6|876|876
-6|877|877
-6|878|878
-6|879|879
-6|880|880
-6|881|881
-6|882|882
-6|883|883
-6|884|884
-6|885|885
-6|886|886
-6|887|887
-6|888|888
-6|889|889
-6|890|890
-6|891|891
-6|892|892
-6|893|893
-6|894|894
-6|895|895
-6|896|896
-6|897|897
-6|898|898
-6|899|899
-6|900|900
-6|901|901
-6|902|902
-6|903|903
-6|904|904
-6|905|905
-6|906|906
-6|907|907
-6|908|908
-6|909|909
-6|910|910
-6|911|911
-6|912|912
-6|913|913
-6|914|914
-6|915|915
-6|916|916
-6|917|917
-6|918|918
-6|919|919
-6|920|920
-6|921|921
-6|922|922
-6|923|923
-6|924|924
-6|925|925
-6|926|926
-6|927|927
-6|928|928
-6|929|929
-6|930|930
-6|931|931
-6|932|932
-6|933|933
-6|934|934
-6|935|935
-6|936|936
-6|937|937
-6|938|938
-6|939|939
-6|940|940
-6|941|941
-6|942|942
-6|943|943
-6|944|944
-6|945|945
-6|946|946
-6|947|947
-6|948|948
-6|949|949
-6|950|950
-6|951|951
-6|952|952
-6|953|953
-6|954|954
-6|955|955
-6|956|956
-6|957|957
-6|958|958
-6|959|959
-6|960|960
-6|961|961
-6|962|962
-6|963|963
-6|964|964
-6|965|965
-6|966|966
-6|967|967
-6|968|968
-6|969|969
-6|970|970
-6|971|971
-6|972|972
-6|973|973
-6|974|974
-6|975|975
-6|976|976
-6|977|977
-6|978|978
-6|979|979
-6|980|980
-6|981|981
-6|982|982
-6|983|983
-6|984|984
-6|985|985
-6|986|986
-6|987|987
-6|988|988
-6|989|989
-6|990|990
-6|991|991
-6|992|992
-6|993|993
-6|994|994
-6|995|995
-6|996|996
-6|997|997
-6|998|998
-6|999|999
-6|1000|1000
-7|1|1
-7|2|2
-7|3|3
-7|4|4
-7|5|5
-7|6|6
-7|7|7
-7|8|8
-7|9|9
-7|10|10
-7|11|11
-7|12|12
-7|13|13
-7|14|14
-7|15|15
-7|16|16
-7|17|17
-7|18|18
-7|19|19
-7|20|20
-7|21|21
-7|22|22
-7|23|23
-7|24|24
-7|25|25
-7|26|26
-7|27|27
-7|28|28
-7|29|29
-7|30|30
-7|31|31
-7|32|32
-7|33|33
-7|34|34
-7|35|35
-7|36|36
-7|37|37
-7|38|38
-7|39|39
-7|40|40
-7|41|41
-7|42|42
-7|43|43
-7|44|44
-7|45|45
-7|46|46
-7|47|47
-7|48|48
-7|49|49
-7|50|50
-7|51|51
-7|52|52
-7|53|53
-7|54|54
-7|55|55
-7|56|56
-7|57|57
-7|58|58
-7|59|59
-7|60|60
-7|61|61
-7|62|62
-7|63|63
-7|64|64
-7|65|65
-7|66|66
-7|67|67
-7|68|68
-7|69|69
-7|70|70
-7|71|71
-7|72|72
-7|73|73
-7|74|74
-7|75|75
-7|76|76
-7|77|77
-7|78|78
-7|79|79
-7|80|80
-7|81|81
-7|82|82
-7|83|83
-7|84|84
-7|85|85
-7|86|86
-7|87|87
-7|88|88
-7|89|89
-7|90|90
-7|91|91
-7|92|92
-7|93|93
-7|94|94
-7|95|95
-7|96|96
-7|97|97
-7|98|98
-7|99|99
-7|100|100
-7|101|101
-7|102|102
-7|103|103
-7|104|104
-7|105|105
-7|106|106
-7|107|107
-7|108|108
-7|109|109
-7|110|110
-7|111|111
-7|112|112
-7|113|113
-7|114|114
-7|115|115
-7|116|116
-7|117|117
-7|118|118
-7|119|119
-7|120|120
-7|121|121
-7|122|122
-7|123|123
-7|124|124
-7|125|125
-7|126|126
-7|127|127
-7|128|128
-7|129|129
-7|130|130
-7|131|131
-7|132|132
-7|133|133
-7|134|134
-7|135|135
-7|136|136
-7|137|137
-7|138|138
-7|139|139
-7|140|140
-7|141|141
-7|142|142
-7|143|143
-7|144|144
-7|145|145
-7|146|146
-7|147|147
-7|148|148
-7|149|149
-7|150|150
-7|151|151
-7|152|152
-7|153|153
-7|154|154
-7|155|155
-7|156|156
-7|157|157
-7|158|158
-7|159|159
-7|160|160
-7|161|161
-7|162|162
-7|163|163
-7|164|164
-7|165|165
-7|166|166
-7|167|167
-7|168|168
-7|169|169
-7|170|170
-7|171|171
-7|172|172
-7|173|173
-7|174|174
-7|175|175
-7|176|176
-7|177|177
-7|178|178
-7|179|179
-7|180|180
-7|181|181
-7|182|182
-7|183|183
-7|184|184
-7|185|185
-7|186|186
-7|187|187
-7|188|188
-7|189|189
-7|190|190
-7|191|191
-7|192|192
-7|193|193
-7|194|194
-7|195|195
-7|196|196
-7|197|197
-7|198|198
-7|199|199
-7|200|200
-7|201|201
-7|202|202
-7|203|203
-7|204|204
-7|205|205
-7|206|206
-7|207|207
-7|208|208
-7|209|209
-7|210|210
-7|211|211
-7|212|212
-7|213|213
-7|214|214
-7|215|215
-7|216|216
-7|217|217
-7|218|218
-7|219|219
-7|220|220
-7|221|221
-7|222|222
-7|223|223
-7|224|224
-7|225|225
-7|226|226
-7|227|227
-7|228|228
-7|229|229
-7|230|230
-7|231|231
-7|232|232
-7|233|233
-7|234|234
-7|235|235
-7|236|236
-7|237|237
-7|238|238
-7|239|239
-7|240|240
-7|241|241
-7|242|242
-7|243|243
-7|244|244
-7|245|245
-7|246|246
-7|247|247
-7|248|248
-7|249|249
-7|250|250
-7|251|251
-7|252|252
-7|253|253
-7|254|254
-7|255|255
-7|256|256
-7|257|257
-7|258|258
-7|259|259
-7|260|260
-7|261|261
-7|262|262
-7|263|263
-7|264|264
-7|265|265
-7|266|266
-7|267|267
-7|268|268
-7|269|269
-7|270|270
-7|271|271
-7|272|272
-7|273|273
-7|274|274
-7|275|275
-7|276|276
-7|277|277
-7|278|278
-7|279|279
-7|280|280
-7|281|281
-7|282|282
-7|283|283
-7|284|284
-7|285|285
-7|286|286
-7|287|287
-7|288|288
-7|289|289
-7|290|290
-7|291|291
-7|292|292
-7|293|293
-7|294|294
-7|295|295
-7|296|296
-7|297|297
-7|298|298
-7|299|299
-7|300|300
-7|301|301
-7|302|302
-7|303|303
-7|304|304
-7|305|305
-7|306|306
-7|307|307
-7|308|308
-7|309|309
-7|310|310
-7|311|311
-7|312|312
-7|313|313
-7|314|314
-7|315|315
-7|316|316
-7|317|317
-7|318|318
-7|319|319
-7|320|320
-7|321|321
-7|322|322
-7|323|323
-7|324|324
-7|325|325
-7|326|326
-7|327|327
-7|328|328
-7|329|329
-7|330|330
-7|331|331
-7|332|332
-7|333|333
-7|334|334
-7|335|335
-7|336|336
-7|337|337
-7|338|338
-7|339|339
-7|340|340
-7|341|341
-7|342|342
-7|343|343
-7|344|344
-7|345|345
-7|346|346
-7|347|347
-7|348|348
-7|349|349
-7|350|350
-7|351|351
-7|352|352
-7|353|353
-7|354|354
-7|355|355
-7|356|356
-7|357|357
-7|358|358
-7|359|359
-7|360|360
-7|361|361
-7|362|362
-7|363|363
-7|364|364
-7|365|365
-7|366|366
-7|367|367
-7|368|368
-7|369|369
-7|370|370
-7|371|371
-7|372|372
-7|373|373
-7|374|374
-7|375|375
-7|376|376
-7|377|377
-7|378|378
-7|379|379
-7|380|380
-7|381|381
-7|382|382
-7|383|383
-7|384|384
-7|385|385
-7|386|386
-7|387|387
-7|388|388
-7|389|389
-7|390|390
-7|391|391
-7|392|392
-7|393|393
-7|394|394
-7|395|395
-7|396|396
-7|397|397
-7|398|398
-7|399|399
-7|400|400
-7|401|401
-7|402|402
-7|403|403
-7|404|404
-7|405|405
-7|406|406
-7|407|407
-7|408|408
-7|409|409
-7|410|410
-7|411|411
-7|412|412
-7|413|413
-7|414|414
-7|415|415
-7|416|416
-7|417|417
-7|418|418
-7|419|419
-7|420|420
-7|421|421
-7|422|422
-7|423|423
-7|424|424
-7|425|425
-7|426|426
-7|427|427
-7|428|428
-7|429|429
-7|430|430
-7|431|431
-7|432|432
-7|433|433
-7|434|434
-7|435|435
-7|436|436
-7|437|437
-7|438|438
-7|439|439
-7|440|440
-7|441|441
-7|442|442
-7|443|443
-7|444|444
-7|445|445
-7|446|446
-7|447|447
-7|448|448
-7|449|449
-7|450|450
-7|451|451
-7|452|452
-7|453|453
-7|454|454
-7|455|455
-7|456|456
-7|457|457
-7|458|458
-7|459|459
-7|460|460
-7|461|461
-7|462|462
-7|463|463
-7|464|464
-7|465|465
-7|466|466
-7|467|467
-7|468|468
-7|469|469
-7|470|470
-7|471|471
-7|472|472
-7|473|473
-7|474|474
-7|475|475
-7|476|476
-7|477|477
-7|478|478
-7|479|479
-7|480|480
-7|481|481
-7|482|482
-7|483|483
-7|484|484
-7|485|485
-7|486|486
-7|487|487
-7|488|488
-7|489|489
-7|490|490
-7|491|491
-7|492|492
-7|493|493
-7|494|494
-7|495|495
-7|496|496
-7|497|497
-7|498|498
-7|499|499
-7|500|500
-7|501|501
-7|502|502
-7|503|503
-7|504|504
-7|505|505
-7|506|506
-7|507|507
-7|508|508
-7|509|509
-7|510|510
-7|511|511
-7|512|512
-7|513|513
-7|514|514
-7|515|515
-7|516|516
-7|517|517
-7|518|518
-7|519|519
-7|520|520
-7|521|521
-7|522|522
-7|523|523
-7|524|524
-7|525|525
-7|526|526
-7|527|527
-7|528|528
-7|529|529
-7|530|530
-7|531|531
-7|532|532
-7|533|533
-7|534|534
-7|535|535
-7|536|536
-7|537|537
-7|538|538
-7|539|539
-7|540|540
-7|541|541
-7|542|542
-7|543|543
-7|544|544
-7|545|545
-7|546|546
-7|547|547
-7|548|548
-7|549|549
-7|550|550
-7|551|551
-7|552|552
-7|553|553
-7|554|554
-7|555|555
-7|556|556
-7|557|557
-7|558|558
-7|559|559
-7|560|560
-7|561|561
-7|562|562
-7|563|563
-7|564|564
-7|565|565
-7|566|566
-7|567|567
-7|568|568
-7|569|569
-7|570|570
-7|571|571
-7|572|572
-7|573|573
-7|574|574
-7|575|575
-7|576|576
-7|577|577
-7|578|578
-7|579|579
-7|580|580
-7|581|581
-7|582|582
-7|583|583
-7|584|584
-7|585|585
-7|586|586
-7|587|587
-7|588|588
-7|589|589
-7|590|590
-7|591|591
-7|592|592
-7|593|593
-7|594|594
-7|595|595
-7|596|596
-7|597|597
-7|598|598
-7|599|599
-7|600|600
-7|601|601
-7|602|602
-7|603|603
-7|604|604
-7|605|605
-7|606|606
-7|607|607
-7|608|608
-7|609|609
-7|610|610
-7|611|611
-7|612|612
-7|613|613
-7|614|614
-7|615|615
-7|616|616
-7|617|617
-7|618|618
-7|619|619
-7|620|620
-7|621|621
-7|622|622
-7|623|623
-7|624|624
-7|625|625
-7|626|626
-7|627|627
-7|628|628
-7|629|629
-7|630|630
-7|631|631
-7|632|632
-7|633|633
-7|634|634
-7|635|635
-7|636|636
-7|637|637
-7|638|638
-7|639|639
-7|640|640
-7|641|641
-7|642|642
-7|643|643
-7|644|644
-7|645|645
-7|646|646
-7|647|647
-7|648|648
-7|649|649
-7|650|650
-7|651|651
-7|652|652
-7|653|653
-7|654|654
-7|655|655
-7|656|656
-7|657|657
-7|658|658
-7|659|659
-7|660|660
-7|661|661
-7|662|662
-7|663|663
-7|664|664
-7|665|665
-7|666|666
-7|667|667
-7|668|668
-7|669|669
-7|670|670
-7|671|671
-7|672|672
-7|673|673
-7|674|674
-7|675|675
-7|676|676
-7|677|677
-7|678|678
-7|679|679
-7|680|680
-7|681|681
-7|682|682
-7|683|683
-7|684|684
-7|685|685
-7|686|686
-7|687|687
-7|688|688
-7|689|689
-7|690|690
-7|691|691
-7|692|692
-7|693|693
-7|694|694
-7|695|695
-7|696|696
-7|697|697
-7|698|698
-7|699|699
-7|700|700
-7|701|701
-7|702|702
-7|703|703
-7|704|704
-7|705|705
-7|706|706
-7|707|707
-7|708|708
-7|709|709
-7|710|710
-7|711|711
-7|712|712
-7|713|713
-7|714|714
-7|715|715
-7|716|716
-7|717|717
-7|718|718
-7|719|719
-7|720|720
-7|721|721
-7|722|722
-7|723|723
-7|724|724
-7|725|725
-7|726|726
-7|727|727
-7|728|728
-7|729|729
-7|730|730
-7|731|731
-7|732|732
-7|733|733
-7|734|734
-7|735|735
-7|736|736
-7|737|737
-7|738|738
-7|739|739
-7|740|740
-7|741|741
-7|742|742
-7|743|743
-7|744|744
-7|745|745
-7|746|746
-7|747|747
-7|748|748
-7|749|749
-7|750|750
-7|751|751
-7|752|752
-7|753|753
-7|754|754
-7|755|755
-7|756|756
-7|757|757
-7|758|758
-7|759|759
-7|760|760
-7|761|761
-7|762|762
-7|763|763
-7|764|764
-7|765|765
-7|766|766
-7|767|767
-7|768|768
-7|769|769
-7|770|770
-7|771|771
-7|772|772
-7|773|773
-7|774|774
-7|775|775
-7|776|776
-7|777|777
-7|778|778
-7|779|779
-7|780|780
-7|781|781
-7|782|782
-7|783|783
-7|784|784
-7|785|785
-7|786|786
-7|787|787
-7|788|788
-7|789|789
-7|790|790
-7|791|791
-7|792|792
-7|793|793
-7|794|794
-7|795|795
-7|796|796
-7|797|797
-7|798|798
-7|799|799
-7|800|800
-7|801|801
-7|802|802
-7|803|803
-7|804|804
-7|805|805
-7|806|806
-7|807|807
-7|808|808
-7|809|809
-7|810|810
-7|811|811
-7|812|812
-7|813|813
-7|814|814
-7|815|815
-7|816|816
-7|817|817
-7|818|818
-7|819|819
-7|820|820
-7|821|821
-7|822|822
-7|823|823
-7|824|824
-7|825|825
-7|826|826
-7|827|827
-7|828|828
-7|829|829
-7|830|830
-7|831|831
-7|832|832
-7|833|833
-7|834|834
-7|835|835
-7|836|836
-7|837|837
-7|838|838
-7|839|839
-7|840|840
-7|841|841
-7|842|842
-7|843|843
-7|844|844
-7|845|845
-7|846|846
-7|847|847
-7|848|848
-7|849|849
-7|850|850
-7|851|851
-7|852|852
-7|853|853
-7|854|854
-7|855|855
-7|856|856
-7|857|857
-7|858|858
-7|859|859
-7|860|860
-7|861|861
-7|862|862
-7|863|863
-7|864|864
-7|865|865
-7|866|866
-7|867|867
-7|868|868
-7|869|869
-7|870|870
-7|871|871
-7|872|872
-7|873|873
-7|874|874
-7|875|875
-7|876|876
-7|877|877
-7|878|878
-7|879|879
-7|880|880
-7|881|881
-7|882|882
-7|883|883
-7|884|884
-7|885|885
-7|886|886
-7|887|887
-7|888|888
-7|889|889
-7|890|890
-7|891|891
-7|892|892
-7|893|893
-7|894|894
-7|895|895
-7|896|896
-7|897|897
-7|898|898
-7|899|899
-7|900|900
-7|901|901
-7|902|902
-7|903|903
-7|904|904
-7|905|905
-7|906|906
-7|907|907
-7|908|908
-7|909|909
-7|910|910
-7|911|911
-7|912|912
-7|913|913
-7|914|914
-7|915|915
-7|916|916
-7|917|917
-7|918|918
-7|919|919
-7|920|920
-7|921|921
-7|922|922
-7|923|923
-7|924|924
-7|925|925
-7|926|926
-7|927|927
-7|928|928
-7|929|929
-7|930|930
-7|931|931
-7|932|932
-7|933|933
-7|934|934
-7|935|935
-7|936|936
-7|937|937
-7|938|938
-7|939|939
-7|940|940
-7|941|941
-7|942|942
-7|943|943
-7|944|944
-7|945|945
-7|946|946
-7|947|947
-7|948|948
-7|949|949
-7|950|950
-7|951|951
-7|952|952
-7|953|953
-7|954|954
-7|955|955
-7|956|956
-7|957|957
-7|958|958
-7|959|959
-7|960|960
-7|961|961
-7|962|962
-7|963|963
-7|964|964
-7|965|965
-7|966|966
-7|967|967
-7|968|968
-7|969|969
-7|970|970
-7|971|971
-7|972|972
-7|973|973
-7|974|974
-7|975|975
-7|976|976
-7|977|977
-7|978|978
-7|979|979
-7|980|980
-7|981|981
-7|982|982
-7|983|983
-7|984|984
-7|985|985
-7|986|986
-7|987|987
-7|988|988
-7|989|989
-7|990|990
-7|991|991
-7|992|992
-7|993|993
-7|994|994
-7|995|995
-7|996|996
-7|997|997
-7|998|998
-7|999|999
-7|1000|1000
-8|1|1
-8|2|2
-8|3|3
-8|4|4
-8|5|5
-8|6|6
-8|7|7
-8|8|8
-8|9|9
-8|10|10
-8|11|11
-8|12|12
-8|13|13
-8|14|14
-8|15|15
-8|16|16
-8|17|17
-8|18|18
-8|19|19
-8|20|20
-8|21|21
-8|22|22
-8|23|23
-8|24|24
-8|25|25
-8|26|26
-8|27|27
-8|28|28
-8|29|29
-8|30|30
-8|31|31
-8|32|32
-8|33|33
-8|34|34
-8|35|35
-8|36|36
-8|37|37
-8|38|38
-8|39|39
-8|40|40
-8|41|41
-8|42|42
-8|43|43
-8|44|44
-8|45|45
-8|46|46
-8|47|47
-8|48|48
-8|49|49
-8|50|50
-8|51|51
-8|52|52
-8|53|53
-8|54|54
-8|55|55
-8|56|56
-8|57|57
-8|58|58
-8|59|59
-8|60|60
-8|61|61
-8|62|62
-8|63|63
-8|64|64
-8|65|65
-8|66|66
-8|67|67
-8|68|68
-8|69|69
-8|70|70
-8|71|71
-8|72|72
-8|73|73
-8|74|74
-8|75|75
-8|76|76
-8|77|77
-8|78|78
-8|79|79
-8|80|80
-8|81|81
-8|82|82
-8|83|83
-8|84|84
-8|85|85
-8|86|86
-8|87|87
-8|88|88
-8|89|89
-8|90|90
-8|91|91
-8|92|92
-8|93|93
-8|94|94
-8|95|95
-8|96|96
-8|97|97
-8|98|98
-8|99|99
-8|100|100
-8|101|101
-8|102|102
-8|103|103
-8|104|104
-8|105|105
-8|106|106
-8|107|107
-8|108|108
-8|109|109
-8|110|110
-8|111|111
-8|112|112
-8|113|113
-8|114|114
-8|115|115
-8|116|116
-8|117|117
-8|118|118
-8|119|119
-8|120|120
-8|121|121
-8|122|122
-8|123|123
-8|124|124
-8|125|125
-8|126|126
-8|127|127
-8|128|128
-8|129|129
-8|130|130
-8|131|131
-8|132|132
-8|133|133
-8|134|134
-8|135|135
-8|136|136
-8|137|137
-8|138|138
-8|139|139
-8|140|140
-8|141|141
-8|142|142
-8|143|143
-8|144|144
-8|145|145
-8|146|146
-8|147|147
-8|148|148
-8|149|149
-8|150|150
-8|151|151
-8|152|152
-8|153|153
-8|154|154
-8|155|155
-8|156|156
-8|157|157
-8|158|158
-8|159|159
-8|160|160
-8|161|161
-8|162|162
-8|163|163
-8|164|164
-8|165|165
-8|166|166
-8|167|167
-8|168|168
-8|169|169
-8|170|170
-8|171|171
-8|172|172
-8|173|173
-8|174|174
-8|175|175
-8|176|176
-8|177|177
-8|178|178
-8|179|179
-8|180|180
-8|181|181
-8|182|182
-8|183|183
-8|184|184
-8|185|185
-8|186|186
-8|187|187
-8|188|188
-8|189|189
-8|190|190
-8|191|191
-8|192|192
-8|193|193
-8|194|194
-8|195|195
-8|196|196
-8|197|197
-8|198|198
-8|199|199
-8|200|200
-8|201|201
-8|202|202
-8|203|203
-8|204|204
-8|205|205
-8|206|206
-8|207|207
-8|208|208
-8|209|209
-8|210|210
-8|211|211
-8|212|212
-8|213|213
-8|214|214
-8|215|215
-8|216|216
-8|217|217
-8|218|218
-8|219|219
-8|220|220
-8|221|221
-8|222|222
-8|223|223
-8|224|224
-8|225|225
-8|226|226
-8|227|227
-8|228|228
-8|229|229
-8|230|230
-8|231|231
-8|232|232
-8|233|233
-8|234|234
-8|235|235
-8|236|236
-8|237|237
-8|238|238
-8|239|239
-8|240|240
-8|241|241
-8|242|242
-8|243|243
-8|244|244
-8|245|245
-8|246|246
-8|247|247
-8|248|248
-8|249|249
-8|250|250
-8|251|251
-8|252|252
-8|253|253
-8|254|254
-8|255|255
-8|256|256
-8|257|257
-8|258|258
-8|259|259
-8|260|260
-8|261|261
-8|262|262
-8|263|263
-8|264|264
-8|265|265
-8|266|266
-8|267|267
-8|268|268
-8|269|269
-8|270|270
-8|271|271
-8|272|272
-8|273|273
-8|274|274


<TRUNCATED>


[2/6] incubator-griffin git commit: remove stale docs

Posted by gu...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-griffin/blob/e934c0d6/docker/griffin_env/conf/hive/hive-site.xml.template
----------------------------------------------------------------------
diff --git a/docker/griffin_env/conf/hive/hive-site.xml.template b/docker/griffin_env/conf/hive/hive-site.xml.template
deleted file mode 100644
index f641dee..0000000
--- a/docker/griffin_env/conf/hive/hive-site.xml.template
+++ /dev/null
@@ -1,3911 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?><!--
-   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.
---><configuration>
-  <!-- WARNING!!! This file is auto generated for documentation purposes ONLY! -->
-  <!-- WARNING!!! Any changes you make to this file will be ignored by Hive.   -->
-  <!-- WARNING!!! You must make your changes in hive-site.xml instead.         -->
-  <!-- Hive Execution Parameters -->
-  <property>
-    <name>hive.exec.script.wrapper</name>
-    <value/>
-    <description/>
-  </property>
-  <property>
-    <name>hive.exec.plan</name>
-    <value/>
-    <description/>
-  </property>
-  <property>
-    <name>hive.plan.serialization.format</name>
-    <value>kryo</value>
-    <description>
-      Query plan format serialization between client and task nodes. 
-      Two supported values are : kryo and javaXML. Kryo is default.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.stagingdir</name>
-    <value>.hive-staging</value>
-    <description>Directory name that will be created inside table locations in order to support HDFS encryption. This is replaces ${hive.exec.scratchdir} for query results with the exception of read-only tables. In all cases ${hive.exec.scratchdir} is still used for other temporary files, such as job plans.</description>
-  </property>
-  <property>
-    <name>hive.exec.scratchdir</name>
-    <value>/tmp/hive-${user.name}</value>
-    <description>HDFS root scratch dir for Hive jobs which gets created with write all (733) permission. For each connecting user, an HDFS scratch dir: ${hive.exec.scratchdir}/&lt;username&gt; is created, with ${hive.scratch.dir.permission}.</description>
-  </property>
-  <property>
-    <name>hive.exec.local.scratchdir</name>
-    <value>/tmp/${user.name}</value>
-    <description>Local scratch space for Hive jobs</description>
-  </property>
-  <property>
-    <name>hive.downloaded.resources.dir</name>
-    <value>/tmp/${user.name}_resources</value>
-    <description>Temporary local directory for added resources in the remote file system.</description>
-  </property>
-  <property>
-    <name>hive.scratch.dir.permission</name>
-    <value>733</value>
-    <description>The permission for the user specific scratch directories that get created.</description>
-  </property>
-  <property>
-    <name>hive.exec.submitviachild</name>
-    <value>false</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.exec.submit.local.task.via.child</name>
-    <value>true</value>
-    <description>
-      Determines whether local tasks (typically mapjoin hashtable generation phase) runs in 
-      separate JVM (true recommended) or not. 
-      Avoids the overhead of spawning new JVM, but can lead to out-of-memory issues.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.script.maxerrsize</name>
-    <value>100000</value>
-    <description>
-      Maximum number of bytes a script is allowed to emit to standard error (per map-reduce task). 
-      This prevents runaway scripts from filling logs partitions to capacity
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.script.allow.partial.consumption</name>
-    <value>false</value>
-    <description>
-      When enabled, this option allows a user script to exit successfully without consuming 
-      all the data from the standard input.
-    </description>
-  </property>
-  <property>
-    <name>stream.stderr.reporter.prefix</name>
-    <value>reporter:</value>
-    <description>Streaming jobs that log to standard error with this prefix can log counter or status information.</description>
-  </property>
-  <property>
-    <name>stream.stderr.reporter.enabled</name>
-    <value>true</value>
-    <description>Enable consumption of status and counter messages for streaming jobs.</description>
-  </property>
-  <property>
-    <name>hive.exec.compress.output</name>
-    <value>false</value>
-    <description>
-      This controls whether the final outputs of a query (to a local/HDFS file or a Hive table) is compressed. 
-      The compression codec and other options are determined from Hadoop config variables mapred.output.compress*
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.compress.intermediate</name>
-    <value>false</value>
-    <description>
-      This controls whether intermediate files produced by Hive between multiple map-reduce jobs are compressed. 
-      The compression codec and other options are determined from Hadoop config variables mapred.output.compress*
-    </description>
-  </property>
-  <property>
-    <name>hive.intermediate.compression.codec</name>
-    <value/>
-    <description/>
-  </property>
-  <property>
-    <name>hive.intermediate.compression.type</name>
-    <value/>
-    <description/>
-  </property>
-  <property>
-    <name>hive.exec.reducers.bytes.per.reducer</name>
-    <value>256000000</value>
-    <description>size per reducer.The default is 256Mb, i.e if the input size is 1G, it will use 4 reducers.</description>
-  </property>
-  <property>
-    <name>hive.exec.reducers.max</name>
-    <value>1009</value>
-    <description>
-      max number of reducers will be used. If the one specified in the configuration parameter mapred.reduce.tasks is
-      negative, Hive will use this one as the max number of reducers when automatically determine number of reducers.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.pre.hooks</name>
-    <value/>
-    <description>
-      Comma-separated list of pre-execution hooks to be invoked for each statement. 
-      A pre-execution hook is specified as the name of a Java class which implements the 
-      org.apache.hadoop.hive.ql.hooks.ExecuteWithHookContext interface.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.post.hooks</name>
-    <value/>
-    <description>
-      Comma-separated list of post-execution hooks to be invoked for each statement. 
-      A post-execution hook is specified as the name of a Java class which implements the 
-      org.apache.hadoop.hive.ql.hooks.ExecuteWithHookContext interface.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.failure.hooks</name>
-    <value/>
-    <description>
-      Comma-separated list of on-failure hooks to be invoked for each statement. 
-      An on-failure hook is specified as the name of Java class which implements the 
-      org.apache.hadoop.hive.ql.hooks.ExecuteWithHookContext interface.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.query.redactor.hooks</name>
-    <value/>
-    <description>
-      Comma-separated list of hooks to be invoked for each query which can 
-      tranform the query before it's placed in the job.xml file. Must be a Java class which 
-      extends from the org.apache.hadoop.hive.ql.hooks.Redactor abstract class.
-    </description>
-  </property>
-  <property>
-    <name>hive.client.stats.publishers</name>
-    <value/>
-    <description>
-      Comma-separated list of statistics publishers to be invoked on counters on each job. 
-      A client stats publisher is specified as the name of a Java class which implements the 
-      org.apache.hadoop.hive.ql.stats.ClientStatsPublisher interface.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.parallel</name>
-    <value>false</value>
-    <description>Whether to execute jobs in parallel</description>
-  </property>
-  <property>
-    <name>hive.exec.parallel.thread.number</name>
-    <value>8</value>
-    <description>How many jobs at most can be executed in parallel</description>
-  </property>
-  <property>
-    <name>hive.mapred.reduce.tasks.speculative.execution</name>
-    <value>true</value>
-    <description>Whether speculative execution for reducers should be turned on. </description>
-  </property>
-  <property>
-    <name>hive.exec.counters.pull.interval</name>
-    <value>1000</value>
-    <description>
-      The interval with which to poll the JobTracker for the counters the running job. 
-      The smaller it is the more load there will be on the jobtracker, the higher it is the less granular the caught will be.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.dynamic.partition</name>
-    <value>true</value>
-    <description>Whether or not to allow dynamic partitions in DML/DDL.</description>
-  </property>
-  <property>
-    <name>hive.exec.dynamic.partition.mode</name>
-    <value>strict</value>
-    <description>
-      In strict mode, the user must specify at least one static partition
-      in case the user accidentally overwrites all partitions.
-      In nonstrict mode all partitions are allowed to be dynamic.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.max.dynamic.partitions</name>
-    <value>1000</value>
-    <description>Maximum number of dynamic partitions allowed to be created in total.</description>
-  </property>
-  <property>
-    <name>hive.exec.max.dynamic.partitions.pernode</name>
-    <value>100</value>
-    <description>Maximum number of dynamic partitions allowed to be created in each mapper/reducer node.</description>
-  </property>
-  <property>
-    <name>hive.exec.max.created.files</name>
-    <value>100000</value>
-    <description>Maximum number of HDFS files created by all mappers/reducers in a MapReduce job.</description>
-  </property>
-  <property>
-    <name>hive.exec.default.partition.name</name>
-    <value>__HIVE_DEFAULT_PARTITION__</value>
-    <description>
-      The default partition name in case the dynamic partition column value is null/empty string or any other values that cannot be escaped. 
-      This value must not contain any special character used in HDFS URI (e.g., ':', '%', '/' etc). 
-      The user has to be aware that the dynamic partition value should not contain this value to avoid confusions.
-    </description>
-  </property>
-  <property>
-    <name>hive.lockmgr.zookeeper.default.partition.name</name>
-    <value>__HIVE_DEFAULT_ZOOKEEPER_PARTITION__</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.exec.show.job.failure.debug.info</name>
-    <value>true</value>
-    <description>
-      If a job fails, whether to provide a link in the CLI to the task with the
-      most failures, along with debugging hints if applicable.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.job.debug.capture.stacktraces</name>
-    <value>true</value>
-    <description>
-      Whether or not stack traces parsed from the task logs of a sampled failed task 
-      for each failed job should be stored in the SessionState
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.job.debug.timeout</name>
-    <value>30000</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.exec.tasklog.debug.timeout</name>
-    <value>20000</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.output.file.extension</name>
-    <value/>
-    <description>
-      String used as a file extension for output files. 
-      If not set, defaults to the codec extension for text files (e.g. ".gz"), or no extension otherwise.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.mode.local.auto</name>
-    <value>false</value>
-    <description>Let Hive determine whether to run in local mode automatically</description>
-  </property>
-  <property>
-    <name>hive.exec.mode.local.auto.inputbytes.max</name>
-    <value>134217728</value>
-    <description>When hive.exec.mode.local.auto is true, input bytes should less than this for local mode.</description>
-  </property>
-  <property>
-    <name>hive.exec.mode.local.auto.input.files.max</name>
-    <value>4</value>
-    <description>When hive.exec.mode.local.auto is true, the number of tasks should less than this for local mode.</description>
-  </property>
-  <property>
-    <name>hive.exec.drop.ignorenonexistent</name>
-    <value>true</value>
-    <description>Do not report an error if DROP TABLE/VIEW/Index/Function specifies a non-existent table/view/index/function</description>
-  </property>
-  <property>
-    <name>hive.ignore.mapjoin.hint</name>
-    <value>true</value>
-    <description>Ignore the mapjoin hint</description>
-  </property>
-  <property>
-    <name>hive.file.max.footer</name>
-    <value>100</value>
-    <description>maximum number of lines for footer user can define for a table file</description>
-  </property>
-  <property>
-    <name>hive.resultset.use.unique.column.names</name>
-    <value>true</value>
-    <description>
-      Make column names unique in the result set by qualifying column names with table alias if needed.
-      Table alias will be added to column names for queries of type "select *" or 
-      if query explicitly uses table alias "select r1.x..".
-    </description>
-  </property>
-  <property>
-    <name>fs.har.impl</name>
-    <value>org.apache.hadoop.hive.shims.HiveHarFileSystem</value>
-    <description>The implementation for accessing Hadoop Archives. Note that this won't be applicable to Hadoop versions less than 0.20</description>
-  </property>
-  <property>
-    <name>hive.metastore.warehouse.dir</name>
-    <value>/user/hive/warehouse</value>
-    <description>location of default database for the warehouse</description>
-  </property>
-  <property>
-    <name>hive.metastore.uris</name>
-    <value>thrift://HOSTNAME:9083</value>
-    <description>Thrift URI for the remote metastore. Used by metastore client to connect to remote metastore.</description>
-  </property>
-  <property>
-    <name>hive.metastore.connect.retries</name>
-    <value>3</value>
-    <description>Number of retries while opening a connection to metastore</description>
-  </property>
-  <property>
-    <name>hive.metastore.failure.retries</name>
-    <value>1</value>
-    <description>Number of retries upon failure of Thrift metastore calls</description>
-  </property>
-  <property>
-    <name>hive.metastore.client.connect.retry.delay</name>
-    <value>1s</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is sec if not specified.
-      Number of seconds for the client to wait between consecutive connection attempts
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.client.socket.timeout</name>
-    <value>600s</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is sec if not specified.
-      MetaStore Client socket timeout in seconds
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.client.socket.lifetime</name>
-    <value>0s</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is sec if not specified.
-      MetaStore Client socket lifetime in seconds. After this time is exceeded, client
-      reconnects on the next MetaStore operation. A value of 0s means the connection
-      has an infinite lifetime.
-    </description>
-  </property>
-  <property>
-    <name>javax.jdo.option.ConnectionPassword</name>
-    <value>123456</value>
-    <description>password to use against metastore database</description>
-  </property>
-  <property>
-    <name>hive.metastore.ds.connection.url.hook</name>
-    <value/>
-    <description>Name of the hook to use for retrieving the JDO connection URL. If empty, the value in javax.jdo.option.ConnectionURL is used</description>
-  </property>
-  <property>
-    <name>javax.jdo.option.Multithreaded</name>
-    <value>true</value>
-    <description>Set this to true if multiple threads access metastore through JDO concurrently.</description>
-  </property>
-  <property>
-    <name>javax.jdo.option.ConnectionURL</name>
-    <!--<value>jdbc:derby:;databaseName=metastore_db;create=true</value>-->
-<value>jdbc:mysql://HOSTNAME:3306/metastore?createDatabaseIfNotExist=true</value>
-    <description>JDBC connect string for a JDBC metastore</description>
-  </property>
-  <property>
-    <name>hive.hmshandler.retry.attempts</name>
-    <value>10</value>
-    <description>The number of times to retry a HMSHandler call if there were a connection error.</description>
-  </property>
-  <property>
-    <name>hive.hmshandler.retry.interval</name>
-    <value>2000ms</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is msec if not specified.
-      The time between HMSHandler retry attempts on failure.
-    </description>
-  </property>
-  <property>
-    <name>hive.hmshandler.force.reload.conf</name>
-    <value>false</value>
-    <description>
-      Whether to force reloading of the HMSHandler configuration (including
-      the connection URL, before the next metastore query that accesses the
-      datastore. Once reloaded, this value is reset to false. Used for
-      testing only.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.server.max.message.size</name>
-    <value>104857600</value>
-    <description>Maximum message size in bytes a HMS will accept.</description>
-  </property>
-  <property>
-    <name>hive.metastore.server.min.threads</name>
-    <value>200</value>
-    <description>Minimum number of worker threads in the Thrift server's pool.</description>
-  </property>
-  <property>
-    <name>hive.metastore.server.max.threads</name>
-    <value>1000</value>
-    <description>Maximum number of worker threads in the Thrift server's pool.</description>
-  </property>
-  <property>
-    <name>hive.metastore.server.tcp.keepalive</name>
-    <value>true</value>
-    <description>Whether to enable TCP keepalive for the metastore server. Keepalive will prevent accumulation of half-open connections.</description>
-  </property>
-  <property>
-    <name>hive.metastore.archive.intermediate.original</name>
-    <value>_INTERMEDIATE_ORIGINAL</value>
-    <description>
-      Intermediate dir suffixes used for archiving. Not important what they
-      are, as long as collisions are avoided
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.archive.intermediate.archived</name>
-    <value>_INTERMEDIATE_ARCHIVED</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.metastore.archive.intermediate.extracted</name>
-    <value>_INTERMEDIATE_EXTRACTED</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.metastore.kerberos.keytab.file</name>
-    <value/>
-    <description>The path to the Kerberos Keytab file containing the metastore Thrift server's service principal.</description>
-  </property>
-  <property>
-    <name>hive.metastore.kerberos.principal</name>
-    <value>hive-metastore/_HOST@EXAMPLE.COM</value>
-    <description>
-      The service principal for the metastore Thrift server. 
-      The special string _HOST will be replaced automatically with the correct host name.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.sasl.enabled</name>
-    <value>false</value>
-    <description>If true, the metastore Thrift interface will be secured with SASL. Clients must authenticate with Kerberos.</description>
-  </property>
-  <property>
-    <name>hive.metastore.thrift.framed.transport.enabled</name>
-    <value>false</value>
-    <description>If true, the metastore Thrift interface will use TFramedTransport. When false (default) a standard TTransport is used.</description>
-  </property>
-  <property>
-    <name>hive.metastore.thrift.compact.protocol.enabled</name>
-    <value>false</value>
-    <description>
-      If true, the metastore Thrift interface will use TCompactProtocol. When false (default) TBinaryProtocol will be used.
-      Setting it to true will break compatibility with older clients running TBinaryProtocol.
-    </description>
-  </property>
-  <property>
-    <name>hive.cluster.delegation.token.store.class</name>
-    <value>org.apache.hadoop.hive.thrift.MemoryTokenStore</value>
-    <description>The delegation token store implementation. Set to org.apache.hadoop.hive.thrift.ZooKeeperTokenStore for load-balanced cluster.</description>
-  </property>
-  <property>
-    <name>hive.cluster.delegation.token.store.zookeeper.connectString</name>
-    <value/>
-    <description>
-      The ZooKeeper token store connect string. You can re-use the configuration value
-      set in hive.zookeeper.quorum, by leaving this parameter unset.
-    </description>
-  </property>
-  <property>
-    <name>hive.cluster.delegation.token.store.zookeeper.znode</name>
-    <value>/hivedelegation</value>
-    <description>
-      The root path for token store data. Note that this is used by both HiveServer2 and
-      MetaStore to store delegation Token. One directory gets created for each of them.
-      The final directory names would have the servername appended to it (HIVESERVER2,
-      METASTORE).
-    </description>
-  </property>
-  <property>
-    <name>hive.cluster.delegation.token.store.zookeeper.acl</name>
-    <value/>
-    <description>
-      ACL for token store entries. Comma separated list of ACL entries. For example:
-      sasl:hive/host1@MY.DOMAIN:cdrwa,sasl:hive/host2@MY.DOMAIN:cdrwa
-      Defaults to all permissions for the hiveserver2/metastore process user.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.cache.pinobjtypes</name>
-    <value>Table,StorageDescriptor,SerDeInfo,Partition,Database,Type,FieldSchema,Order</value>
-    <description>List of comma separated metastore object types that should be pinned in the cache</description>
-  </property>
-  <property>
-    <name>datanucleus.connectionPoolingType</name>
-    <value>BONECP</value>
-    <description>Specify connection pool library for datanucleus</description>
-  </property>
-  <property>
-    <name>datanucleus.validateTables</name>
-    <value>false</value>
-    <description>validates existing schema against code. turn this on if you want to verify existing schema</description>
-  </property>
-  <property>
-    <name>datanucleus.validateColumns</name>
-    <value>false</value>
-    <description>validates existing schema against code. turn this on if you want to verify existing schema</description>
-  </property>
-  <property>
-    <name>datanucleus.validateConstraints</name>
-    <value>false</value>
-    <description>validates existing schema against code. turn this on if you want to verify existing schema</description>
-  </property>
-  <property>
-    <name>datanucleus.storeManagerType</name>
-    <value>rdbms</value>
-    <description>metadata store type</description>
-  </property>
-  <property>
-    <name>datanucleus.autoCreateSchema</name>
-    <value>false</value>
-    <description>creates necessary schema on a startup if one doesn't exist. set this to false, after creating it once</description>
-  </property>
-  <property>
-    <name>datanucleus.fixedDatastore</name>
-    <value>true</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.metastore.schema.verification</name>
-    <value>false</value>
-    <description>
-      Enforce metastore schema version consistency.
-      True: Verify that version information stored in metastore matches with one from Hive jars.  Also disable automatic
-            schema migration attempt. Users are required to manually migrate schema after Hive upgrade which ensures
-            proper metastore schema migration. (Default)
-      False: Warn if the version information stored in metastore doesn't match with one from in Hive jars.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.schema.verification.record.version</name>
-    <value>true</value>
-    <description>
-      When true the current MS version is recorded in the VERSION table. If this is disabled and verification is
-       enabled the MS will be unusable.
-    </description>
-  </property>
-  <property>
-    <name>datanucleus.autoStartMechanismMode</name>
-    <value>checked</value>
-    <description>throw exception if metadata tables are incorrect</description>
-  </property>
-  <property>
-    <name>datanucleus.transactionIsolation</name>
-    <value>read-committed</value>
-    <description>Default transaction isolation level for identity generation.</description>
-  </property>
-  <property>
-    <name>datanucleus.cache.level2</name>
-    <value>false</value>
-    <description>Use a level 2 cache. Turn this off if metadata is changed independently of Hive metastore server</description>
-  </property>
-  <property>
-    <name>datanucleus.cache.level2.type</name>
-    <value>none</value>
-    <description/>
-  </property>
-  <property>
-    <name>datanucleus.identifierFactory</name>
-    <value>datanucleus1</value>
-    <description>
-      Name of the identifier factory to use when generating table/column names etc. 
-      'datanucleus1' is used for backward compatibility with DataNucleus v1
-    </description>
-  </property>
-  <property>
-    <name>datanucleus.rdbms.useLegacyNativeValueStrategy</name>
-    <value>true</value>
-    <description/>
-  </property>
-  <property>
-    <name>datanucleus.plugin.pluginRegistryBundleCheck</name>
-    <value>LOG</value>
-    <description>Defines what happens when plugin bundles are found and are duplicated [EXCEPTION|LOG|NONE]</description>
-  </property>
-  <property>
-    <name>hive.metastore.batch.retrieve.max</name>
-    <value>300</value>
-    <description>
-      Maximum number of objects (tables/partitions) can be retrieved from metastore in one batch. 
-      The higher the number, the less the number of round trips is needed to the Hive metastore server, 
-      but it may also cause higher memory requirement at the client side.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.batch.retrieve.table.partition.max</name>
-    <value>1000</value>
-    <description>Maximum number of table partitions that metastore internally retrieves in one batch.</description>
-  </property>
-  <property>
-    <name>hive.metastore.init.hooks</name>
-    <value/>
-    <description>
-      A comma separated list of hooks to be invoked at the beginning of HMSHandler initialization. 
-      An init hook is specified as the name of Java class which extends org.apache.hadoop.hive.metastore.MetaStoreInitListener.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.pre.event.listeners</name>
-    <value/>
-    <description>List of comma separated listeners for metastore events.</description>
-  </property>
-  <property>
-    <name>hive.metastore.event.listeners</name>
-    <value/>
-    <description/>
-  </property>
-  <property>
-    <name>hive.metastore.event.db.listener.timetolive</name>
-    <value>86400s</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is sec if not specified.
-      time after which events will be removed from the database listener queue
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.authorization.storage.checks</name>
-    <value>false</value>
-    <description>
-      Should the metastore do authorization checks against the underlying storage (usually hdfs) 
-      for operations like drop-partition (disallow the drop-partition if the user in
-      question doesn't have permissions to delete the corresponding directory
-      on the storage).
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.event.clean.freq</name>
-    <value>0s</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is sec if not specified.
-      Frequency at which timer task runs to purge expired events in metastore.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.event.expiry.duration</name>
-    <value>0s</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is sec if not specified.
-      Duration after which events expire from events table
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.execute.setugi</name>
-    <value>true</value>
-    <description>
-      In unsecure mode, setting this property to true will cause the metastore to execute DFS operations using 
-      the client's reported user and group permissions. Note that this property must be set on 
-      both the client and server sides. Further note that its best effort. 
-      If client sets its to true and server sets it to false, client setting will be ignored.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.partition.name.whitelist.pattern</name>
-    <value/>
-    <description>Partition names will be checked against this regex pattern and rejected if not matched.</description>
-  </property>
-  <property>
-    <name>hive.metastore.integral.jdo.pushdown</name>
-    <value>false</value>
-    <description>
-      Allow JDO query pushdown for integral partition columns in metastore. Off by default. This
-      improves metastore perf for integral columns, especially if there's a large number of partitions.
-      However, it doesn't work correctly with integral values that are not normalized (e.g. have
-      leading zeroes, like 0012). If metastore direct SQL is enabled and works, this optimization
-      is also irrelevant.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.try.direct.sql</name>
-    <value>true</value>
-    <description>
-      Whether the Hive metastore should try to use direct SQL queries instead of the
-      DataNucleus for certain read paths. This can improve metastore performance when
-      fetching many partitions or column statistics by orders of magnitude; however, it
-      is not guaranteed to work on all RDBMS-es and all versions. In case of SQL failures,
-      the metastore will fall back to the DataNucleus, so it's safe even if SQL doesn't
-      work for all queries on your datastore. If all SQL queries fail (for example, your
-      metastore is backed by MongoDB), you might want to disable this to save the
-      try-and-fall-back cost.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.direct.sql.batch.size</name>
-    <value>0</value>
-    <description>
-      Batch size for partition and other object retrieval from the underlying DB in direct
-      SQL. For some DBs like Oracle and MSSQL, there are hardcoded or perf-based limitations
-      that necessitate this. For DBs that can handle the queries, this isn't necessary and
-      may impede performance. -1 means no batching, 0 means automatic batching.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.try.direct.sql.ddl</name>
-    <value>true</value>
-    <description>
-      Same as hive.metastore.try.direct.sql, for read statements within a transaction that
-      modifies metastore data. Due to non-standard behavior in Postgres, if a direct SQL
-      select query has incorrect syntax or something similar inside a transaction, the
-      entire transaction will fail and fall-back to DataNucleus will not be possible. You
-      should disable the usage of direct SQL inside transactions if that happens in your case.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.orm.retrieveMapNullsAsEmptyStrings</name>
-    <value>false</value>
-    <description>Thrift does not support nulls in maps, so any nulls present in maps retrieved from ORM must either be pruned or converted to empty strings. Some backing dbs such as Oracle persist empty strings as nulls, so we should set this parameter if we wish to reverse that behaviour. For others, pruning is the correct behaviour</description>
-  </property>
-  <property>
-    <name>hive.metastore.disallow.incompatible.col.type.changes</name>
-    <value>false</value>
-    <description>
-      If true (default is false), ALTER TABLE operations which change the type of a
-      column (say STRING) to an incompatible type (say MAP) are disallowed.
-      RCFile default SerDe (ColumnarSerDe) serializes the values in such a way that the
-      datatypes can be converted from string to any type. The map is also serialized as
-      a string, which can be read as a string as well. However, with any binary
-      serialization, this is not true. Blocking the ALTER TABLE prevents ClassCastExceptions
-      when subsequently trying to access old partitions.
-      
-      Primitive types like INT, STRING, BIGINT, etc., are compatible with each other and are
-      not blocked.
-      
-      See HIVE-4409 for more details.
-    </description>
-  </property>
-  <property>
-    <name>hive.table.parameters.default</name>
-    <value/>
-    <description>Default property values for newly created tables</description>
-  </property>
-  <property>
-    <name>hive.ddl.createtablelike.properties.whitelist</name>
-    <value/>
-    <description>Table Properties to copy over when executing a Create Table Like.</description>
-  </property>
-  <property>
-    <name>hive.metastore.rawstore.impl</name>
-    <value>org.apache.hadoop.hive.metastore.ObjectStore</value>
-    <description>
-      Name of the class that implements org.apache.hadoop.hive.metastore.rawstore interface. 
-      This class is used to store and retrieval of raw metadata objects such as table, database
-    </description>
-  </property>
-  <property>
-    <name>javax.jdo.option.ConnectionDriverName</name>
-    <!--<value>org.apache.derby.jdbc.EmbeddedDriver</value>-->
-<value>com.mysql.jdbc.Driver</value>
-    <description>Driver class name for a JDBC metastore</description>
-  </property>
-  <property>
-    <name>javax.jdo.PersistenceManagerFactoryClass</name>
-    <value>org.datanucleus.api.jdo.JDOPersistenceManagerFactory</value>
-    <description>class implementing the jdo persistence</description>
-  </property>
-  <property>
-    <name>hive.metastore.expression.proxy</name>
-    <value>org.apache.hadoop.hive.ql.optimizer.ppr.PartitionExpressionForMetastore</value>
-    <description/>
-  </property>
-  <property>
-    <name>javax.jdo.option.DetachAllOnCommit</name>
-    <value>true</value>
-    <description>Detaches all objects from session so that they can be used after transaction is committed</description>
-  </property>
-  <property>
-    <name>javax.jdo.option.NonTransactionalRead</name>
-    <value>true</value>
-    <description>Reads outside of transactions</description>
-  </property>
-  <property>
-    <name>javax.jdo.option.ConnectionUserName</name>
-    <value>hive</value>
-    <description>Username to use against metastore database</description>
-  </property>
-  <property>
-    <name>hive.metastore.end.function.listeners</name>
-    <value/>
-    <description>List of comma separated listeners for the end of metastore functions.</description>
-  </property>
-  <property>
-    <name>hive.metastore.partition.inherit.table.properties</name>
-    <value/>
-    <description>
-      List of comma separated keys occurring in table properties which will get inherited to newly created partitions. 
-      * implies all the keys will get inherited.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.filter.hook</name>
-    <value>org.apache.hadoop.hive.metastore.DefaultMetaStoreFilterHookImpl</value>
-    <description>Metastore hook class for filtering the metadata read results. If hive.security.authorization.manageris set to instance of HiveAuthorizerFactory, then this value is ignored.</description>
-  </property>
-  <property>
-    <name>hive.metastore.dml.events</name>
-    <value>false</value>
-    <description>If true, the metastore will be asked to fire events for DML operations</description>
-  </property>
-  <property>
-    <name>hive.metastore.client.drop.partitions.using.expressions</name>
-    <value>true</value>
-    <description>Choose whether dropping partitions with HCatClient pushes the partition-predicate to the metastore, or drops partitions iteratively</description>
-  </property>
-  <property>
-    <name>hive.metastore.aggregate.stats.cache.enabled</name>
-    <value>true</value>
-    <description>Whether aggregate stats caching is enabled or not.</description>
-  </property>
-  <property>
-    <name>hive.metastore.aggregate.stats.cache.size</name>
-    <value>10000</value>
-    <description>Maximum number of aggregate stats nodes that we will place in the metastore aggregate stats cache.</description>
-  </property>
-  <property>
-    <name>hive.metastore.aggregate.stats.cache.max.partitions</name>
-    <value>10000</value>
-    <description>Maximum number of partitions that are aggregated per cache node.</description>
-  </property>
-  <property>
-    <name>hive.metastore.aggregate.stats.cache.fpp</name>
-    <value>0.01</value>
-    <description>Maximum false positive probability for the Bloom Filter used in each aggregate stats cache node (default 1%).</description>
-  </property>
-  <property>
-    <name>hive.metastore.aggregate.stats.cache.max.variance</name>
-    <value>0.01</value>
-    <description>Maximum tolerable variance in number of partitions between a cached node and our request (default 1%).</description>
-  </property>
-  <property>
-    <name>hive.metastore.aggregate.stats.cache.ttl</name>
-    <value>600s</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is sec if not specified.
-      Number of seconds for a cached node to be active in the cache before they become stale.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.aggregate.stats.cache.max.writer.wait</name>
-    <value>5000ms</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is msec if not specified.
-      Number of milliseconds a writer will wait to acquire the writelock before giving up.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.aggregate.stats.cache.max.reader.wait</name>
-    <value>1000ms</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is msec if not specified.
-      Number of milliseconds a reader will wait to acquire the readlock before giving up.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.aggregate.stats.cache.max.full</name>
-    <value>0.9</value>
-    <description>Maximum cache full % after which the cache cleaner thread kicks in.</description>
-  </property>
-  <property>
-    <name>hive.metastore.aggregate.stats.cache.clean.until</name>
-    <value>0.8</value>
-    <description>The cleaner thread cleans until cache reaches this % full size.</description>
-  </property>
-  <property>
-    <name>hive.metadata.export.location</name>
-    <value/>
-    <description>
-      When used in conjunction with the org.apache.hadoop.hive.ql.parse.MetaDataExportListener pre event listener, 
-      it is the location to which the metadata will be exported. The default is an empty string, which results in the 
-      metadata being exported to the current user's home directory on HDFS.
-    </description>
-  </property>
-  <property>
-    <name>hive.metadata.move.exported.metadata.to.trash</name>
-    <value>true</value>
-    <description>
-      When used in conjunction with the org.apache.hadoop.hive.ql.parse.MetaDataExportListener pre event listener, 
-      this setting determines if the metadata that is exported will subsequently be moved to the user's trash directory 
-      alongside the dropped table data. This ensures that the metadata will be cleaned up along with the dropped table data.
-    </description>
-  </property>
-  <property>
-    <name>hive.cli.errors.ignore</name>
-    <value>false</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.cli.print.current.db</name>
-    <value>false</value>
-    <description>Whether to include the current database in the Hive prompt.</description>
-  </property>
-  <property>
-    <name>hive.cli.prompt</name>
-    <value>hive</value>
-    <description>
-      Command line prompt configuration value. Other hiveconf can be used in this configuration value. 
-      Variable substitution will only be invoked at the Hive CLI startup.
-    </description>
-  </property>
-  <property>
-    <name>hive.cli.pretty.output.num.cols</name>
-    <value>-1</value>
-    <description>
-      The number of columns to use when formatting output generated by the DESCRIBE PRETTY table_name command.
-      If the value of this property is -1, then Hive will use the auto-detected terminal width.
-    </description>
-  </property>
-  <property>
-    <name>hive.metastore.fs.handler.class</name>
-    <value>org.apache.hadoop.hive.metastore.HiveMetaStoreFsImpl</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.session.id</name>
-    <value/>
-    <description/>
-  </property>
-  <property>
-    <name>hive.session.silent</name>
-    <value>false</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.session.history.enabled</name>
-    <value>false</value>
-    <description>Whether to log Hive query, query plan, runtime statistics etc.</description>
-  </property>
-  <property>
-    <name>hive.query.string</name>
-    <value/>
-    <description>Query being executed (might be multiple per a session)</description>
-  </property>
-  <property>
-    <name>hive.query.id</name>
-    <value/>
-    <description>ID for query being executed (might be multiple per a session)</description>
-  </property>
-  <property>
-    <name>hive.jobname.length</name>
-    <value>50</value>
-    <description>max jobname length</description>
-  </property>
-  <property>
-    <name>hive.jar.path</name>
-    <value/>
-    <description>The location of hive_cli.jar that is used when submitting jobs in a separate jvm.</description>
-  </property>
-  <property>
-    <name>hive.aux.jars.path</name>
-    <value/>
-    <description>The location of the plugin jars that contain implementations of user defined functions and serdes.</description>
-  </property>
-  <property>
-    <name>hive.reloadable.aux.jars.path</name>
-    <value/>
-    <description>Jars can be renewed by executing reload command. And these jars can be used as the auxiliary classes like creating a UDF or SerDe.</description>
-  </property>
-  <property>
-    <name>hive.added.files.path</name>
-    <value/>
-    <description>This an internal parameter.</description>
-  </property>
-  <property>
-    <name>hive.added.jars.path</name>
-    <value/>
-    <description>This an internal parameter.</description>
-  </property>
-  <property>
-    <name>hive.added.archives.path</name>
-    <value/>
-    <description>This an internal parameter.</description>
-  </property>
-  <property>
-    <name>hive.auto.progress.timeout</name>
-    <value>0s</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is sec if not specified.
-      How long to run autoprogressor for the script/UDTF operators.
-      Set to 0 for forever.
-    </description>
-  </property>
-  <property>
-    <name>hive.script.auto.progress</name>
-    <value>false</value>
-    <description>
-      Whether Hive Transform/Map/Reduce Clause should automatically send progress information to TaskTracker 
-      to avoid the task getting killed because of inactivity.  Hive sends progress information when the script is 
-      outputting to stderr.  This option removes the need of periodically producing stderr messages, 
-      but users should be cautious because this may prevent infinite loops in the scripts to be killed by TaskTracker.
-    </description>
-  </property>
-  <property>
-    <name>hive.script.operator.id.env.var</name>
-    <value>HIVE_SCRIPT_OPERATOR_ID</value>
-    <description>
-      Name of the environment variable that holds the unique script operator ID in the user's 
-      transform function (the custom mapper/reducer that the user has specified in the query)
-    </description>
-  </property>
-  <property>
-    <name>hive.script.operator.truncate.env</name>
-    <value>false</value>
-    <description>Truncate each environment variable for external script in scripts operator to 20KB (to fit system limits)</description>
-  </property>
-  <property>
-    <name>hive.script.operator.env.blacklist</name>
-    <value>hive.txn.valid.txns,hive.script.operator.env.blacklist</value>
-    <description>Comma separated list of keys from the configuration file not to convert to environment variables when envoking the script operator</description>
-  </property>
-  <property>
-    <name>hive.mapred.mode</name>
-    <value>nonstrict</value>
-    <description>
-      The mode in which the Hive operations are being performed. 
-      In strict mode, some risky queries are not allowed to run. They include:
-        Cartesian Product.
-        No partition being picked up for a query.
-        Comparing bigints and strings.
-        Comparing bigints and doubles.
-        Orderby without limit.
-    </description>
-  </property>
-  <property>
-    <name>hive.alias</name>
-    <value/>
-    <description/>
-  </property>
-  <property>
-    <name>hive.map.aggr</name>
-    <value>true</value>
-    <description>Whether to use map-side aggregation in Hive Group By queries</description>
-  </property>
-  <property>
-    <name>hive.groupby.skewindata</name>
-    <value>false</value>
-    <description>Whether there is skew in data to optimize group by queries</description>
-  </property>
-  <property>
-    <name>hive.join.emit.interval</name>
-    <value>1000</value>
-    <description>How many rows in the right-most join operand Hive should buffer before emitting the join result.</description>
-  </property>
-  <property>
-    <name>hive.join.cache.size</name>
-    <value>25000</value>
-    <description>How many rows in the joining tables (except the streaming table) should be cached in memory.</description>
-  </property>
-  <property>
-    <name>hive.cbo.enable</name>
-    <value>true</value>
-    <description>Flag to control enabling Cost Based Optimizations using Calcite framework.</description>
-  </property>
-  <property>
-    <name>hive.cbo.returnpath.hiveop</name>
-    <value>false</value>
-    <description>Flag to control calcite plan to hive operator conversion</description>
-  </property>
-  <property>
-    <name>hive.cbo.costmodel.extended</name>
-    <value>false</value>
-    <description>Flag to control enabling the extended cost model based onCPU, IO and cardinality. Otherwise, the cost model is based on cardinality.</description>
-  </property>
-  <property>
-    <name>hive.cbo.costmodel.cpu</name>
-    <value>0.000001</value>
-    <description>Default cost of a comparison</description>
-  </property>
-  <property>
-    <name>hive.cbo.costmodel.network</name>
-    <value>150.0</value>
-    <description>Default cost of a transfering a byte over network; expressed as multiple of CPU cost</description>
-  </property>
-  <property>
-    <name>hive.cbo.costmodel.local.fs.write</name>
-    <value>4.0</value>
-    <description>Default cost of writing a byte to local FS; expressed as multiple of NETWORK cost</description>
-  </property>
-  <property>
-    <name>hive.cbo.costmodel.local.fs.read</name>
-    <value>4.0</value>
-    <description>Default cost of reading a byte from local FS; expressed as multiple of NETWORK cost</description>
-  </property>
-  <property>
-    <name>hive.cbo.costmodel.hdfs.write</name>
-    <value>10.0</value>
-    <description>Default cost of writing a byte to HDFS; expressed as multiple of Local FS write cost</description>
-  </property>
-  <property>
-    <name>hive.cbo.costmodel.hdfs.read</name>
-    <value>1.5</value>
-    <description>Default cost of reading a byte from HDFS; expressed as multiple of Local FS read cost</description>
-  </property>
-  <property>
-    <name>hive.mapjoin.bucket.cache.size</name>
-    <value>100</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.mapjoin.optimized.hashtable</name>
-    <value>true</value>
-    <description>
-      Whether Hive should use memory-optimized hash table for MapJoin. Only works on Tez,
-      because memory-optimized hashtable cannot be serialized.
-    </description>
-  </property>
-  <property>
-    <name>hive.mapjoin.hybridgrace.hashtable</name>
-    <value>true</value>
-    <description>Whether to use hybridgrace hash join as the join method for mapjoin. Tez only.</description>
-  </property>
-  <property>
-    <name>hive.mapjoin.hybridgrace.memcheckfrequency</name>
-    <value>1024</value>
-    <description>For hybrid grace hash join, how often (how many rows apart) we check if memory is full. This number should be power of 2.</description>
-  </property>
-  <property>
-    <name>hive.mapjoin.hybridgrace.minwbsize</name>
-    <value>524288</value>
-    <description>For hybrid grace hash join, the minimum write buffer size used by optimized hashtable. Default is 512 KB.</description>
-  </property>
-  <property>
-    <name>hive.mapjoin.hybridgrace.minnumpartitions</name>
-    <value>16</value>
-    <description>For hybrid grace hash join, the minimum number of partitions to create.</description>
-  </property>
-  <property>
-    <name>hive.mapjoin.optimized.hashtable.wbsize</name>
-    <value>10485760</value>
-    <description>
-      Optimized hashtable (see hive.mapjoin.optimized.hashtable) uses a chain of buffers to
-      store data. This is one buffer size. HT may be slightly faster if this is larger, but for small
-      joins unnecessary memory will be allocated and then trimmed.
-    </description>
-  </property>
-  <property>
-    <name>hive.smbjoin.cache.rows</name>
-    <value>10000</value>
-    <description>How many rows with the same key value should be cached in memory per smb joined table.</description>
-  </property>
-  <property>
-    <name>hive.groupby.mapaggr.checkinterval</name>
-    <value>100000</value>
-    <description>Number of rows after which size of the grouping keys/aggregation classes is performed</description>
-  </property>
-  <property>
-    <name>hive.map.aggr.hash.percentmemory</name>
-    <value>0.5</value>
-    <description>Portion of total memory to be used by map-side group aggregation hash table</description>
-  </property>
-  <property>
-    <name>hive.mapjoin.followby.map.aggr.hash.percentmemory</name>
-    <value>0.3</value>
-    <description>Portion of total memory to be used by map-side group aggregation hash table, when this group by is followed by map join</description>
-  </property>
-  <property>
-    <name>hive.map.aggr.hash.force.flush.memory.threshold</name>
-    <value>0.9</value>
-    <description>
-      The max memory to be used by map-side group aggregation hash table.
-      If the memory usage is higher than this number, force to flush data
-    </description>
-  </property>
-  <property>
-    <name>hive.map.aggr.hash.min.reduction</name>
-    <value>0.5</value>
-    <description>
-      Hash aggregation will be turned off if the ratio between hash  table size and input rows is bigger than this number. 
-      Set to 1 to make sure hash aggregation is never turned off.
-    </description>
-  </property>
-  <property>
-    <name>hive.multigroupby.singlereducer</name>
-    <value>true</value>
-    <description>
-      Whether to optimize multi group by query to generate single M/R  job plan. If the multi group by query has 
-      common group by keys, it will be optimized to generate single M/R job.
-    </description>
-  </property>
-  <property>
-    <name>hive.map.groupby.sorted</name>
-    <value>false</value>
-    <description>
-      If the bucketing/sorting properties of the table exactly match the grouping key, whether to perform 
-      the group by in the mapper by using BucketizedHiveInputFormat. The only downside to this
-      is that it limits the number of mappers to the number of files.
-    </description>
-  </property>
-  <property>
-    <name>hive.map.groupby.sorted.testmode</name>
-    <value>false</value>
-    <description>
-      If the bucketing/sorting properties of the table exactly match the grouping key, whether to perform 
-      the group by in the mapper by using BucketizedHiveInputFormat. If the test mode is set, the plan
-      is not converted, but a query property is set to denote the same.
-    </description>
-  </property>
-  <property>
-    <name>hive.groupby.orderby.position.alias</name>
-    <value>false</value>
-    <description>Whether to enable using Column Position Alias in Group By or Order By</description>
-  </property>
-  <property>
-    <name>hive.new.job.grouping.set.cardinality</name>
-    <value>30</value>
-    <description>
-      Whether a new map-reduce job should be launched for grouping sets/rollups/cubes.
-      For a query like: select a, b, c, count(1) from T group by a, b, c with rollup;
-      4 rows are created per row: (a, b, c), (a, b, null), (a, null, null), (null, null, null).
-      This can lead to explosion across map-reduce boundary if the cardinality of T is very high,
-      and map-side aggregation does not do a very good job. 
-      
-      This parameter decides if Hive should add an additional map-reduce job. If the grouping set
-      cardinality (4 in the example above), is more than this value, a new MR job is added under the
-      assumption that the original group by will reduce the data size.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.copyfile.maxsize</name>
-    <value>33554432</value>
-    <description>Maximum file size (in Mb) that Hive uses to do single HDFS copies between directories.Distributed copies (distcp) will be used instead for bigger files so that copies can be done faster.</description>
-  </property>
-  <property>
-    <name>hive.udtf.auto.progress</name>
-    <value>false</value>
-    <description>
-      Whether Hive should automatically send progress information to TaskTracker 
-      when using UDTF's to prevent the task getting killed because of inactivity.  Users should be cautious 
-      because this may prevent TaskTracker from killing tasks with infinite loops.
-    </description>
-  </property>
-  <property>
-    <name>hive.default.fileformat</name>
-    <value>TextFile</value>
-    <description>
-      Expects one of [textfile, sequencefile, rcfile, orc].
-      Default file format for CREATE TABLE statement. Users can explicitly override it by CREATE TABLE ... STORED AS [FORMAT]
-    </description>
-  </property>
-  <property>
-    <name>hive.default.fileformat.managed</name>
-    <value>none</value>
-    <description>
-      Expects one of [none, textfile, sequencefile, rcfile, orc].
-      Default file format for CREATE TABLE statement applied to managed tables only. External tables will be 
-      created with format specified by hive.default.fileformat. Leaving this null will result in using hive.default.fileformat 
-      for all tables.
-    </description>
-  </property>
-  <property>
-    <name>hive.query.result.fileformat</name>
-    <value>TextFile</value>
-    <description>
-      Expects one of [textfile, sequencefile, rcfile].
-      Default file format for storing result of the query.
-    </description>
-  </property>
-  <property>
-    <name>hive.fileformat.check</name>
-    <value>true</value>
-    <description>Whether to check file format or not when loading data files</description>
-  </property>
-  <property>
-    <name>hive.default.rcfile.serde</name>
-    <value>org.apache.hadoop.hive.serde2.columnar.LazyBinaryColumnarSerDe</value>
-    <description>The default SerDe Hive will use for the RCFile format</description>
-  </property>
-  <property>
-    <name>hive.default.serde</name>
-    <value>org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe</value>
-    <description>The default SerDe Hive will use for storage formats that do not specify a SerDe.</description>
-  </property>
-  <property>
-    <name>hive.serdes.using.metastore.for.schema</name>
-    <value>org.apache.hadoop.hive.ql.io.orc.OrcSerde,org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe,org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe,org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe,org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe,org.apache.hadoop.hive.serde2.columnar.LazyBinaryColumnarSerDe,org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe,org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe</value>
-    <description>SerDes retriving schema from metastore. This an internal parameter. Check with the hive dev. team</description>
-  </property>
-  <property>
-    <name>hive.querylog.location</name>
-    <value>${system:java.io.tmpdir}/${system:user.name}</value>
-    <description>Location of Hive run time structured log file</description>
-  </property>
-  <property>
-    <name>hive.querylog.enable.plan.progress</name>
-    <value>true</value>
-    <description>
-      Whether to log the plan's progress every time a job's progress is checked.
-      These logs are written to the location specified by hive.querylog.location
-    </description>
-  </property>
-  <property>
-    <name>hive.querylog.plan.progress.interval</name>
-    <value>60000ms</value>
-    <description>
-      Expects a time value with unit (d/day, h/hour, m/min, s/sec, ms/msec, us/usec, ns/nsec), which is msec if not specified.
-      The interval to wait between logging the plan's progress.
-      If there is a whole number percentage change in the progress of the mappers or the reducers,
-      the progress is logged regardless of this value.
-      The actual interval will be the ceiling of (this value divided by the value of
-      hive.exec.counters.pull.interval) multiplied by the value of hive.exec.counters.pull.interval
-      I.e. if it is not divide evenly by the value of hive.exec.counters.pull.interval it will be
-      logged less frequently than specified.
-      This only has an effect if hive.querylog.enable.plan.progress is set to true.
-    </description>
-  </property>
-  <property>
-    <name>hive.script.serde</name>
-    <value>org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe</value>
-    <description>The default SerDe for transmitting input data to and reading output data from the user scripts. </description>
-  </property>
-  <property>
-    <name>hive.script.recordreader</name>
-    <value>org.apache.hadoop.hive.ql.exec.TextRecordReader</value>
-    <description>The default record reader for reading data from the user scripts. </description>
-  </property>
-  <property>
-    <name>hive.script.recordwriter</name>
-    <value>org.apache.hadoop.hive.ql.exec.TextRecordWriter</value>
-    <description>The default record writer for writing data to the user scripts. </description>
-  </property>
-  <property>
-    <name>hive.transform.escape.input</name>
-    <value>false</value>
-    <description>
-      This adds an option to escape special chars (newlines, carriage returns and
-      tabs) when they are passed to the user script. This is useful if the Hive tables
-      can contain data that contains special characters.
-    </description>
-  </property>
-  <property>
-    <name>hive.binary.record.max.length</name>
-    <value>1000</value>
-    <description>
-      Read from a binary stream and treat each hive.binary.record.max.length bytes as a record. 
-      The last record before the end of stream can have less than hive.binary.record.max.length bytes
-    </description>
-  </property>
-  <property>
-    <name>hive.hwi.listen.host</name>
-    <value>0.0.0.0</value>
-    <description>This is the host address the Hive Web Interface will listen on</description>
-  </property>
-  <property>
-    <name>hive.hwi.listen.port</name>
-    <value>9999</value>
-    <description>This is the port the Hive Web Interface will listen on</description>
-  </property>
-  <property>
-    <name>hive.hwi.war.file</name>
-    <value>${env:HWI_WAR_FILE}</value>
-    <description>This sets the path to the HWI war file, relative to ${HIVE_HOME}. </description>
-  </property>
-  <property>
-    <name>hive.mapred.local.mem</name>
-    <value>0</value>
-    <description>mapper/reducer memory in local mode</description>
-  </property>
-  <property>
-    <name>hive.mapjoin.smalltable.filesize</name>
-    <value>25000000</value>
-    <description>
-      The threshold for the input file size of the small tables; if the file size is smaller 
-      than this threshold, it will try to convert the common join into map join
-    </description>
-  </property>
-  <property>
-    <name>hive.sample.seednumber</name>
-    <value>0</value>
-    <description>A number used to percentage sampling. By changing this number, user will change the subsets of data sampled.</description>
-  </property>
-  <property>
-    <name>hive.test.mode</name>
-    <value>false</value>
-    <description>Whether Hive is running in test mode. If yes, it turns on sampling and prefixes the output tablename.</description>
-  </property>
-  <property>
-    <name>hive.test.mode.prefix</name>
-    <value>test_</value>
-    <description>In test mode, specfies prefixes for the output table</description>
-  </property>
-  <property>
-    <name>hive.test.mode.samplefreq</name>
-    <value>32</value>
-    <description>
-      In test mode, specfies sampling frequency for table, which is not bucketed,
-      For example, the following query:
-        INSERT OVERWRITE TABLE dest SELECT col1 from src
-      would be converted to
-        INSERT OVERWRITE TABLE test_dest
-        SELECT col1 from src TABLESAMPLE (BUCKET 1 out of 32 on rand(1))
-    </description>
-  </property>
-  <property>
-    <name>hive.test.mode.nosamplelist</name>
-    <value/>
-    <description>In test mode, specifies comma separated table names which would not apply sampling</description>
-  </property>
-  <property>
-    <name>hive.test.dummystats.aggregator</name>
-    <value/>
-    <description>internal variable for test</description>
-  </property>
-  <property>
-    <name>hive.test.dummystats.publisher</name>
-    <value/>
-    <description>internal variable for test</description>
-  </property>
-  <property>
-    <name>hive.test.currenttimestamp</name>
-    <value/>
-    <description>current timestamp for test</description>
-  </property>
-  <property>
-    <name>hive.merge.mapfiles</name>
-    <value>true</value>
-    <description>Merge small files at the end of a map-only job</description>
-  </property>
-  <property>
-    <name>hive.merge.mapredfiles</name>
-    <value>false</value>
-    <description>Merge small files at the end of a map-reduce job</description>
-  </property>
-  <property>
-    <name>hive.merge.tezfiles</name>
-    <value>false</value>
-    <description>Merge small files at the end of a Tez DAG</description>
-  </property>
-  <property>
-    <name>hive.merge.sparkfiles</name>
-    <value>false</value>
-    <description>Merge small files at the end of a Spark DAG Transformation</description>
-  </property>
-  <property>
-    <name>hive.merge.size.per.task</name>
-    <value>256000000</value>
-    <description>Size of merged files at the end of the job</description>
-  </property>
-  <property>
-    <name>hive.merge.smallfiles.avgsize</name>
-    <value>16000000</value>
-    <description>
-      When the average output file size of a job is less than this number, Hive will start an additional 
-      map-reduce job to merge the output files into bigger files. This is only done for map-only jobs 
-      if hive.merge.mapfiles is true, and for map-reduce jobs if hive.merge.mapredfiles is true.
-    </description>
-  </property>
-  <property>
-    <name>hive.merge.rcfile.block.level</name>
-    <value>true</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.merge.orcfile.stripe.level</name>
-    <value>true</value>
-    <description>
-      When hive.merge.mapfiles, hive.merge.mapredfiles or hive.merge.tezfiles is enabled
-      while writing a table with ORC file format, enabling this config will do stripe-level
-      fast merge for small ORC files. Note that enabling this config will not honor the
-      padding tolerance config (hive.exec.orc.block.padding.tolerance).
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.rcfile.use.explicit.header</name>
-    <value>true</value>
-    <description>
-      If this is set the header for RCFiles will simply be RCF.  If this is not
-      set the header will be that borrowed from sequence files, e.g. SEQ- followed
-      by the input and output RCFile formats.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.rcfile.use.sync.cache</name>
-    <value>true</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.io.rcfile.record.interval</name>
-    <value>2147483647</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.io.rcfile.column.number.conf</name>
-    <value>0</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.io.rcfile.tolerate.corruptions</name>
-    <value>false</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.io.rcfile.record.buffer.size</name>
-    <value>4194304</value>
-    <description/>
-  </property>
-  <property>
-    <name>parquet.memory.pool.ratio</name>
-    <value>0.5</value>
-    <description>
-      Maximum fraction of heap that can be used by Parquet file writers in one task.
-      It is for avoiding OutOfMemory error in tasks. Work with Parquet 1.6.0 and above.
-      This config parameter is defined in Parquet, so that it does not start with 'hive.'.
-    </description>
-  </property>
-  <property>
-    <name>hive.parquet.timestamp.skip.conversion</name>
-    <value>true</value>
-    <description>Current Hive implementation of parquet stores timestamps to UTC, this flag allows skipping of the conversionon reading parquet files from other tools</description>
-  </property>
-  <property>
-    <name>hive.int.timestamp.conversion.in.seconds</name>
-    <value>false</value>
-    <description>
-      Boolean/tinyint/smallint/int/bigint value is interpreted as milliseconds during the timestamp conversion.
-      Set this flag to true to interpret the value as seconds to be consistent with float/double.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.orc.memory.pool</name>
-    <value>0.5</value>
-    <description>Maximum fraction of heap that can be used by ORC file writers</description>
-  </property>
-  <property>
-    <name>hive.exec.orc.write.format</name>
-    <value/>
-    <description>
-      Define the version of the file to write. Possible values are 0.11 and 0.12.
-      If this parameter is not defined, ORC will use the run length encoding (RLE)
-      introduced in Hive 0.12. Any value other than 0.11 results in the 0.12 encoding.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.orc.default.stripe.size</name>
-    <value>67108864</value>
-    <description>Define the default ORC stripe size, in bytes.</description>
-  </property>
-  <property>
-    <name>hive.exec.orc.default.block.size</name>
-    <value>268435456</value>
-    <description>Define the default file system block size for ORC files.</description>
-  </property>
-  <property>
-    <name>hive.exec.orc.dictionary.key.size.threshold</name>
-    <value>0.8</value>
-    <description>
-      If the number of keys in a dictionary is greater than this fraction of the total number of
-      non-null rows, turn off dictionary encoding.  Use 1 to always use dictionary encoding.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.orc.default.row.index.stride</name>
-    <value>10000</value>
-    <description>
-      Define the default ORC index stride in number of rows. (Stride is the number of rows
-      an index entry represents.)
-    </description>
-  </property>
-  <property>
-    <name>hive.orc.row.index.stride.dictionary.check</name>
-    <value>true</value>
-    <description>
-      If enabled dictionary check will happen after first row index stride (default 10000 rows)
-      else dictionary check will happen before writing first stripe. In both cases, the decision
-      to use dictionary or not will be retained thereafter.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.orc.default.buffer.size</name>
-    <value>262144</value>
-    <description>Define the default ORC buffer size, in bytes.</description>
-  </property>
-  <property>
-    <name>hive.exec.orc.default.block.padding</name>
-    <value>true</value>
-    <description>Define the default block padding, which pads stripes to the HDFS block boundaries.</description>
-  </property>
-  <property>
-    <name>hive.exec.orc.block.padding.tolerance</name>
-    <value>0.05</value>
-    <description>
-      Define the tolerance for block padding as a decimal fraction of stripe size (for
-      example, the default value 0.05 is 5% of the stripe size). For the defaults of 64Mb
-      ORC stripe and 256Mb HDFS blocks, the default block padding tolerance of 5% will
-      reserve a maximum of 3.2Mb for padding within the 256Mb block. In that case, if the
-      available size within the block is more than 3.2Mb, a new smaller stripe will be
-      inserted to fit within that space. This will make sure that no stripe written will
-      cross block boundaries and cause remote reads within a node local task.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.orc.default.compress</name>
-    <value>ZLIB</value>
-    <description>Define the default compression codec for ORC file</description>
-  </property>
-  <property>
-    <name>hive.exec.orc.encoding.strategy</name>
-    <value>SPEED</value>
-    <description>
-      Expects one of [speed, compression].
-      Define the encoding strategy to use while writing data. Changing this will
-      only affect the light weight encoding for integers. This flag will not
-      change the compression level of higher level compression codec (like ZLIB).
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.orc.compression.strategy</name>
-    <value>SPEED</value>
-    <description>
-      Expects one of [speed, compression].
-      Define the compression strategy to use while writing data. 
-      This changes the compression level of higher level compression codec (like ZLIB).
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.orc.split.strategy</name>
-    <value>HYBRID</value>
-    <description>
-      Expects one of [hybrid, bi, etl].
-      This is not a user level config. BI strategy is used when the requirement is to spend less time in split generation as opposed to query execution (split generation does not read or cache file footers). ETL strategy is used when spending little more time in split generation is acceptable (split generation reads and caches file footers). HYBRID chooses between the above strategies based on heuristics.
-    </description>
-  </property>
-  <property>
-    <name>hive.orc.splits.include.file.footer</name>
-    <value>false</value>
-    <description>
-      If turned on splits generated by orc will include metadata about the stripes in the file. This
-      data is read remotely (from the client or HS2 machine) and sent to all the tasks.
-    </description>
-  </property>
-  <property>
-    <name>hive.orc.cache.stripe.details.size</name>
-    <value>10000</value>
-    <description>Cache size for keeping meta info about orc splits cached in the client.</description>
-  </property>
-  <property>
-    <name>hive.orc.compute.splits.num.threads</name>
-    <value>10</value>
-    <description>How many threads orc should use to create splits in parallel.</description>
-  </property>
-  <property>
-    <name>hive.exec.orc.skip.corrupt.data</name>
-    <value>false</value>
-    <description>
-      If ORC reader encounters corrupt data, this value will be used to determine
-      whether to skip the corrupt data or throw exception. The default behavior is to throw exception.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.orc.zerocopy</name>
-    <value>false</value>
-    <description>Use zerocopy reads with ORC. (This requires Hadoop 2.3 or later.)</description>
-  </property>
-  <property>
-    <name>hive.lazysimple.extended_boolean_literal</name>
-    <value>false</value>
-    <description>
-      LazySimpleSerde uses this property to determine if it treats 'T', 't', 'F', 'f',
-      '1', and '0' as extened, legal boolean literal, in addition to 'TRUE' and 'FALSE'.
-      The default is false, which means only 'TRUE' and 'FALSE' are treated as legal
-      boolean literal.
-    </description>
-  </property>
-  <property>
-    <name>hive.optimize.skewjoin</name>
-    <value>false</value>
-    <description>
-      Whether to enable skew join optimization. 
-      The algorithm is as follows: At runtime, detect the keys with a large skew. Instead of
-      processing those keys, store them temporarily in an HDFS directory. In a follow-up map-reduce
-      job, process those skewed keys. The same key need not be skewed for all the tables, and so,
-      the follow-up map-reduce job (for the skewed keys) would be much faster, since it would be a
-      map-join.
-    </description>
-  </property>
-  <property>
-    <name>hive.auto.convert.join</name>
-    <value>true</value>
-    <description>Whether Hive enables the optimization about converting common join into mapjoin based on the input file size</description>
-  </property>
-  <property>
-    <name>hive.auto.convert.join.noconditionaltask</name>
-    <value>true</value>
-    <description>
-      Whether Hive enables the optimization about converting common join into mapjoin based on the input file size. 
-      If this parameter is on, and the sum of size for n-1 of the tables/partitions for a n-way join is smaller than the
-      specified size, the join is directly converted to a mapjoin (there is no conditional task).
-    </description>
-  </property>
-  <property>
-    <name>hive.auto.convert.join.noconditionaltask.size</name>
-    <value>10000000</value>
-    <description>
-      If hive.auto.convert.join.noconditionaltask is off, this parameter does not take affect. 
-      However, if it is on, and the sum of size for n-1 of the tables/partitions for a n-way join is smaller than this size, 
-      the join is directly converted to a mapjoin(there is no conditional task). The default is 10MB
-    </description>
-  </property>
-  <property>
-    <name>hive.auto.convert.join.use.nonstaged</name>
-    <value>false</value>
-    <description>
-      For conditional joins, if input stream from a small alias can be directly applied to join operator without 
-      filtering or projection, the alias need not to be pre-staged in distributed cache via mapred local task.
-      Currently, this is not working with vectorization or tez execution engine.
-    </description>
-  </property>
-  <property>
-    <name>hive.skewjoin.key</name>
-    <value>100000</value>
-    <description>
-      Determine if we get a skew key in join. If we see more than the specified number of rows with the same key in join operator,
-      we think the key as a skew join key. 
-    </description>
-  </property>
-  <property>
-    <name>hive.skewjoin.mapjoin.map.tasks</name>
-    <value>10000</value>
-    <description>
-      Determine the number of map task used in the follow up map join job for a skew join.
-      It should be used together with hive.skewjoin.mapjoin.min.split to perform a fine grained control.
-    </description>
-  </property>
-  <property>
-    <name>hive.skewjoin.mapjoin.min.split</name>
-    <value>33554432</value>
-    <description>
-      Determine the number of map task at most used in the follow up map join job for a skew join by specifying 
-      the minimum split size. It should be used together with hive.skewjoin.mapjoin.map.tasks to perform a fine grained control.
-    </description>
-  </property>
-  <property>
-    <name>hive.heartbeat.interval</name>
-    <value>1000</value>
-    <description>Send a heartbeat after this interval - used by mapjoin and filter operators</description>
-  </property>
-  <property>
-    <name>hive.limit.row.max.size</name>
-    <value>100000</value>
-    <description>When trying a smaller subset of data for simple LIMIT, how much size we need to guarantee each row to have at least.</description>
-  </property>
-  <property>
-    <name>hive.limit.optimize.limit.file</name>
-    <value>10</value>
-    <description>When trying a smaller subset of data for simple LIMIT, maximum number of files we can sample.</description>
-  </property>
-  <property>
-    <name>hive.limit.optimize.enable</name>
-    <value>false</value>
-    <description>Whether to enable to optimization to trying a smaller subset of data for simple LIMIT first.</description>
-  </property>
-  <property>
-    <name>hive.limit.optimize.fetch.max</name>
-    <value>50000</value>
-    <description>
-      Maximum number of rows allowed for a smaller subset of data for simple LIMIT, if it is a fetch query. 
-      Insert queries are not restricted by this limit.
-    </description>
-  </property>
-  <property>
-    <name>hive.limit.pushdown.memory.usage</name>
-    <value>-1.0</value>
-    <description>The max memory to be used for hash in RS operator for top K selection.</description>
-  </property>
-  <property>
-    <name>hive.limit.query.max.table.partition</name>
-    <value>-1</value>
-    <description>
-      This controls how many partitions can be scanned for each partitioned table.
-      The default value "-1" means no limit.
-    </description>
-  </property>
-  <property>
-    <name>hive.hashtable.key.count.adjustment</name>
-    <value>1.0</value>
-    <description>Adjustment to mapjoin hashtable size derived from table and column statistics; the estimate of the number of keys is divided by this value. If the value is 0, statistics are not usedand hive.hashtable.initialCapacity is used instead.</description>
-  </property>
-  <property>
-    <name>hive.hashtable.initialCapacity</name>
-    <value>100000</value>
-    <description>Initial capacity of mapjoin hashtable if statistics are absent, or if hive.hashtable.stats.key.estimate.adjustment is set to 0</description>
-  </property>
-  <property>
-    <name>hive.hashtable.loadfactor</name>
-    <value>0.75</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.mapjoin.followby.gby.localtask.max.memory.usage</name>
-    <value>0.55</value>
-    <description>
-      This number means how much memory the local task can take to hold the key/value into an in-memory hash table 
-      when this map join is followed by a group by. If the local task's memory usage is more than this number, 
-      the local task will abort by itself. It means the data of the small table is too large to be held in memory.
-    </description>
-  </property>
-  <property>
-    <name>hive.mapjoin.localtask.max.memory.usage</name>
-    <value>0.9</value>
-    <description>
-      This number means how much memory the local task can take to hold the key/value into an in-memory hash table. 
-      If the local task's memory usage is more than this number, the local task will abort by itself. 
-      It means the data of the small table is too large to be held in memory.
-    </description>
-  </property>
-  <property>
-    <name>hive.mapjoin.check.memory.rows</name>
-    <value>100000</value>
-    <description>The number means after how many rows processed it needs to check the memory usage</description>
-  </property>
-  <property>
-    <name>hive.debug.localtask</name>
-    <value>false</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.input.format</name>
-    <value>org.apache.hadoop.hive.ql.io.CombineHiveInputFormat</value>
-    <description>The default input format. Set this to HiveInputFormat if you encounter problems with CombineHiveInputFormat.</description>
-  </property>
-  <property>
-    <name>hive.tez.input.format</name>
-    <value>org.apache.hadoop.hive.ql.io.HiveInputFormat</value>
-    <description>The default input format for tez. Tez groups splits in the AM.</description>
-  </property>
-  <property>
-    <name>hive.tez.container.size</name>
-    <value>-1</value>
-    <description>By default Tez will spawn containers of the size of a mapper. This can be used to overwrite.</description>
-  </property>
-  <property>
-    <name>hive.tez.cpu.vcores</name>
-    <value>-1</value>
-    <description>
-      By default Tez will ask for however many cpus map-reduce is configured to use per container.
-      This can be used to overwrite.
-    </description>
-  </property>
-  <property>
-    <name>hive.tez.java.opts</name>
-    <value/>
-    <description>By default Tez will use the Java options from map tasks. This can be used to overwrite.</description>
-  </property>
-  <property>
-    <name>hive.tez.log.level</name>
-    <value>INFO</value>
-    <description>
-      The log level to use for tasks executing as part of the DAG.
-      Used only if hive.tez.java.opts is used to configure Java options.
-    </description>
-  </property>
-  <property>
-    <name>hive.enforce.bucketing</name>
-    <value>false</value>
-    <description>Whether bucketing is enforced. If true, while inserting into the table, bucketing is enforced.</description>
-  </property>
-  <property>
-    <name>hive.enforce.sorting</name>
-    <value>false</value>
-    <description>Whether sorting is enforced. If true, while inserting into the table, sorting is enforced.</description>
-  </property>
-  <property>
-    <name>hive.optimize.bucketingsorting</name>
-    <value>true</value>
-    <description>
-      If hive.enforce.bucketing or hive.enforce.sorting is true, don't create a reducer for enforcing 
-      bucketing/sorting for queries of the form: 
-      insert overwrite table T2 select * from T1;
-      where T1 and T2 are bucketed/sorted by the same keys into the same number of buckets.
-    </description>
-  </property>
-  <property>
-    <name>hive.mapred.partitioner</name>
-    <value>org.apache.hadoop.hive.ql.io.DefaultHivePartitioner</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.enforce.sortmergebucketmapjoin</name>
-    <value>false</value>
-    <description>If the user asked for sort-merge bucketed map-side join, and it cannot be performed, should the query fail or not ?</description>
-  </property>
-  <property>
-    <name>hive.enforce.bucketmapjoin</name>
-    <value>false</value>
-    <description>
-      If the user asked for bucketed map-side join, and it cannot be performed, 
-      should the query fail or not ? For example, if the buckets in the tables being joined are
-      not a multiple of each other, bucketed map-side join cannot be performed, and the
-      query will fail if hive.enforce.bucketmapjoin is set to true.
-    </description>
-  </property>
-  <property>
-    <name>hive.auto.convert.sortmerge.join</name>
-    <value>false</value>
-    <description>Will the join be automatically converted to a sort-merge join, if the joined tables pass the criteria for sort-merge join.</description>
-  </property>
-  <property>
-    <name>hive.auto.convert.sortmerge.join.bigtable.selection.policy</name>
-    <value>org.apache.hadoop.hive.ql.optimizer.AvgPartitionSizeBasedBigTableSelectorForAutoSMJ</value>
-    <description>
-      The policy to choose the big table for automatic conversion to sort-merge join. 
-      By default, the table with the largest partitions is assigned the big table. All policies are:
-      . based on position of the table - the leftmost table is selected
-      org.apache.hadoop.hive.ql.optimizer.LeftmostBigTableSMJ.
-      . based on total size (all the partitions selected in the query) of the table 
-      org.apache.hadoop.hive.ql.optimizer.TableSizeBasedBigTableSelectorForAutoSMJ.
-      . based on average size (all the partitions selected in the query) of the table 
-      org.apache.hadoop.hive.ql.optimizer.AvgPartitionSizeBasedBigTableSelectorForAutoSMJ.
-      New policies can be added in future.
-    </description>
-  </property>
-  <property>
-    <name>hive.auto.convert.sortmerge.join.to.mapjoin</name>
-    <value>false</value>
-    <description>
-      If hive.auto.convert.sortmerge.join is set to true, and a join was converted to a sort-merge join, 
-      this parameter decides whether each table should be tried as a big table, and effectively a map-join should be
-      tried. That would create a conditional task with n+1 children for a n-way join (1 child for each table as the
-      big table), and the backup task will be the sort-merge join. In some cases, a map-join would be faster than a
-      sort-merge join, if there is no advantage of having the output bucketed and sorted. For example, if a very big sorted
-      and bucketed table with few files (say 10 files) are being joined with a very small sorter and bucketed table
-      with few files (10 files), the sort-merge join will only use 10 mappers, and a simple map-only join might be faster
-      if the complete small table can fit in memory, and a map-join can be performed.
-    </description>
-  </property>
-  <property>
-    <name>hive.exec.script.trust</name>
-    <value>false</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.exec.rowoffset</name>
-    <value>false</value>
-    <description>Whether to provide the row offset virtual column</description>
-  </property>
-  <property>
-    <name>hive.hadoop.supports.splittable.combineinputformat</name>
-    <value>false</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.optimize.index.filter</name>
-    <value>false</value>
-    <description>Whether to enable automatic use of indexes</description>
-  </property>
-  <property>
-    <name>hive.optimize.index.autoupdate</name>
-    <value>false</value>
-    <description>Whether to update stale indexes automatically</description>
-  </property>
-  <property>
-    <name>hive.optimize.ppd</name>
-    <value>true</value>
-    <description>Whether to enable predicate pushdown</description>
-  </property>
-  <property>
-    <name>hive.ppd.recognizetransivity</name>
-    <value>true</value>
-    <description>Whether to transitively replicate predicate filters over equijoin conditions.</description>
-  </property>
-  <property>
-    <name>hive.ppd.remove.duplicatefilters</name>
-    <value>true</value>
-    <description>Whether to push predicates down into storage handlers.  Ignored when hive.optimize.ppd is false.</description>
-  </property>
-  <property>
-    <name>hive.optimize.constant.propagation</name>
-    <value>true</value>
-    <description>Whether to enable constant propagation optimizer</description>
-  </property>
-  <property>
-    <name>hive.optimize.remove.identity.project</name>
-    <value>true</value>
-    <description>Removes identity project from operator tree</description>
-  </property>
-  <property>
-    <name>hive.optimize.metadataonly</name>
-    <value>true</value>
-    <description/>
-  </property>
-  <property>
-    <name>hive.optimize.null.scan</name>
-    <value>true</value>
-    <description>Dont scan relations which are guaranteed to not generate any rows</description>
-  </property>
-  <property>
-    <name>hive.optimize.ppd.storage</name>
-    <value>true</value>
-    <description>Whether to push predicates down to storage handlers</description>
-  </property>
-  <property>
-    <name>hive.optimize.groupby</name>
-    <value>true</value>
-    <description>Whether to enable the bucketed group by from bucketed partitions/tables.</descript

<TRUNCATED>