You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tajo.apache.org by hy...@apache.org on 2016/05/20 22:19:37 UTC

svn commit: r1744805 [1/6] - in /tajo/site/docs/devel: ./ _sources/ _sources/configuration/ _sources/functions/ _sources/storage_plugins/ _static/ backup_and_restore/ configuration/ functions/ index/ partitioning/ sql_language/ storage_plugins/ table_m...

Author: hyunsik
Date: Fri May 20 22:19:36 2016
New Revision: 1744805

URL: http://svn.apache.org/viewvc?rev=1744805&view=rev
Log:
Update devel documentation by TAJO-2027

Added:
    tajo/site/docs/devel/_sources/configuration/pullserver_configuration.txt
    tajo/site/docs/devel/_sources/functions/hivefunc.txt
    tajo/site/docs/devel/configuration/pullserver_configuration.html
    tajo/site/docs/devel/functions/hivefunc.html
Modified:
    tajo/site/docs/devel/_sources/configuration.txt
    tajo/site/docs/devel/_sources/configuration/cluster_setup.txt
    tajo/site/docs/devel/_sources/configuration/service_config_defaults.txt
    tajo/site/docs/devel/_sources/functions.txt
    tajo/site/docs/devel/_sources/jdbc_driver.txt
    tajo/site/docs/devel/_sources/storage_plugins/postgresql.txt
    tajo/site/docs/devel/_sources/time_zone.txt
    tajo/site/docs/devel/_static/basic.css
    tajo/site/docs/devel/_static/doctools.js
    tajo/site/docs/devel/_static/searchtools.js
    tajo/site/docs/devel/_static/websupport.js
    tajo/site/docs/devel/backup_and_restore.html
    tajo/site/docs/devel/backup_and_restore/catalog.html
    tajo/site/docs/devel/configuration.html
    tajo/site/docs/devel/configuration/catalog-site-xml.html
    tajo/site/docs/devel/configuration/catalog_configuration.html
    tajo/site/docs/devel/configuration/cluster_setup.html
    tajo/site/docs/devel/configuration/ha_configuration.html
    tajo/site/docs/devel/configuration/preliminary.html
    tajo/site/docs/devel/configuration/service_config_defaults.html
    tajo/site/docs/devel/configuration/storage-site-json.html
    tajo/site/docs/devel/configuration/tajo-site-xml.html
    tajo/site/docs/devel/configuration/tajo_master_configuration.html
    tajo/site/docs/devel/configuration/worker_configuration.html
    tajo/site/docs/devel/faq.html
    tajo/site/docs/devel/functions.html
    tajo/site/docs/devel/functions/agg_func.html
    tajo/site/docs/devel/functions/data_type_func_and_operators.html
    tajo/site/docs/devel/functions/datetime_func_and_operators.html
    tajo/site/docs/devel/functions/json_func.html
    tajo/site/docs/devel/functions/math_func_and_operators.html
    tajo/site/docs/devel/functions/network_func_and_operators.html
    tajo/site/docs/devel/functions/python.html
    tajo/site/docs/devel/functions/string_func_and_operators.html
    tajo/site/docs/devel/functions/window_func.html
    tajo/site/docs/devel/genindex.html
    tajo/site/docs/devel/getting_started.html
    tajo/site/docs/devel/hbase_integration.html
    tajo/site/docs/devel/hive_integration.html
    tajo/site/docs/devel/index.html
    tajo/site/docs/devel/index/future_work.html
    tajo/site/docs/devel/index/how_to_use.html
    tajo/site/docs/devel/index/types.html
    tajo/site/docs/devel/index_overview.html
    tajo/site/docs/devel/introduction.html
    tajo/site/docs/devel/jdbc_driver.html
    tajo/site/docs/devel/objects.inv
    tajo/site/docs/devel/partitioning/column_partitioning.html
    tajo/site/docs/devel/partitioning/hash_partitioning.html
    tajo/site/docs/devel/partitioning/intro_to_partitioning.html
    tajo/site/docs/devel/partitioning/range_partitioning.html
    tajo/site/docs/devel/search.html
    tajo/site/docs/devel/searchindex.js
    tajo/site/docs/devel/sql_language.html
    tajo/site/docs/devel/sql_language/alter_table.html
    tajo/site/docs/devel/sql_language/data_model.html
    tajo/site/docs/devel/sql_language/ddl.html
    tajo/site/docs/devel/sql_language/explain.html
    tajo/site/docs/devel/sql_language/insert.html
    tajo/site/docs/devel/sql_language/joins.html
    tajo/site/docs/devel/sql_language/predicates.html
    tajo/site/docs/devel/sql_language/queries.html
    tajo/site/docs/devel/sql_language/sql_expression.html
    tajo/site/docs/devel/storage_plugins.html
    tajo/site/docs/devel/storage_plugins/overview.html
    tajo/site/docs/devel/storage_plugins/postgresql.html
    tajo/site/docs/devel/swift_integration.html
    tajo/site/docs/devel/table_management.html
    tajo/site/docs/devel/table_management/compression.html
    tajo/site/docs/devel/table_management/data_formats.html
    tajo/site/docs/devel/table_management/json.html
    tajo/site/docs/devel/table_management/orc.html
    tajo/site/docs/devel/table_management/parquet.html
    tajo/site/docs/devel/table_management/rcfile.html
    tajo/site/docs/devel/table_management/sequencefile.html
    tajo/site/docs/devel/table_management/table_overview.html
    tajo/site/docs/devel/table_management/tablespaces.html
    tajo/site/docs/devel/table_management/text.html
    tajo/site/docs/devel/table_partitioning.html
    tajo/site/docs/devel/tajo_client_api.html
    tajo/site/docs/devel/time_zone.html
    tajo/site/docs/devel/tsql.html
    tajo/site/docs/devel/tsql/admin_command.html
    tajo/site/docs/devel/tsql/background_command.html
    tajo/site/docs/devel/tsql/dfs_command.html
    tajo/site/docs/devel/tsql/execute_file.html
    tajo/site/docs/devel/tsql/intro.html
    tajo/site/docs/devel/tsql/meta_command.html
    tajo/site/docs/devel/tsql/single_command.html
    tajo/site/docs/devel/tsql/variables.html

Modified: tajo/site/docs/devel/_sources/configuration.txt
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_sources/configuration.txt?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_sources/configuration.txt (original)
+++ tajo/site/docs/devel/_sources/configuration.txt Fri May 20 22:19:36 2016
@@ -10,6 +10,7 @@ Configuration
     configuration/tajo_master_configuration
     configuration/worker_configuration
     configuration/catalog_configuration
+    configuration/pullserver_configuration
     configuration/ha_configuration
     configuration/service_config_defaults
     configuration/tajo-site-xml

Modified: tajo/site/docs/devel/_sources/configuration/cluster_setup.txt
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_sources/configuration/cluster_setup.txt?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_sources/configuration/cluster_setup.txt (original)
+++ tajo/site/docs/devel/_sources/configuration/cluster_setup.txt Fri May 20 22:19:36 2016
@@ -1,9 +1,9 @@
-*******************************************
+*************
 Cluster Setup
-*******************************************
+*************
 
 Fully Distributed Mode
-==========================================
+======================
 A fully distributed mode enables a Tajo instance to run on `Hadoop Distributed File System (HDFS) <http://wiki.apache.org/hadoop/HDFS>`_. In this mode, a number of Tajo workers run across a number of the physical nodes where HDFS data nodes run.
 
 
@@ -11,7 +11,7 @@ In this section, we explain how to setup
 
 
 Settings
---------------------------------------------------------
+--------
 
 Please add the following configs to tajo-site.xml file:
 
@@ -19,31 +19,24 @@ Please add the following configs to tajo
 
   <property>
     <name>tajo.rootdir</name>
-    <value>hdfs://hostname:port/tajo</value>
+    <value>hdfs://nameservice/tajo</value>
   </property>
 
   <property>
     <name>tajo.master.umbilical-rpc.address</name>
     <value>hostname:26001</value>
+    <description>TajoMaster binding address between master and workers.</description>
   </property>
 
   <property>
     <name>tajo.master.client-rpc.address</name>
     <value>hostname:26002</value>
+    <description>TajoMaster binding address between master and remote clients.</description>
   </property>
 
-  <property>
-    <name>tajo.resource-tracker.rpc.address</name>
-    <value>hostname:26003</value>
-  </property>
-
-  <property>
-    <name>tajo.catalog.client-rpc.address</name>
-    <value>hostname:26005</value>
-  </property>
 
 Workers
---------------------------------------------------------
+-------
 
 The file ``conf/workers`` lists all host names of workers, one per line.
 By default, this file contains the single entry ``localhost``.
@@ -59,7 +52,7 @@ For example: ::
   <ctrl + d>
 
 Make base directories and set permissions
---------------------------------------------------------
+-----------------------------------------
 
 If you want to know Tajo’s configuration in more detail, see Configuration page.
 Before launching the tajo, you should create the tajo root dir and set the permission as follows: ::
@@ -69,7 +62,7 @@ Before launching the tajo, you should cr
 
 
 Launch a Tajo cluster
---------------------------------------------------------
+---------------------
 
 Then, execute ``start-tajo.sh`` ::
 
@@ -77,10 +70,10 @@ Then, execute ``start-tajo.sh`` ::
 
 .. note::
 
-  In default, each worker is set to very little resource capacity. In order to increase parallel degree, please read 
+  By default, each worker is set to very little resource capacity. In order to increase parallel degree, please read
   :doc:`/configuration/worker_configuration`.
 
 .. note::
 
-  In default, TajoMaster listens on 127.0.0.1 for clients. To allow remote clients to access TajoMaster, please set tajo.master.client-rpc.address config to tajo-site.xml. In order to know how to change the listen port, please refer :doc:`/configuration/service_config_defaults`.
+  By default, TajoMaster listens on localhost/127.0.0.1 for clients. To allow remote clients to access TajoMaster, please set tajo.master.client-rpc.address config to tajo-site.xml. In order to know how to change the listen port, please refer :doc:`/configuration/service_config_defaults`.
 

Added: tajo/site/docs/devel/_sources/configuration/pullserver_configuration.txt
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_sources/configuration/pullserver_configuration.txt?rev=1744805&view=auto
==============================================================================
--- tajo/site/docs/devel/_sources/configuration/pullserver_configuration.txt (added)
+++ tajo/site/docs/devel/_sources/configuration/pullserver_configuration.txt Fri May 20 22:19:36 2016
@@ -0,0 +1,75 @@
+*************************
+Pull Server Configuration
+*************************
+
+Pull servers are responsible for transmitting data among Tajo workers during shuffle phases. Tajo provides several modes
+for pull servers.
+
+Internal Mode (Default)
+=======================
+
+With the internal mode, each worker acts as a pull server. So, they need to transmit data during shuffle phase as well
+as processing them during processing phase.
+
+Standalone Mode
+===============
+
+Sometimes, data shuffling requires huge memory space and a lot of cpu processing.
+This can make query processing slow because Tajo's query engine should contend for limited resources with pull servers.
+Tajo provides the standalone mode to avoid this unnecessary contention.
+
+In this mode, each pull server is executed as a separate process. To enable this mode, you need to add the following
+line to ``${TAJO_HOME}/conf/tajo-env.sh``.
+
+.. code-block:: sh
+
+  export TAJO_PULLSERVER_STANDALONE=true
+
+Then, you can see the following messages when you start up the tajo cluster.
+
+.. code-block:: sh
+
+  Starting single TajoMaster
+  starting master, logging to ...
+  192.168.10.1: starting pullserver, logging to ...
+  192.168.10.1: starting worker, logging to ...
+  192.168.10.2: starting pullserver, logging to ...
+  192.168.10.2: starting worker, logging to ...
+  ...
+
+.. warning::
+
+  Currently, only one single server should be run in each machine.
+
+Yarn Auxiliary Service Mode
+===========================
+
+You can run pull servers as one of Yarn's auxiliary services. To do so, you need to add the following configurations
+to ``${HADOOP_CONF}/yarn-site.xml``.
+
+.. code-block:: xml
+
+  <property>
+    <name>yarn.nodemanager.aux-services</name>
+    <value>mapreduce_shuffle,tajo_shuffle</value>
+  </property>
+
+  <property>
+    <name>yarn.nodemanager.aux-services.tajo_shuffle.class</name>
+    <value>org.apache.tajo.yarn.TajoPullServerService</value>
+  </property>
+
+  <property>
+    <name>tajo.pullserver.port</name>
+    <value>port number</value>
+  </property>
+
+Optionally, you can add the below configuration to specify temp directories. For this configuration,
+please refer to :doc:`/configuration/worker_configuration`.
+
+.. code-block:: xml
+
+  <property>
+    <name>tajo.worker.tmpdir.locations</name>
+    <value>/path/to/tajo/temporal/directory</value>
+  </property>
\ No newline at end of file

Modified: tajo/site/docs/devel/_sources/configuration/service_config_defaults.txt
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_sources/configuration/service_config_defaults.txt?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_sources/configuration/service_config_defaults.txt (original)
+++ tajo/site/docs/devel/_sources/configuration/service_config_defaults.txt Fri May 20 22:19:36 2016
@@ -5,24 +5,24 @@ Cluster Service Configuration Defaults
 Tajo Master Configuration Defaults
 ====================================
 
-============================  ==============================================================  ===========   ===============  
-  Service Name                Config Property Name                                            Description   default address 
-============================  ==============================================================  ===========   ===============  
-Tajo Master Umbilical Rpc     tajo.master.umbilical-rpc.address                                             localhost:26001 
-Tajo Master Client Rpc        tajo.master.client-rpc.address                                                localhost:26002 
-Tajo Master Info Http         tajo.master.info-http.address                                                 0.0.0.0:26080
-Tajo Resource Tracker Rpc     tajo.resource-tracker.rpc.address                                             localhost:26003
-Tajo Catalog Client Rpc       tajo.catalog.client-rpc.address                                               localhost:26005
-============================  ==============================================================  ===========   ===============  
+============================  ====================================  ===============  =================================================================
+  Service Name                Config Property Name                  default address  Description
+============================  ====================================  ===============  =================================================================
+Tajo Master Umbilical Rpc     tajo.master.umbilical-rpc.address     localhost:26001  TajoMaster binding address between master and workers.
+Tajo Master Client Rpc        tajo.master.client-rpc.address        localhost:26002  TajoMaster binding address between master and remote clients.
+Tajo Master Info Http         tajo.master.info-http.address         0.0.0.0:26080    TajoMaster binding address between master and web browser.
+Tajo Resource Tracker Rpc     tajo.resource-tracker.rpc.address     0.0.0.0:26003    TajoMaster binding address between master and workers.
+Tajo Catalog Client Rpc       tajo.catalog.client-rpc.address       0.0.0.0:26005    CatalogServer binding address between catalog server and workers.
+============================  ====================================  ===============  =================================================================
 
 ====================================
 Tajo Worker Configuration Defaults
 ====================================
 
-============================  ==============================================================  ===========   ===============  
-  Service Name                Config Property Name                                            Description   default address 
-============================  ==============================================================  ===========   ===============  
-Tajo Worker Peer Rpc          tajo.worker.peer-rpc.address                                                  0.0.0.0:28091   
-Tajo Worker Client Rpc        tajo.worker.client-rpc.address                                                0.0.0.0:28092   
-Tajo Worker Info Http         tajo.worker.info-http.address                                                 0.0.0.0:28080   
-============================  ==============================================================  ===========   ===============  
\ No newline at end of file
+============================  ====================================  ===============  =================================================================
+  Service Name                Config Property Name                  default address  Description
+============================  ====================================  ===============  =================================================================
+Tajo Worker Peer Rpc          tajo.worker.peer-rpc.address          0.0.0.0:28091    TajoWorker binding address between worker and master.
+Tajo Worker Client Rpc        tajo.worker.client-rpc.address        0.0.0.0:28092    TajoWorker binding address between worker and remote clients.
+Tajo Worker Info Http         tajo.worker.info-http.address         0.0.0.0:28080    TajoWorker binding address between master and web browser.
+============================  ====================================  ===============  =================================================================
\ No newline at end of file

Modified: tajo/site/docs/devel/_sources/functions.txt
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_sources/functions.txt?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_sources/functions.txt (original)
+++ tajo/site/docs/devel/_sources/functions.txt Fri May 20 22:19:36 2016
@@ -1,12 +1,12 @@
-******************
+*********
 Functions
-******************
+*********
 
 Tajo provides extensive supports for functions. It includes a lot of built-in functions and user-defined functions which is implemented in Python.
 
-==========================
+=========================
 Built-in Scalar Functions
-==========================
+=========================
 
 .. toctree::
     :maxdepth: 1
@@ -18,29 +18,30 @@ Built-in Scalar Functions
     functions/network_func_and_operators
     functions/json_func
 
-================================
+==============================
 Built-in Aggregation Functions
-================================
+==============================
 
 .. toctree::
     :maxdepth: 1
 
     functions/agg_func
 
-================================
+=========================
 Built-in Window Functions
-================================
+=========================
 
 .. toctree::
     :maxdepth: 1
 
     functions/window_func
 
-==============================
+======================
 User-defined Functions
-==============================
+======================
 
 .. toctree::
     :maxdepth: 1
 
-    functions/python
\ No newline at end of file
+    functions/python
+    functions/hivefunc

Added: tajo/site/docs/devel/_sources/functions/hivefunc.txt
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_sources/functions/hivefunc.txt?rev=1744805&view=auto
==============================================================================
--- tajo/site/docs/devel/_sources/functions/hivefunc.txt (added)
+++ tajo/site/docs/devel/_sources/functions/hivefunc.txt Fri May 20 22:19:36 2016
@@ -0,0 +1,80 @@
+##############
+Hive Functions
+##############
+
+Tajo provides a feature to use Hive functions directly without re-compilation or additional code.
+
+*************
+Configuration
+*************
+
+Only thing to do is registering path to a directory for jar files containing your hive functions.
+You can do this by set ``tajo.function.hive.jar-dir`` in ``tajo-site.xml`` like the following.
+
+.. code-block:: xml
+
+  <property>
+    <name>tajo.function.hive.jar-dir</name>
+    <value>/path/to/hive/function/jar</value>
+  </property>
+
+.. note::
+  The path should be one in local filesystem. HDFS directory is not supported because of JAVA URI compatability problem.
+
+.. warning::
+
+  The path must point to a directory, not a file. And multiple directory entries are not allowed.
+  However, it is possible to load multiple jar files.
+
+***************
+Using in detail
+***************
+
+=============
+Function Name
+=============
+
+Tajo reads hive functions override ``org.apache.hadoop.hive.ql.exec.UDF`` class. Function name is used as specified in
+``@Description`` annotation. If it doesn't exist, Tajo uses full qualified class name as function name. For example,
+it can be like this : ``select com_example_hive_udf_myupper('abcd')``, so it is recommended to use Description annotation.
+
+Additionally if some function signature duplicate occurs, it may throw ``AmbiguousFunctionException``.
+
+============================
+Parameter type / Return type
+============================
+
+Hive uses *Writable* type of Hadoop in functions, but Tajo uses its internal *Datum* type.
+So only some Writable types are supported currently by internal converting.
+They are listed below.
+
+==================== =========
+Writable             Tajo Type
+==================== =========
+ByteWritable         INT1
+ShortWritable        INT2
+IntWritable          INT4
+LongWritable         INT8
+FloatWritable        FLOAT4
+DoubleWritable       FLOAT8
+Text                 TEXT
+BytesWritable        VARBINARY
+DateWritable(*)      DATE
+TimestampWritable(*) TIMESTAMP
+HiveCharWritable(*)  CHAR
+==================== =========
+
+.. note::
+
+  (*) They are in org.apache.hadoop.hive.serde2.io package, others are in org.apache.hadoop.io package.
+
+==========
+Limitation
+==========
+
+1. Currently, Hive UDAF is not supported. Old UDAF interface is deprecated in Hive,
+and new GenericUDAF interface cannot be applied because of function design difference between Tajo and Hive.
+For same reason, new GenericUDF functions are not supported in Tajo.
+
+2. Because HDFS directory is not supported, Hive UDF jar files should be copied to each worker directory and each path
+should be specified in tajo-site.xml.

Modified: tajo/site/docs/devel/_sources/jdbc_driver.txt
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_sources/jdbc_driver.txt?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_sources/jdbc_driver.txt (original)
+++ tajo/site/docs/devel/_sources/jdbc_driver.txt Fri May 20 22:19:36 2016
@@ -83,6 +83,7 @@ The connection parameters that Tajo curr
  * ``connectTimeout = int (seconds)`` - The timeout value used for socket connect operations. If connecting to the server takes longer than this value, the connection is broken. The timeout is specified in seconds and a value of zero means that it is disabled.
  * ``socketTimeout = int (seconds)`` - The timeout value used for socket read operations. If reading from the server takes longer than this value, the connection is closed. This can be used as both a brute force global query timeout and a method of detecting network problems. The timeout is specified in seconds and a value of zero means that it is disabled.
  * ``retry = int`` - Number of retry operation. Tajo JDBC driver is resilient against some network or connection problems. It determines how many times the connection will retry.
+ * ``timezone = string (timezone id e,g, 'Asia/Tokyo')`` - Each connection has its own client time zone setting.
 
 
 An Example JDBC Client

Modified: tajo/site/docs/devel/_sources/storage_plugins/postgresql.txt
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_sources/storage_plugins/postgresql.txt?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_sources/storage_plugins/postgresql.txt (original)
+++ tajo/site/docs/devel/_sources/storage_plugins/postgresql.txt Fri May 20 22:19:36 2016
@@ -17,10 +17,9 @@ PostgreSQL storage handler is a builtin
   {
     "spaces": {
       "pgsql_db1": {
-        "uri": "jdbc:postgresql://hostname:port/db1"
-        
+        "uri": "jdbc:postgresql://hostname:port/db1",
         "configs": {
-          "mapped_database": "tajo_db1"
+          "mapped_database": "tajo_db1",
           "connection_properties": {
             "user":     "tajo",
             "password": "xxxx"

Modified: tajo/site/docs/devel/_sources/time_zone.txt
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_sources/time_zone.txt?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_sources/time_zone.txt (original)
+++ tajo/site/docs/devel/_sources/time_zone.txt Fri May 20 22:19:36 2016
@@ -2,7 +2,7 @@
 Time Zone
 ******************
 
-Time zone affects some data types (e.g., ``Timestamp`` and ``Time``) and operations (e.g., ``to_char``). Tables can have different time zones. Internally, Tajo translates all table rows to UTC values and processes them. It becomes easier for Tajo to handle multiple different time zones.
+Time zone affects ``Timestamp`` data type and operations (e.g., ``to_char``). Tables can have different time zones. Internally, Tajo translates all table rows to UTC values and processes them. It becomes easier for Tajo to handle multiple different time zones.
 
 In Tajo, there are some time zong settings.
 
@@ -27,7 +27,7 @@ Table Time Zone
 ==================
 
 In Tajo, a table property ``timezone`` allows users to specify a time zone that the table uses for reading or writing. 
-When each table row are read or written, ```timestamp``` and ```time``` column values are adjusted by a given time zone if it is set.
+When each table row are read or written, ```timestamp``` column values are adjusted by a given time zone if it is set.
 
 You can specify a table time zone as follows:
 

Modified: tajo/site/docs/devel/_static/basic.css
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_static/basic.css?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_static/basic.css (original)
+++ tajo/site/docs/devel/_static/basic.css Fri May 20 22:19:36 2016
@@ -4,7 +4,7 @@
  *
  * Sphinx stylesheet -- basic theme.
  *
- * :copyright: Copyright 2007-2016 by the Sphinx team, see AUTHORS.
+ * :copyright: Copyright 2007-2015 by the Sphinx team, see AUTHORS.
  * :license: BSD, see LICENSE for details.
  *
  */
@@ -52,8 +52,6 @@ div.sphinxsidebar {
     width: 230px;
     margin-left: -100%;
     font-size: 90%;
-    word-wrap: break-word;
-    overflow-wrap : break-word;
 }
 
 div.sphinxsidebar ul {
@@ -189,13 +187,6 @@ div.genindex-jumpbox {
 
 /* -- general body styles --------------------------------------------------- */
 
-div.body p, div.body dd, div.body li, div.body blockquote {
-    -moz-hyphens: auto;
-    -ms-hyphens: auto;
-    -webkit-hyphens: auto;
-    hyphens: auto;
-}
-
 a.headerlink {
     visibility: hidden;
 }

Modified: tajo/site/docs/devel/_static/doctools.js
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_static/doctools.js?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_static/doctools.js (original)
+++ tajo/site/docs/devel/_static/doctools.js Fri May 20 22:19:36 2016
@@ -4,7 +4,7 @@
  *
  * Sphinx JavaScript utilities for all documentation.
  *
- * :copyright: Copyright 2007-2016 by the Sphinx team, see AUTHORS.
+ * :copyright: Copyright 2007-2015 by the Sphinx team, see AUTHORS.
  * :license: BSD, see LICENSE for details.
  *
  */
@@ -124,7 +124,6 @@ var Documentation = {
     this.fixFirefoxAnchorBug();
     this.highlightSearchWords();
     this.initIndexTable();
-    
   },
 
   /**
@@ -253,29 +252,6 @@ var Documentation = {
     });
     var url = parts.join('/');
     return path.substring(url.lastIndexOf('/') + 1, path.length - 1);
-  },
-
-  initOnKeyListeners: function() {
-    $(document).keyup(function(event) {
-      var activeElementType = document.activeElement.tagName;
-      // don't navigate when in search box or textarea
-      if (activeElementType !== 'TEXTAREA' && activeElementType !== 'INPUT' && activeElementType !== 'SELECT') {
-        switch (event.keyCode) {
-          case 37: // left
-            var prevHref = $('link[rel="prev"]').prop('href');
-            if (prevHref) {
-              window.location.href = prevHref;
-              return false;
-            }
-          case 39: // right
-            var nextHref = $('link[rel="next"]').prop('href');
-            if (nextHref) {
-              window.location.href = nextHref;
-              return false;
-            }
-        }
-      }
-    });
   }
 };
 
@@ -284,4 +260,4 @@ _ = Documentation.gettext;
 
 $(document).ready(function() {
   Documentation.init();
-});
\ No newline at end of file
+});

Modified: tajo/site/docs/devel/_static/searchtools.js
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_static/searchtools.js?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_static/searchtools.js (original)
+++ tajo/site/docs/devel/_static/searchtools.js Fri May 20 22:19:36 2016
@@ -2,15 +2,14 @@
  * searchtools.js_t
  * ~~~~~~~~~~~~~~~~
  *
- * Sphinx JavaScript utilities for the full-text search.
+ * Sphinx JavaScript utilties for the full-text search.
  *
- * :copyright: Copyright 2007-2016 by the Sphinx team, see AUTHORS.
+ * :copyright: Copyright 2007-2015 by the Sphinx team, see AUTHORS.
  * :license: BSD, see LICENSE for details.
  *
  */
 
 
-/* Non-minified version JS is _stemmer.js if file is provided */ 
 /**
  * Porter Stemmer
  */
@@ -374,7 +373,8 @@ var Search = {
     }
 
     // lookup as search terms in fulltext
-    results = results.concat(this.performTermsSearch(searchterms, excluded, terms, titleterms));
+    results = results.concat(this.performTermsSearch(searchterms, excluded, terms, Scorer.term))
+                     .concat(this.performTermsSearch(searchterms, excluded, titleterms, Scorer.title));
 
     // let the scorer override scores with a custom scoring function
     if (Scorer.score) {
@@ -538,47 +538,23 @@ var Search = {
   /**
    * search for full-text terms in the index
    */
-  performTermsSearch : function(searchterms, excluded, terms, titleterms) {
+  performTermsSearch : function(searchterms, excluded, terms, score) {
     var filenames = this._index.filenames;
     var titles = this._index.titles;
 
-    var i, j, file;
+    var i, j, file, files;
     var fileMap = {};
-    var scoreMap = {};
     var results = [];
 
     // perform the search on the required terms
     for (i = 0; i < searchterms.length; i++) {
       var word = searchterms[i];
-      var files = [];
-      var _o = [
-        {files: terms[word], score: Scorer.term},
-        {files: titleterms[word], score: Scorer.title}
-      ];
-
       // no match but word was a required one
-      if ($u.every(_o, function(o){return o.files === undefined;})) {
+      if ((files = terms[word]) === undefined)
         break;
+      if (files.length === undefined) {
+        files = [files];
       }
-      // found search word in contents
-      $u.each(_o, function(o) {
-        var _files = o.files;
-        if (_files === undefined)
-          return
-
-        if (_files.length === undefined)
-          _files = [_files];
-        files = files.concat(_files);
-
-        // set score for the word in each file to Scorer.term
-        for (j = 0; j < _files.length; j++) {
-          file = _files[j];
-          if (!(file in scoreMap))
-            scoreMap[file] = {}
-          scoreMap[file][word] = o.score;
-        }
-      });
-
       // create the mapping
       for (j = 0; j < files.length; j++) {
         file = files[j];
@@ -600,9 +576,7 @@ var Search = {
       // ensure that none of the excluded terms is in the search result
       for (i = 0; i < excluded.length; i++) {
         if (terms[excluded[i]] == file ||
-            titleterms[excluded[i]] == file ||
-            $u.contains(terms[excluded[i]] || [], file) ||
-            $u.contains(titleterms[excluded[i]] || [], file)) {
+          $u.contains(terms[excluded[i]] || [], file)) {
           valid = false;
           break;
         }
@@ -610,9 +584,6 @@ var Search = {
 
       // if we have still a valid result we can add it to the result list
       if (valid) {
-        // select one (max) score for the file.
-        // for better ranking, we should calculate ranking by using words statistics like basic tf-idf...
-        var score = $u.max($u.map(fileMap[file], function(w){return scoreMap[file][w]}));
         results.push([filenames[file], titles[file], '', null, score]);
       }
     }
@@ -623,7 +594,7 @@ var Search = {
    * helper function to return a node containing the
    * search summary for a given text. keywords is a list
    * of stemmed words, hlwords is the list of normal, unstemmed
-   * words. the first one is used to find the occurrence, the
+   * words. the first one is used to find the occurance, the
    * latter for highlighting it.
    */
   makeSearchSummary : function(text, keywords, hlwords) {

Modified: tajo/site/docs/devel/_static/websupport.js
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/_static/websupport.js?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/_static/websupport.js (original)
+++ tajo/site/docs/devel/_static/websupport.js Fri May 20 22:19:36 2016
@@ -2,9 +2,9 @@
  * websupport.js
  * ~~~~~~~~~~~~~
  *
- * sphinx.websupport utilities for all documentation.
+ * sphinx.websupport utilties for all documentation.
  *
- * :copyright: Copyright 2007-2016 by the Sphinx team, see AUTHORS.
+ * :copyright: Copyright 2007-2015 by the Sphinx team, see AUTHORS.
  * :license: BSD, see LICENSE for details.
  *
  */

Modified: tajo/site/docs/devel/backup_and_restore.html
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/backup_and_restore.html?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/backup_and_restore.html (original)
+++ tajo/site/docs/devel/backup_and_restore.html Fri May 20 22:19:36 2016
@@ -73,6 +73,7 @@
 <li class="toctree-l2"><a class="reference internal" href="configuration/tajo_master_configuration.html">Tajo Master Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/worker_configuration.html">Worker Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/catalog_configuration.html">Catalog Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="configuration/pullserver_configuration.html">Pull Server Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/ha_configuration.html">High Availability for TajoMaster</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/service_config_defaults.html">Cluster Service Configuration Defaults</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/tajo-site-xml.html">The tajo-site.xml File</a></li>
@@ -143,7 +144,7 @@
 <li class="toctree-l2"><a class="reference internal" href="index/future_work.html">Future Works</a></li>
 </ul>
 </li>
-<li class="toctree-l1 current"><a class="current reference internal" href="#">Backup and Restore</a><ul>
+<li class="toctree-l1 current"><a class="current reference internal" href="">Backup and Restore</a><ul>
 <li class="toctree-l2"><a class="reference internal" href="backup_and_restore/catalog.html">Backup and Restore Catalog</a></li>
 </ul>
 </li>

Modified: tajo/site/docs/devel/backup_and_restore/catalog.html
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/backup_and_restore/catalog.html?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/backup_and_restore/catalog.html (original)
+++ tajo/site/docs/devel/backup_and_restore/catalog.html Fri May 20 22:19:36 2016
@@ -74,6 +74,7 @@
 <li class="toctree-l2"><a class="reference internal" href="../configuration/tajo_master_configuration.html">Tajo Master Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../configuration/worker_configuration.html">Worker Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../configuration/catalog_configuration.html">Catalog Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../configuration/pullserver_configuration.html">Pull Server Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../configuration/ha_configuration.html">High Availability for TajoMaster</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../configuration/service_config_defaults.html">Cluster Service Configuration Defaults</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../configuration/tajo-site-xml.html">The tajo-site.xml File</a></li>
@@ -145,7 +146,7 @@
 </ul>
 </li>
 <li class="toctree-l1 current"><a class="reference internal" href="../backup_and_restore.html">Backup and Restore</a><ul class="current">
-<li class="toctree-l2 current"><a class="current reference internal" href="#">Backup and Restore Catalog</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="">Backup and Restore Catalog</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../hive_integration.html">Hive Integration</a></li>
@@ -219,11 +220,11 @@
 <div class="section" id="sql-dump">
 <h2>SQL dump<a class="headerlink" href="#sql-dump" title="Permalink to this headline">¶</a></h2>
 <p>SQL dump is an easy and strong way. If you use this approach, you don&#8217;t need to concern database-level compatibilities. If you want to backup your catalog, just use bin/tajo-dump command. The basic usage of this command is:</p>
-<div class="highlight-default"><div class="highlight"><pre>$ tajo-dump table_name &gt; outfile
+<div class="highlight-python"><div class="highlight"><pre>$ tajo-dump table_name &gt; outfile
 </pre></div>
 </div>
 <p>For example, if you want to backup a table customer, you should type a command as follows:</p>
-<div class="highlight-default"><div class="highlight"><pre>$ bin/tajo-dump customer &gt; table_backup.sql
+<div class="highlight-python"><div class="highlight"><pre>$ bin/tajo-dump customer &gt; table_backup.sql
 $
 $ cat table_backup.sql
 -- Tajo database dump
@@ -238,16 +239,19 @@ CREATE EXTERNAL TABLE customer (c_custke
 </pre></div>
 </div>
 <p>If you want to restore the catalog from the SQL dump file, please type the below command:</p>
-<div class="highlight-default"><div class="highlight"><pre>$ bin/tsql -f table_backup.sql
+<div class="highlight-python"><div class="highlight"><pre>$ bin/tsql -f table_backup.sql
 </pre></div>
 </div>
 <p>If you use an option &#8216;-a&#8217;, tajo-dump will dump all table DDLs.</p>
-<div class="highlight-default"><div class="highlight"><pre>$ bin/tajo-dump -a &gt; all_backup.sql
+<div class="highlight-python"><div class="highlight"><pre>$ bin/tajo-dump -a &gt; all_backup.sql
 </pre></div>
 </div>
 </div>
 <div class="section" id="database-level-backup">
 <h2>Database-level backup<a class="headerlink" href="#database-level-backup" title="Permalink to this headline">¶</a></h2>
+<div class="admonition-todo admonition" id="index-0">
+<p class="first last admonition-title">Todo</p>
+</div>
 </div>
 </div>
 

Modified: tajo/site/docs/devel/configuration.html
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/configuration.html?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/configuration.html (original)
+++ tajo/site/docs/devel/configuration.html Fri May 20 22:19:36 2016
@@ -67,12 +67,13 @@
 <li class="toctree-l2"><a class="reference internal" href="getting_started.html#first-query-execution">First query execution</a></li>
 </ul>
 </li>
-<li class="toctree-l1 current"><a class="current reference internal" href="#">Configuration</a><ul>
+<li class="toctree-l1 current"><a class="current reference internal" href="">Configuration</a><ul>
 <li class="toctree-l2"><a class="reference internal" href="configuration/preliminary.html">Preliminary</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/cluster_setup.html">Cluster Setup</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/tajo_master_configuration.html">Tajo Master Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/worker_configuration.html">Worker Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/catalog_configuration.html">Catalog Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="configuration/pullserver_configuration.html">Pull Server Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/ha_configuration.html">High Availability for TajoMaster</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/service_config_defaults.html">Cluster Service Configuration Defaults</a></li>
 <li class="toctree-l2"><a class="reference internal" href="configuration/tajo-site-xml.html">The tajo-site.xml File</a></li>
@@ -215,6 +216,7 @@
 <li class="toctree-l1"><a class="reference internal" href="configuration/tajo_master_configuration.html">Tajo Master Configuration</a></li>
 <li class="toctree-l1"><a class="reference internal" href="configuration/worker_configuration.html">Worker Configuration</a></li>
 <li class="toctree-l1"><a class="reference internal" href="configuration/catalog_configuration.html">Catalog Configuration</a></li>
+<li class="toctree-l1"><a class="reference internal" href="configuration/pullserver_configuration.html">Pull Server Configuration</a></li>
 <li class="toctree-l1"><a class="reference internal" href="configuration/ha_configuration.html">High Availability for TajoMaster</a></li>
 <li class="toctree-l1"><a class="reference internal" href="configuration/service_config_defaults.html">Cluster Service Configuration Defaults</a></li>
 <li class="toctree-l1"><a class="reference internal" href="configuration/tajo-site-xml.html">The tajo-site.xml File</a></li>

Modified: tajo/site/docs/devel/configuration/catalog-site-xml.html
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/configuration/catalog-site-xml.html?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/configuration/catalog-site-xml.html (original)
+++ tajo/site/docs/devel/configuration/catalog-site-xml.html Fri May 20 22:19:36 2016
@@ -74,10 +74,11 @@
 <li class="toctree-l2"><a class="reference internal" href="tajo_master_configuration.html">Tajo Master Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="worker_configuration.html">Worker Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="catalog_configuration.html">Catalog Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="pullserver_configuration.html">Pull Server Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="ha_configuration.html">High Availability for TajoMaster</a></li>
 <li class="toctree-l2"><a class="reference internal" href="service_config_defaults.html">Cluster Service Configuration Defaults</a></li>
 <li class="toctree-l2"><a class="reference internal" href="tajo-site-xml.html">The tajo-site.xml File</a></li>
-<li class="toctree-l2 current"><a class="current reference internal" href="#">The catalog-site.xml File</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="">The catalog-site.xml File</a></li>
 <li class="toctree-l2"><a class="reference internal" href="storage-site-json.html">The storage-site.json File</a></li>
 </ul>
 </li>

Modified: tajo/site/docs/devel/configuration/catalog_configuration.html
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/configuration/catalog_configuration.html?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/configuration/catalog_configuration.html (original)
+++ tajo/site/docs/devel/configuration/catalog_configuration.html Fri May 20 22:19:36 2016
@@ -30,7 +30,7 @@
   
     <link rel="top" title="Apache Tajo 0.12.0-SNAPSHOT documentation" href="../index.html"/>
         <link rel="up" title="Configuration" href="../configuration.html"/>
-        <link rel="next" title="High Availability for TajoMaster" href="ha_configuration.html"/>
+        <link rel="next" title="Pull Server Configuration" href="pullserver_configuration.html"/>
         <link rel="prev" title="Worker Configuration" href="worker_configuration.html"/> 
 
   
@@ -73,7 +73,8 @@
 <li class="toctree-l2"><a class="reference internal" href="cluster_setup.html">Cluster Setup</a></li>
 <li class="toctree-l2"><a class="reference internal" href="tajo_master_configuration.html">Tajo Master Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="worker_configuration.html">Worker Configuration</a></li>
-<li class="toctree-l2 current"><a class="current reference internal" href="#">Catalog Configuration</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="">Catalog Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="pullserver_configuration.html">Pull Server Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="ha_configuration.html">High Availability for TajoMaster</a></li>
 <li class="toctree-l2"><a class="reference internal" href="service_config_defaults.html">Cluster Service Configuration Defaults</a></li>
 <li class="toctree-l2"><a class="reference internal" href="tajo-site-xml.html">The tajo-site.xml File</a></li>
@@ -388,7 +389,7 @@ Query OK, <span class="m">0</span> rows
   
     <div class="rst-footer-buttons" role="navigation" aria-label="footer navigation">
       
-        <a href="ha_configuration.html" class="btn btn-neutral float-right" title="High Availability for TajoMaster"/>Next <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="pullserver_configuration.html" class="btn btn-neutral float-right" title="Pull Server Configuration"/>Next <span class="fa fa-arrow-circle-right"></span></a>
       
       
         <a href="worker_configuration.html" class="btn btn-neutral" title="Worker Configuration"><span class="fa fa-arrow-circle-left"></span> Previous</a>

Modified: tajo/site/docs/devel/configuration/cluster_setup.html
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/configuration/cluster_setup.html?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/configuration/cluster_setup.html (original)
+++ tajo/site/docs/devel/configuration/cluster_setup.html Fri May 20 22:19:36 2016
@@ -70,10 +70,11 @@
 </li>
 <li class="toctree-l1 current"><a class="reference internal" href="../configuration.html">Configuration</a><ul class="current">
 <li class="toctree-l2"><a class="reference internal" href="preliminary.html">Preliminary</a></li>
-<li class="toctree-l2 current"><a class="current reference internal" href="#">Cluster Setup</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="">Cluster Setup</a></li>
 <li class="toctree-l2"><a class="reference internal" href="tajo_master_configuration.html">Tajo Master Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="worker_configuration.html">Worker Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="catalog_configuration.html">Catalog Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="pullserver_configuration.html">Pull Server Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="ha_configuration.html">High Availability for TajoMaster</a></li>
 <li class="toctree-l2"><a class="reference internal" href="service_config_defaults.html">Cluster Service Configuration Defaults</a></li>
 <li class="toctree-l2"><a class="reference internal" href="tajo-site-xml.html">The tajo-site.xml File</a></li>
@@ -220,27 +221,19 @@
 <p>Please add the following configs to tajo-site.xml file:</p>
 <div class="highlight-xml"><div class="highlight"><pre><span class="nt">&lt;property&gt;</span>
   <span class="nt">&lt;name&gt;</span>tajo.rootdir<span class="nt">&lt;/name&gt;</span>
-  <span class="nt">&lt;value&gt;</span>hdfs://hostname:port/tajo<span class="nt">&lt;/value&gt;</span>
+  <span class="nt">&lt;value&gt;</span>hdfs://nameservice/tajo<span class="nt">&lt;/value&gt;</span>
 <span class="nt">&lt;/property&gt;</span>
 
 <span class="nt">&lt;property&gt;</span>
   <span class="nt">&lt;name&gt;</span>tajo.master.umbilical-rpc.address<span class="nt">&lt;/name&gt;</span>
   <span class="nt">&lt;value&gt;</span>hostname:26001<span class="nt">&lt;/value&gt;</span>
+  <span class="nt">&lt;description&gt;</span>TajoMaster binding address between master and workers.<span class="nt">&lt;/description&gt;</span>
 <span class="nt">&lt;/property&gt;</span>
 
 <span class="nt">&lt;property&gt;</span>
   <span class="nt">&lt;name&gt;</span>tajo.master.client-rpc.address<span class="nt">&lt;/name&gt;</span>
   <span class="nt">&lt;value&gt;</span>hostname:26002<span class="nt">&lt;/value&gt;</span>
-<span class="nt">&lt;/property&gt;</span>
-
-<span class="nt">&lt;property&gt;</span>
-  <span class="nt">&lt;name&gt;</span>tajo.resource-tracker.rpc.address<span class="nt">&lt;/name&gt;</span>
-  <span class="nt">&lt;value&gt;</span>hostname:26003<span class="nt">&lt;/value&gt;</span>
-<span class="nt">&lt;/property&gt;</span>
-
-<span class="nt">&lt;property&gt;</span>
-  <span class="nt">&lt;name&gt;</span>tajo.catalog.client-rpc.address<span class="nt">&lt;/name&gt;</span>
-  <span class="nt">&lt;value&gt;</span>hostname:26005<span class="nt">&lt;/value&gt;</span>
+  <span class="nt">&lt;description&gt;</span>TajoMaster binding address between master and remote clients.<span class="nt">&lt;/description&gt;</span>
 <span class="nt">&lt;/property&gt;</span>
 </pre></div>
 </div>
@@ -251,7 +244,7 @@
 By default, this file contains the single entry <code class="docutils literal"><span class="pre">localhost</span></code>.
 You can easily add host names of workers via your favorite text editor.</p>
 <p>For example:</p>
-<div class="highlight-default"><div class="highlight"><pre>$ cat &gt; conf/workers
+<div class="highlight-python"><div class="highlight"><pre>$ cat &gt; conf/workers
 host1.domain.com
 host2.domain.com
 ....
@@ -264,7 +257,7 @@ host2.domain.com
 <h3>Make base directories and set permissions<a class="headerlink" href="#make-base-directories-and-set-permissions" title="Permalink to this headline">¶</a></h3>
 <p>If you want to know Tajo’s configuration in more detail, see Configuration page.
 Before launching the tajo, you should create the tajo root dir and set the permission as follows:</p>
-<div class="highlight-default"><div class="highlight"><pre>$ $HADOOP_HOME/bin/hadoop fs -mkdir       /tajo
+<div class="highlight-python"><div class="highlight"><pre>$ $HADOOP_HOME/bin/hadoop fs -mkdir       /tajo
 $ $HADOOP_HOME/bin/hadoop fs -chmod g+w   /tajo
 </pre></div>
 </div>
@@ -272,17 +265,17 @@ $ $HADOOP_HOME/bin/hadoop fs -chmod g+w
 <div class="section" id="launch-a-tajo-cluster">
 <h3>Launch a Tajo cluster<a class="headerlink" href="#launch-a-tajo-cluster" title="Permalink to this headline">¶</a></h3>
 <p>Then, execute <code class="docutils literal"><span class="pre">start-tajo.sh</span></code></p>
-<div class="highlight-default"><div class="highlight"><pre>$ $TAJO_HOME/bin/start-tajo.sh
+<div class="highlight-python"><div class="highlight"><pre>$ $TAJO_HOME/bin/start-tajo.sh
 </pre></div>
 </div>
 <div class="admonition note">
 <p class="first admonition-title">Note</p>
-<p class="last">In default, each worker is set to very little resource capacity. In order to increase parallel degree, please read
-<a class="reference internal" href="worker_configuration.html"><span class="doc">Worker Configuration</span></a>.</p>
+<p class="last">By default, each worker is set to very little resource capacity. In order to increase parallel degree, please read
+<a class="reference internal" href="worker_configuration.html"><em>Worker Configuration</em></a>.</p>
 </div>
 <div class="admonition note">
 <p class="first admonition-title">Note</p>
-<p class="last">In default, TajoMaster listens on 127.0.0.1 for clients. To allow remote clients to access TajoMaster, please set tajo.master.client-rpc.address config to tajo-site.xml. In order to know how to change the listen port, please refer <a class="reference internal" href="service_config_defaults.html"><span class="doc">Cluster Service Configuration Defaults</span></a>.</p>
+<p class="last">By default, TajoMaster listens on localhost/127.0.0.1 for clients. To allow remote clients to access TajoMaster, please set tajo.master.client-rpc.address config to tajo-site.xml. In order to know how to change the listen port, please refer <a class="reference internal" href="service_config_defaults.html"><em>Cluster Service Configuration Defaults</em></a>.</p>
 </div>
 </div>
 </div>

Modified: tajo/site/docs/devel/configuration/ha_configuration.html
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/configuration/ha_configuration.html?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/configuration/ha_configuration.html (original)
+++ tajo/site/docs/devel/configuration/ha_configuration.html Fri May 20 22:19:36 2016
@@ -31,7 +31,7 @@
     <link rel="top" title="Apache Tajo 0.12.0-SNAPSHOT documentation" href="../index.html"/>
         <link rel="up" title="Configuration" href="../configuration.html"/>
         <link rel="next" title="Cluster Service Configuration Defaults" href="service_config_defaults.html"/>
-        <link rel="prev" title="Catalog Configuration" href="catalog_configuration.html"/> 
+        <link rel="prev" title="Pull Server Configuration" href="pullserver_configuration.html"/> 
 
   
   <script src="https://cdnjs.cloudflare.com/ajax/libs/modernizr/2.6.2/modernizr.min.js"></script>
@@ -74,7 +74,8 @@
 <li class="toctree-l2"><a class="reference internal" href="tajo_master_configuration.html">Tajo Master Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="worker_configuration.html">Worker Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="catalog_configuration.html">Catalog Configuration</a></li>
-<li class="toctree-l2 current"><a class="current reference internal" href="#">High Availability for TajoMaster</a></li>
+<li class="toctree-l2"><a class="reference internal" href="pullserver_configuration.html">Pull Server Configuration</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="">High Availability for TajoMaster</a></li>
 <li class="toctree-l2"><a class="reference internal" href="service_config_defaults.html">Cluster Service Configuration Defaults</a></li>
 <li class="toctree-l2"><a class="reference internal" href="tajo-site-xml.html">The tajo-site.xml File</a></li>
 <li class="toctree-l2"><a class="reference internal" href="catalog-site-xml.html">The catalog-site.xml File</a></li>
@@ -245,7 +246,7 @@
 <h2>Backup Master Settings<a class="headerlink" href="#backup-master-settings" title="Permalink to this headline">¶</a></h2>
 <p>If you want to run masters with <code class="docutils literal"><span class="pre">start-tajo.sh</span></code>, specific your masters in <code class="docutils literal"><span class="pre">conf/masters</span></code>. The file lists all host names of masters, one per line.By default, this file contains the single entry <code class="docutils literal"><span class="pre">localhost</span></code>. You can easily add host names of workers via your favorite text editor.</p>
 <p>For example:</p>
-<div class="highlight-default"><div class="highlight"><pre>$ cat &gt; conf/masters
+<div class="highlight-python"><div class="highlight"><pre>$ cat &gt; conf/masters
 host1.domain.com
 host2.domain.com
 ....
@@ -294,7 +295,7 @@ host2.domain.com
 <div class="section" id="launch-a-tajo-cluster">
 <h2>Launch a Tajo cluster<a class="headerlink" href="#launch-a-tajo-cluster" title="Permalink to this headline">¶</a></h2>
 <p>Then, execute <code class="docutils literal"><span class="pre">start-tajo.sh</span></code></p>
-<div class="highlight-default"><div class="highlight"><pre>$ $TAJO_HOME/bin/start-tajo.sh
+<div class="highlight-python"><div class="highlight"><pre>$ $TAJO_HOME/bin/start-tajo.sh
 </pre></div>
 </div>
 <div class="admonition note">
@@ -305,19 +306,19 @@ host2.domain.com
 <div class="section" id="administration-ha-state">
 <h2>Administration HA state<a class="headerlink" href="#administration-ha-state" title="Permalink to this headline">¶</a></h2>
 <p>If you want to transit any backup master to active master, execute <code class="docutils literal"><span class="pre">tajo</span> <span class="pre">hadmin</span> <span class="pre">-transitionToActive</span></code></p>
-<div class="highlight-default"><div class="highlight"><pre>$ $TAJO_HOME/bin/tajo haadmin -transitionToActive &lt;target tajo.master.umbilical-rpc.address&gt;
+<div class="highlight-python"><div class="highlight"><pre>$ $TAJO_HOME/bin/tajo haadmin -transitionToActive &lt;target tajo.master.umbilical-rpc.address&gt;
 </pre></div>
 </div>
 <p>If you want to transit any active master to backup master, execute <code class="docutils literal"><span class="pre">tajo</span> <span class="pre">hadmin</span> <span class="pre">-transitionToBackup</span></code></p>
-<div class="highlight-default"><div class="highlight"><pre>$ $TAJO_HOME/bin/tajo haadmin -transitionToBackup &lt;target tajo.master.umbilical-rpc.address&gt;
+<div class="highlight-python"><div class="highlight"><pre>$ $TAJO_HOME/bin/tajo haadmin -transitionToBackup &lt;target tajo.master.umbilical-rpc.address&gt;
 </pre></div>
 </div>
 <p>If you want to find the state of any master, execute <code class="docutils literal"><span class="pre">tajo</span> <span class="pre">hadmin</span> <span class="pre">-getState</span></code></p>
-<div class="highlight-default"><div class="highlight"><pre>$ $TAJO_HOME/bin/tajo haadmin -getState &lt;target tajo.master.umbilical-rpc.address&gt;
+<div class="highlight-python"><div class="highlight"><pre>$ $TAJO_HOME/bin/tajo haadmin -getState &lt;target tajo.master.umbilical-rpc.address&gt;
 </pre></div>
 </div>
 <p>If you want to initiate HA information, execute <code class="docutils literal"><span class="pre">tajo</span> <span class="pre">haadmin</span> <span class="pre">-formatHA</span></code></p>
-<div class="highlight-default"><div class="highlight"><pre>$ $TAJO_HOME/bin/tajo haadmin -formatHA
+<div class="highlight-python"><div class="highlight"><pre>$ $TAJO_HOME/bin/tajo haadmin -formatHA
 </pre></div>
 </div>
 <div class="admonition note">
@@ -345,7 +346,7 @@ host2.domain.com
         <a href="service_config_defaults.html" class="btn btn-neutral float-right" title="Cluster Service Configuration Defaults"/>Next <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="catalog_configuration.html" class="btn btn-neutral" title="Catalog Configuration"><span class="fa fa-arrow-circle-left"></span> Previous</a>
+        <a href="pullserver_configuration.html" class="btn btn-neutral" title="Pull Server Configuration"><span class="fa fa-arrow-circle-left"></span> Previous</a>
       
     </div>
   

Modified: tajo/site/docs/devel/configuration/preliminary.html
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/configuration/preliminary.html?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/configuration/preliminary.html (original)
+++ tajo/site/docs/devel/configuration/preliminary.html Fri May 20 22:19:36 2016
@@ -69,11 +69,12 @@
 </ul>
 </li>
 <li class="toctree-l1 current"><a class="reference internal" href="../configuration.html">Configuration</a><ul class="current">
-<li class="toctree-l2 current"><a class="current reference internal" href="#">Preliminary</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="">Preliminary</a></li>
 <li class="toctree-l2"><a class="reference internal" href="cluster_setup.html">Cluster Setup</a></li>
 <li class="toctree-l2"><a class="reference internal" href="tajo_master_configuration.html">Tajo Master Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="worker_configuration.html">Worker Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="catalog_configuration.html">Catalog Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="pullserver_configuration.html">Pull Server Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="ha_configuration.html">High Availability for TajoMaster</a></li>
 <li class="toctree-l2"><a class="reference internal" href="service_config_defaults.html">Cluster Service Configuration Defaults</a></li>
 <li class="toctree-l2"><a class="reference internal" href="tajo-site-xml.html">The tajo-site.xml File</a></li>

Added: tajo/site/docs/devel/configuration/pullserver_configuration.html
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/configuration/pullserver_configuration.html?rev=1744805&view=auto
==============================================================================
--- tajo/site/docs/devel/configuration/pullserver_configuration.html (added)
+++ tajo/site/docs/devel/configuration/pullserver_configuration.html Fri May 20 22:19:36 2016
@@ -0,0 +1,343 @@
+
+
+<!DOCTYPE html>
+<!--[if IE 8]><html class="no-js lt-ie9" lang="en" > <![endif]-->
+<!--[if gt IE 8]><!--> <html class="no-js" lang="en" > <!--<![endif]-->
+<head>
+  <meta charset="utf-8">
+  <meta name="viewport" content="width=device-width, initial-scale=1.0">
+  
+  <title>Pull Server Configuration &mdash; Apache Tajo 0.12.0-SNAPSHOT documentation</title>
+  
+
+  
+  
+
+  
+  <link href='https://fonts.googleapis.com/css?family=Lato:400,700|Roboto+Slab:400,700|Inconsolata:400,700' rel='stylesheet' type='text/css'>
+
+  
+  
+    
+
+  
+
+  
+  
+    <link rel="stylesheet" href="../_static/css/theme.css" type="text/css" />
+  
+
+  
+    <link rel="top" title="Apache Tajo 0.12.0-SNAPSHOT documentation" href="../index.html"/>
+        <link rel="up" title="Configuration" href="../configuration.html"/>
+        <link rel="next" title="High Availability for TajoMaster" href="ha_configuration.html"/>
+        <link rel="prev" title="Catalog Configuration" href="catalog_configuration.html"/> 
+
+  
+  <script src="https://cdnjs.cloudflare.com/ajax/libs/modernizr/2.6.2/modernizr.min.js"></script>
+
+</head>
+
+<body class="wy-body-for-nav" role="document">
+
+  <div class="wy-grid-for-nav">
+
+    
+    <nav data-toggle="wy-nav-shift" class="wy-nav-side">
+      <div class="wy-side-nav-search">
+        <a href="../index.html" class="fa fa-home"> Apache Tajo</a>
+        <div role="search">
+  <form id ="rtd-search-form" class="wy-form" action="../search.html" method="get">
+    <input type="text" name="q" placeholder="Search docs" />
+    <input type="hidden" name="check_keywords" value="yes" />
+    <input type="hidden" name="area" value="default" />
+  </form>
+</div>
+      </div>
+
+      <div class="wy-menu wy-menu-vertical" data-spy="affix" role="navigation" aria-label="main navigation">
+        
+        
+            <ul class="current">
+<li class="toctree-l1"><a class="reference internal" href="../introduction.html">Introduction</a></li>
+<li class="toctree-l1"><a class="reference internal" href="../getting_started.html">Getting Started</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../getting_started.html#prerequisites">Prerequisites</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../getting_started.html#dowload-and-unpack-the-source-code">Dowload and unpack the source code</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../getting_started.html#build-source-code">Build source code</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../getting_started.html#setting-up-a-local-tajo-cluster">Setting up a local Tajo cluster</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../getting_started.html#first-query-execution">First query execution</a></li>
+</ul>
+</li>
+<li class="toctree-l1 current"><a class="reference internal" href="../configuration.html">Configuration</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="preliminary.html">Preliminary</a></li>
+<li class="toctree-l2"><a class="reference internal" href="cluster_setup.html">Cluster Setup</a></li>
+<li class="toctree-l2"><a class="reference internal" href="tajo_master_configuration.html">Tajo Master Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="worker_configuration.html">Worker Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="catalog_configuration.html">Catalog Configuration</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="">Pull Server Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="ha_configuration.html">High Availability for TajoMaster</a></li>
+<li class="toctree-l2"><a class="reference internal" href="service_config_defaults.html">Cluster Service Configuration Defaults</a></li>
+<li class="toctree-l2"><a class="reference internal" href="tajo-site-xml.html">The tajo-site.xml File</a></li>
+<li class="toctree-l2"><a class="reference internal" href="catalog-site-xml.html">The catalog-site.xml File</a></li>
+<li class="toctree-l2"><a class="reference internal" href="storage-site-json.html">The storage-site.json File</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../tsql.html">Tajo Shell (TSQL)</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../tsql/meta_command.html">Meta Commands</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../tsql/dfs_command.html">Executing HDFS commands</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../tsql/variables.html">Session Variables</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../tsql/admin_command.html">Administration Commands</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../tsql/intro.html">Introducing to TSQL</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../tsql/single_command.html">Executing a single command</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../tsql/execute_file.html">Executing Queries from Files</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../tsql/background_command.html">Executing as background process</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../sql_language.html">SQL Language</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../sql_language/data_model.html">Data Model</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../sql_language/ddl.html">Data Definition Language</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../sql_language/insert.html">INSERT (OVERWRITE) INTO</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../sql_language/alter_table.html">ALTER TABLE</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../sql_language/queries.html">Queries</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../sql_language/joins.html">Joins</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../sql_language/sql_expression.html">SQL Expressions</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../sql_language/predicates.html">Predicates</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../sql_language/explain.html">EXPLAIN</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../time_zone.html">Time Zone</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../time_zone.html#server-cluster-time-zone">Server Cluster Time Zone</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../time_zone.html#table-time-zone">Table Time Zone</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../time_zone.html#client-time-zone">Client Time Zone</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../time_zone.html#time-zone-id">Time Zone ID</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../time_zone.html#examples-of-time-zone">Examples of Time Zone</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../functions.html">Functions</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../functions.html#built-in-scalar-functions">Built-in Scalar Functions</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../functions.html#built-in-aggregation-functions">Built-in Aggregation Functions</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../functions.html#built-in-window-functions">Built-in Window Functions</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../functions.html#user-defined-functions">User-defined Functions</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../table_management.html">Table Management</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../table_management/table_overview.html">Overview of Tajo Tables</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../table_management/tablespaces.html">Tablespaces</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../table_management/data_formats.html">Data Formats</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../table_management/compression.html">Compression</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../table_partitioning.html">Table Partitioning</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../partitioning/intro_to_partitioning.html">Introduction to Partitioning</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../partitioning/column_partitioning.html">Column Partitioning</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../partitioning/range_partitioning.html">Range Partitioning</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../partitioning/hash_partitioning.html">Hash Partitioning</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../storage_plugins.html">Storage Plugin</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../storage_plugins/overview.html">Storage Plugin Overview</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../storage_plugins/postgresql.html">PostgreSQL Storage Handler</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../index_overview.html">Index (Experimental Feature)</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../index/types.html">Index Types</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../index/how_to_use.html">How to use index?</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../index/future_work.html">Future Works</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../backup_and_restore.html">Backup and Restore</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../backup_and_restore/catalog.html">Backup and Restore Catalog</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../hive_integration.html">Hive Integration</a></li>
+<li class="toctree-l1"><a class="reference internal" href="../hbase_integration.html">HBase Integration</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../hbase_integration.html#create-table">CREATE TABLE</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../hbase_integration.html#drop-table">DROP TABLE</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../hbase_integration.html#insert-overwrite-into">INSERT (OVERWRITE) INTO</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../hbase_integration.html#usage">Usage</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../swift_integration.html">OpenStack Swift Integration</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../swift_integration.html#swift-configuration">Swift configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../swift_integration.html#hadoop-configurations">Hadoop configurations</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../swift_integration.html#tajo-configuration">Tajo configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../swift_integration.html#querying-on-swift">Querying on Swift</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../jdbc_driver.html">Tajo JDBC Driver</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../jdbc_driver.html#how-to-get-jdbc-driver">How to get JDBC driver</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../jdbc_driver.html#setting-the-classpath">Setting the CLASSPATH</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../jdbc_driver.html#connecting-to-the-tajo-cluster-instance">Connecting to the Tajo cluster instance</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../jdbc_driver.html#connection-parameters">Connection Parameters</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../jdbc_driver.html#an-example-jdbc-client">An Example JDBC Client</a></li>
+</ul>
+</li>
+<li class="toctree-l1"><a class="reference internal" href="../tajo_client_api.html">Tajo Client API</a></li>
+<li class="toctree-l1"><a class="reference internal" href="../faq.html">FAQ</a></li>
+</ul>
+
+        
+      </div>
+      &nbsp;
+    </nav>
+
+    <section data-toggle="wy-nav-shift" class="wy-nav-content-wrap">
+
+      
+      <nav class="wy-nav-top" role="navigation" aria-label="top navigation">
+        <i data-toggle="wy-nav-top" class="fa fa-bars"></i>
+        <a href="../index.html">Apache Tajo</a>
+      </nav>
+
+
+      
+      <div class="wy-nav-content">
+        <div class="rst-content">
+          <div role="navigation" aria-label="breadcrumbs navigation">
+  <ul class="wy-breadcrumbs">
+    <li><a href="../index.html">Docs</a> &raquo;</li>
+      
+          <li><a href="../configuration.html">Configuration</a> &raquo;</li>
+      
+    <li>Pull Server Configuration</li>
+      <li class="wy-breadcrumbs-aside">
+        
+          <a href="../_sources/configuration/pullserver_configuration.txt" rel="nofollow"> View page source</a>
+        
+      </li>
+  </ul>
+  <hr/>
+</div>
+          <div role="main">
+            
+  <div class="section" id="pull-server-configuration">
+<h1>Pull Server Configuration<a class="headerlink" href="#pull-server-configuration" title="Permalink to this headline">¶</a></h1>
+<p>Pull servers are responsible for transmitting data among Tajo workers during shuffle phases. Tajo provides several modes
+for pull servers.</p>
+<div class="section" id="internal-mode-default">
+<h2>Internal Mode (Default)<a class="headerlink" href="#internal-mode-default" title="Permalink to this headline">¶</a></h2>
+<p>With the internal mode, each worker acts as a pull server. So, they need to transmit data during shuffle phase as well
+as processing them during processing phase.</p>
+</div>
+<div class="section" id="standalone-mode">
+<h2>Standalone Mode<a class="headerlink" href="#standalone-mode" title="Permalink to this headline">¶</a></h2>
+<p>Sometimes, data shuffling requires huge memory space and a lot of cpu processing.
+This can make query processing slow because Tajo&#8217;s query engine should contend for limited resources with pull servers.
+Tajo provides the standalone mode to avoid this unnecessary contention.</p>
+<p>In this mode, each pull server is executed as a separate process. To enable this mode, you need to add the following
+line to <code class="docutils literal"><span class="pre">${TAJO_HOME}/conf/tajo-env.sh</span></code>.</p>
+<div class="highlight-sh"><div class="highlight"><pre><span class="nb">export </span><span class="nv">TAJO_PULLSERVER_STANDALONE</span><span class="o">=</span><span class="nb">true</span>
+</pre></div>
+</div>
+<p>Then, you can see the following messages when you start up the tajo cluster.</p>
+<div class="highlight-sh"><div class="highlight"><pre>Starting single TajoMaster
+starting master, logging to ...
+192.168.10.1: starting pullserver, logging to ...
+192.168.10.1: starting worker, logging to ...
+192.168.10.2: starting pullserver, logging to ...
+192.168.10.2: starting worker, logging to ...
+...
+</pre></div>
+</div>
+<div class="admonition warning">
+<p class="first admonition-title">Warning</p>
+<p class="last">Currently, only one single server should be run in each machine.</p>
+</div>
+</div>
+<div class="section" id="yarn-auxiliary-service-mode">
+<h2>Yarn Auxiliary Service Mode<a class="headerlink" href="#yarn-auxiliary-service-mode" title="Permalink to this headline">¶</a></h2>
+<p>You can run pull servers as one of Yarn&#8217;s auxiliary services. To do so, you need to add the following configurations
+to <code class="docutils literal"><span class="pre">${HADOOP_CONF}/yarn-site.xml</span></code>.</p>
+<div class="highlight-xml"><div class="highlight"><pre><span class="nt">&lt;property&gt;</span>
+  <span class="nt">&lt;name&gt;</span>yarn.nodemanager.aux-services<span class="nt">&lt;/name&gt;</span>
+  <span class="nt">&lt;value&gt;</span>mapreduce_shuffle,tajo_shuffle<span class="nt">&lt;/value&gt;</span>
+<span class="nt">&lt;/property&gt;</span>
+
+<span class="nt">&lt;property&gt;</span>
+  <span class="nt">&lt;name&gt;</span>yarn.nodemanager.aux-services.tajo_shuffle.class<span class="nt">&lt;/name&gt;</span>
+  <span class="nt">&lt;value&gt;</span>org.apache.tajo.yarn.TajoPullServerService<span class="nt">&lt;/value&gt;</span>
+<span class="nt">&lt;/property&gt;</span>
+
+<span class="nt">&lt;property&gt;</span>
+  <span class="nt">&lt;name&gt;</span>tajo.pullserver.port<span class="nt">&lt;/name&gt;</span>
+  <span class="nt">&lt;value&gt;</span>port number<span class="nt">&lt;/value&gt;</span>
+<span class="nt">&lt;/property&gt;</span>
+</pre></div>
+</div>
+<p>Optionally, you can add the below configuration to specify temp directories. For this configuration,
+please refer to <a class="reference internal" href="worker_configuration.html"><em>Worker Configuration</em></a>.</p>
+<div class="highlight-xml"><div class="highlight"><pre><span class="nt">&lt;property&gt;</span>
+  <span class="nt">&lt;name&gt;</span>tajo.worker.tmpdir.locations<span class="nt">&lt;/name&gt;</span>
+  <span class="nt">&lt;value&gt;</span>/path/to/tajo/temporal/directory<span class="nt">&lt;/value&gt;</span>
+<span class="nt">&lt;/property&gt;</span>
+</pre></div>
+</div>
+</div>
+</div>
+
+
+          </div>
+          <footer>
+  
+    <div class="rst-footer-buttons" role="navigation" aria-label="footer navigation">
+      
+        <a href="ha_configuration.html" class="btn btn-neutral float-right" title="High Availability for TajoMaster"/>Next <span class="fa fa-arrow-circle-right"></span></a>
+      
+      
+        <a href="catalog_configuration.html" class="btn btn-neutral" title="Catalog Configuration"><span class="fa fa-arrow-circle-left"></span> Previous</a>
+      
+    </div>
+  
+
+  <hr/>
+
+  <div role="contentinfo">
+    <p>
+        &copy; Copyright 2016, Apache Tajo Team.
+    </p>
+  </div>
+
+  <a href="https://github.com/snide/sphinx_rtd_theme">Sphinx theme</a> provided by <a href="https://readthedocs.org">Read the Docs</a>
+</footer>
+        </div>
+      </div>
+
+    </section>
+
+  </div>
+  
+
+
+  
+
+    <script type="text/javascript">
+        var DOCUMENTATION_OPTIONS = {
+            URL_ROOT:'../',
+            VERSION:'0.12.0-SNAPSHOT',
+            COLLAPSE_INDEX:false,
+            FILE_SUFFIX:'.html',
+            HAS_SOURCE:  true
+        };
+    </script>
+      <script type="text/javascript" src="../_static/jquery.js"></script>
+      <script type="text/javascript" src="../_static/underscore.js"></script>
+      <script type="text/javascript" src="../_static/doctools.js"></script>
+
+  
+
+  
+  
+    <script type="text/javascript" src="../_static/js/theme.js"></script>
+  
+
+  
+  
+  <script type="text/javascript">
+      jQuery(function () {
+          SphinxRtdTheme.StickyNav.enable();
+      });
+  </script>
+   
+
+</body>
+</html>
\ No newline at end of file

Modified: tajo/site/docs/devel/configuration/service_config_defaults.html
URL: http://svn.apache.org/viewvc/tajo/site/docs/devel/configuration/service_config_defaults.html?rev=1744805&r1=1744804&r2=1744805&view=diff
==============================================================================
--- tajo/site/docs/devel/configuration/service_config_defaults.html (original)
+++ tajo/site/docs/devel/configuration/service_config_defaults.html Fri May 20 22:19:36 2016
@@ -74,8 +74,9 @@
 <li class="toctree-l2"><a class="reference internal" href="tajo_master_configuration.html">Tajo Master Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="worker_configuration.html">Worker Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="catalog_configuration.html">Catalog Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="pullserver_configuration.html">Pull Server Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="ha_configuration.html">High Availability for TajoMaster</a></li>
-<li class="toctree-l2 current"><a class="current reference internal" href="#">Cluster Service Configuration Defaults</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="">Cluster Service Configuration Defaults</a></li>
 <li class="toctree-l2"><a class="reference internal" href="tajo-site-xml.html">The tajo-site.xml File</a></li>
 <li class="toctree-l2"><a class="reference internal" href="catalog-site-xml.html">The catalog-site.xml File</a></li>
 <li class="toctree-l2"><a class="reference internal" href="storage-site-json.html">The storage-site.json File</a></li>
@@ -215,43 +216,43 @@
 <h2>Tajo Master Configuration Defaults<a class="headerlink" href="#tajo-master-configuration-defaults" title="Permalink to this headline">¶</a></h2>
 <table border="1" class="docutils">
 <colgroup>
-<col width="24%" />
-<col width="53%" />
-<col width="9%" />
-<col width="13%" />
+<col width="19%" />
+<col width="25%" />
+<col width="10%" />
+<col width="45%" />
 </colgroup>
 <thead valign="bottom">
 <tr class="row-odd"><th class="head">Service Name</th>
 <th class="head">Config Property Name</th>
-<th class="head">Description</th>
 <th class="head">default address</th>
+<th class="head">Description</th>
 </tr>
 </thead>
 <tbody valign="top">
 <tr class="row-even"><td>Tajo Master Umbilical Rpc</td>
 <td>tajo.master.umbilical-rpc.address</td>
-<td>&nbsp;</td>
 <td>localhost:26001</td>
+<td>TajoMaster binding address between master and workers.</td>
 </tr>
 <tr class="row-odd"><td>Tajo Master Client Rpc</td>
 <td>tajo.master.client-rpc.address</td>
-<td>&nbsp;</td>
 <td>localhost:26002</td>
+<td>TajoMaster binding address between master and remote clients.</td>
 </tr>
 <tr class="row-even"><td>Tajo Master Info Http</td>
 <td>tajo.master.info-http.address</td>
-<td>&nbsp;</td>
 <td>0.0.0.0:26080</td>
+<td>TajoMaster binding address between master and web browser.</td>
 </tr>
 <tr class="row-odd"><td>Tajo Resource Tracker Rpc</td>
 <td>tajo.resource-tracker.rpc.address</td>
-<td>&nbsp;</td>
-<td>localhost:26003</td>
+<td>0.0.0.0:26003</td>
+<td>TajoMaster binding address between master and workers.</td>
 </tr>
 <tr class="row-even"><td>Tajo Catalog Client Rpc</td>
 <td>tajo.catalog.client-rpc.address</td>
-<td>&nbsp;</td>
-<td>localhost:26005</td>
+<td>0.0.0.0:26005</td>
+<td>CatalogServer binding address between catalog server and workers.</td>
 </tr>
 </tbody>
 </table>
@@ -259,33 +260,33 @@
 <h3>Tajo Worker Configuration Defaults<a class="headerlink" href="#tajo-worker-configuration-defaults" title="Permalink to this headline">¶</a></h3>
 <table border="1" class="docutils">
 <colgroup>
-<col width="24%" />
-<col width="53%" />
-<col width="9%" />
-<col width="13%" />
+<col width="19%" />
+<col width="25%" />
+<col width="10%" />
+<col width="45%" />
 </colgroup>
 <thead valign="bottom">
 <tr class="row-odd"><th class="head">Service Name</th>
 <th class="head">Config Property Name</th>
-<th class="head">Description</th>
 <th class="head">default address</th>
+<th class="head">Description</th>
 </tr>
 </thead>
 <tbody valign="top">
 <tr class="row-even"><td>Tajo Worker Peer Rpc</td>
 <td>tajo.worker.peer-rpc.address</td>
-<td>&nbsp;</td>
 <td>0.0.0.0:28091</td>
+<td>TajoWorker binding address between worker and master.</td>
 </tr>
 <tr class="row-odd"><td>Tajo Worker Client Rpc</td>
 <td>tajo.worker.client-rpc.address</td>
-<td>&nbsp;</td>
 <td>0.0.0.0:28092</td>
+<td>TajoWorker binding address between worker and remote clients.</td>
 </tr>
 <tr class="row-even"><td>Tajo Worker Info Http</td>
 <td>tajo.worker.info-http.address</td>
-<td>&nbsp;</td>
 <td>0.0.0.0:28080</td>
+<td>TajoWorker binding address between master and web browser.</td>
 </tr>
 </tbody>
 </table>