You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by mw...@apache.org on 2018/07/11 16:37:03 UTC

[accumulo-website] branch master updated: Update auto-generated properties.md

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

mwalch pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/accumulo-website.git


The following commit(s) were added to refs/heads/master by this push:
     new 8a7aa58  Update auto-generated properties.md
8a7aa58 is described below

commit 8a7aa58c6b2373c8fb6a1baddb11f9447bdc8c40
Author: Mike Walch <mw...@apache.org>
AuthorDate: Wed Jul 11 12:31:26 2018 -0400

    Update auto-generated properties.md
    
    Also fixed minor issue in summaries.md
---
 _docs-2-0/administration/properties.md | 18 +++++++++---------
 _docs-2-0/development/summaries.md     |  2 +-
 2 files changed, 10 insertions(+), 10 deletions(-)

diff --git a/_docs-2-0/administration/properties.md b/_docs-2-0/administration/properties.md
index c1c6d32..f4b177e 100644
--- a/_docs-2-0/administration/properties.md
+++ b/_docs-2-0/administration/properties.md
@@ -45,9 +45,9 @@ Below are properties set in `accumulo-site.xml` or the Accumulo shell that confi
 | <a name="instance_rpc_ssl_clientAuth" class="prop"></a> instance.rpc.ssl.clientAuth | Require clients to present certs signed by a trusted root<br>**type:** BOOLEAN, **zk mutable:** no, **default value:** `false` |
 | <a name="instance_rpc_ssl_enabled" class="prop"></a> instance.rpc.ssl.enabled | Use SSL for socket connections from clients and among accumulo services. Mutually exclusive with SASL RPC configuration.<br>**type:** BOOLEAN, **zk mutable:** no, **default value:** `false` |
 | <a name="instance_secret" class="prop"></a> instance.secret | A secret unique to a given instance that all servers must know in order to communicate with one another. It should be changed prior to the initialization of Accumulo. To change it after Accumulo has been initialized, use the ChangeSecret tool and then update accumulo-site.xml everywhere. Before using the ChangeSecret tool, make sure Accumulo is not running and you are logged in as the user that controls Accumulo files in HDF [...]
-| <a name="instance_security_authenticator" class="prop"></a> instance.security.authenticator | The authenticator class that accumulo will use to determine if a user has privilege to perform an action<br>**type:** CLASSNAME, **zk mutable:** no, **default value:** `org.apache.accumulo.server.security.handler.ZKAuthenticator` |
-| <a name="instance_security_authorizor" class="prop"></a> instance.security.authorizor | The authorizor class that accumulo will use to determine what labels a user has privilege to see<br>**type:** CLASSNAME, **zk mutable:** no, **default value:** `org.apache.accumulo.server.security.handler.ZKAuthorizor` |
-| <a name="instance_security_permissionHandler" class="prop"></a> instance.security.permissionHandler | The permission handler class that accumulo will use to determine if a user has privilege to perform an action<br>**type:** CLASSNAME, **zk mutable:** no, **default value:** `org.apache.accumulo.server.security.handler.ZKPermHandler` |
+| <a name="instance_security_authenticator" class="prop"></a> instance.security.authenticator | The authenticator class that accumulo will use to determine if a user has privilege to perform an action<br>**type:** CLASSNAME, **zk mutable:** no, **default value:** {% jlink -f org.apache.accumulo.server.security.handler.ZKAuthenticator %} |
+| <a name="instance_security_authorizor" class="prop"></a> instance.security.authorizor | The authorizor class that accumulo will use to determine what labels a user has privilege to see<br>**type:** CLASSNAME, **zk mutable:** no, **default value:** {% jlink -f org.apache.accumulo.server.security.handler.ZKAuthorizor %} |
+| <a name="instance_security_permissionHandler" class="prop"></a> instance.security.permissionHandler | The permission handler class that accumulo will use to determine if a user has privilege to perform an action<br>**type:** CLASSNAME, **zk mutable:** no, **default value:** {% jlink -f org.apache.accumulo.server.security.handler.ZKPermHandler %} |
 | <a name="instance_volumes" class="prop"></a> instance.volumes | A comma seperated list of dfs uris to use. Files will be stored across these filesystems. If this is empty, then instance.dfs.uri will be used. After adding uris to this list, run 'accumulo init --add-volume' and then restart tservers. If entries are removed from this list then tservers will need to be restarted. After a uri is removed from the list Accumulo will not create new files in that location, however Accumulo can  [...]
 | <a name="instance_volumes_replacements" class="prop"></a> instance.volumes.replacements | Since accumulo stores absolute URIs changing the location of a namenode could prevent Accumulo from starting. The property helps deal with that situation. Provide a comma separated list of uri replacement pairs here if a namenode location changes. Each pair shold be separated with a space. For example, if hdfs://nn1 was replaced with hdfs://nnA and hdfs://nn2 was replaced with hdfs://nnB, then set [...]
 | <a name="instance_zookeeper_host" class="prop"></a> instance.zookeeper.host | Comma separated list of zookeeper servers<br>**type:** HOSTLIST, **zk mutable:** no, **default value:** `localhost:2181` |
@@ -70,8 +70,8 @@ Below are properties set in `accumulo-site.xml` or the Accumulo shell that confi
 | <a name="master_server_threadcheck_time" class="prop"></a> master.server.threadcheck.time | The time between adjustments of the server thread pool.<br>**type:** TIMEDURATION, **zk mutable:** yes, **default value:** `1s` |
 | <a name="master_server_threads_minimum" class="prop"></a> master.server.threads.minimum | The minimum number of threads to use to handle incoming requests.<br>**type:** COUNT, **zk mutable:** yes, **default value:** `20` |
 | <a name="master_status_threadpool_size" class="prop"></a> master.status.threadpool.size | The number of threads to use when fetching the tablet server status for balancing.  Zero indicates an unlimited number of threads will be used.<br>**type:** COUNT, **zk mutable:** yes, **default value:** `0` |
-| <a name="master_tablet_balancer" class="prop"></a> master.tablet.balancer | The balancer class that accumulo will use to make tablet assignment and migration decisions.<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** `org.apache.accumulo.server.master.balancer.TableLoadBalancer` |
-| <a name="master_walog_closer_implementation" class="prop"></a> master.walog.closer.implementation | A class that implements a mechanism to steal write access to a write-ahead log<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** `org.apache.accumulo.server.master.recovery.HadoopLogCloser` |
+| <a name="master_tablet_balancer" class="prop"></a> master.tablet.balancer | The balancer class that accumulo will use to make tablet assignment and migration decisions.<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** {% jlink -f org.apache.accumulo.server.master.balancer.TableLoadBalancer %} |
+| <a name="master_walog_closer_implementation" class="prop"></a> master.walog.closer.implementation | A class that implements a mechanism to steal write access to a write-ahead log<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** {% jlink -f org.apache.accumulo.server.master.recovery.HadoopLogCloser %} |
 | <a name="monitor_prefix" class="prop"></a> **monitor.*** | Properties in this category affect the behavior of the monitor web server. |
 | <a name="monitor_lock_check_interval" class="prop"></a> monitor.lock.check.interval | The amount of time to sleep between checking for the Montior ZooKeeper lock<br>**type:** TIMEDURATION, **zk mutable:** no, **default value:** `5s` |
 | <a name="monitor_port_client" class="prop"></a> monitor.port.client | The listening port for the monitor's http service<br>**type:** PORT, **zk mutable:** no, **default value:** `9995` |
@@ -100,7 +100,7 @@ Below are properties set in `accumulo-site.xml` or the Accumulo shell that confi
 | <a name="replication_receiver_threadcheck_time" class="prop"></a> replication.receiver.threadcheck.time | The time between adjustments of the replication thread pool.<br>**type:** TIMEDURATION, **zk mutable:** yes, **default value:** `30s` |
 | <a name="replication_rpc_timeout" class="prop"></a> replication.rpc.timeout | Amount of time for a single replication RPC call to last before failing the attempt. See replication.work.attempts.<br>**type:** TIMEDURATION, **zk mutable:** yes, **default value:** `2m` |
 | <a name="replication_trace_percent" class="prop"></a> replication.trace.percent | The sampling percentage to use for replication traces<br>**type:** FRACTION, **zk mutable:** yes, **default value:** `0.1` |
-| <a name="replication_work_assigner" class="prop"></a> replication.work.assigner | Replication WorkAssigner implementation to use<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** `org.apache.accumulo.master.replication.UnorderedWorkAssigner` |
+| <a name="replication_work_assigner" class="prop"></a> replication.work.assigner | Replication WorkAssigner implementation to use<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** {% jlink -f org.apache.accumulo.master.replication.UnorderedWorkAssigner %} |
 | <a name="replication_work_assignment_sleep" class="prop"></a> replication.work.assignment.sleep | Amount of time to sleep between replication work assignment<br>**type:** TIMEDURATION, **zk mutable:** yes, **default value:** `30s` |
 | <a name="replication_work_attempts" class="prop"></a> replication.work.attempts | Number of attempts to try to replicate some data before giving up and letting it naturally be retried later<br>**type:** COUNT, **zk mutable:** yes, **default value:** `10` |
 | <a name="replication_work_processor_delay" class="prop"></a> replication.work.processor.delay | Amount of time to wait before first checking for replication work, not useful outside of tests<br>**type:** TIMEDURATION, **zk mutable:** yes, **default value:** `0s` |
@@ -154,7 +154,7 @@ Below are properties set in `accumulo-site.xml` or the Accumulo shell that confi
 | <a name="table_iterator_majc_prefix" class="prop"></a> **table.iterator.majc.*** | Convenience prefix to find options for the majc iterator scope |
 | <a name="table_iterator_minc_prefix" class="prop"></a> **table.iterator.minc.*** | Convenience prefix to find options for the minc iterator scope |
 | <a name="table_iterator_scan_prefix" class="prop"></a> **table.iterator.scan.*** | Convenience prefix to find options for the scan iterator scope |
-| <a name="table_majc_compaction_strategy" class="prop"></a> table.majc.compaction.strategy | A customizable major compaction strategy.<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** `org.apache.accumulo.tserver.compaction.DefaultCompactionStrategy` |
+| <a name="table_majc_compaction_strategy" class="prop"></a> table.majc.compaction.strategy | A customizable major compaction strategy.<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** {% jlink -f org.apache.accumulo.tserver.compaction.DefaultCompactionStrategy %} |
 | <a name="table_majc_compaction_strategy_opts_prefix" class="prop"></a> **table.majc.compaction.strategy.opts.*** | Properties in this category are used to configure the compaction strategy. |
 | <a name="table_replication" class="prop"></a> table.replication | Is replication enabled for the given table<br>**type:** BOOLEAN, **zk mutable:** yes, **default value:** `false` |
 | <a name="table_replication_target_prefix" class="prop"></a> **table.replication.target.*** | Enumerate a mapping of other systems which this table should replicate their data to. The key suffix is the identifying cluster name and the value is an identifier for a location on the target system, e.g. the ID of the table on the target to replicate to |
@@ -204,7 +204,7 @@ Below are properties set in `accumulo-site.xml` or the Accumulo shell that confi
 | <a name="tserver_dir_memdump" class="prop"></a> tserver.dir.memdump | A long running scan could possibly hold memory that has been minor compacted. To prevent this, the in memory map is dumped to a local file and the scan is switched to that local file. We can not switch to the minor compacted file because it may have been modified by iterators. The file dumped to the local dir is an exact copy of what was in memory.<br>**type:** PATH, **zk mutable:** yes, **default value:** `/tmp` |
 | <a name="tserver_files_open_idle" class="prop"></a> tserver.files.open.idle | Tablet servers leave previously used RFiles open for future queries. This setting determines how much time an unused RFile should be kept open until it is closed.<br>**type:** TIMEDURATION, **zk mutable:** yes, **default value:** `1m` |
 | <a name="tserver_hold_time_max" class="prop"></a> tserver.hold.time.max | The maximum time for a tablet server to be in the "memory full" state. If the tablet server cannot write out memory in this much time, it will assume there is some failure local to its node, and quit. A value of zero is equivalent to forever.<br>**type:** TIMEDURATION, **zk mutable:** yes, **default value:** `5m` |
-| <a name="tserver_memory_manager" class="prop"></a> tserver.memory.manager | An implementation of MemoryManger that accumulo will use.<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** `org.apache.accumulo.server.tabletserver.LargestFirstMemoryManager` |
+| <a name="tserver_memory_manager" class="prop"></a> tserver.memory.manager | An implementation of MemoryManger that accumulo will use.<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** {% jlink -f org.apache.accumulo.server.tabletserver.LargestFirstMemoryManager %} |
 | <a name="tserver_memory_maps_max" class="prop"></a> tserver.memory.maps.max | Maximum amount of memory that can be used to buffer data written to a tablet server. There are two other properties that can effectively limit memory usage table.compaction.minor.logs.threshold and tserver.walog.max.size. Ensure that table.compaction.minor.logs.threshold * tserver.walog.max.size >= this property.<br>**type:** MEMORY, **zk mutable:** yes, **default value:** `33%` |
 | <a name="tserver_memory_maps_native_enabled" class="prop"></a> tserver.memory.maps.native.enabled | An in-memory data store for accumulo implemented in c++ that increases the amount of data accumulo can hold in memory and avoids Java GC pauses.<br>**type:** BOOLEAN, **zk mutable:** yes but requires restart of the tserver, **default value:** `true` |
 | <a name="tserver_metadata_readahead_concurrent_max" class="prop"></a> tserver.metadata.readahead.concurrent.max | **Deprecated.** ~~This property is deprecated since 2.0.0, use tserver.scan.executors.meta.threads instead. The maximum number of concurrent metadata read ahead that will execute.~~<br>~~**type:** COUNT~~, ~~**zk mutable:** yes~~, ~~**default value:** `8`~~ |
@@ -215,7 +215,7 @@ Below are properties set in `accumulo-site.xml` or the Accumulo shell that confi
 | <a name="tserver_readahead_concurrent_max" class="prop"></a> tserver.readahead.concurrent.max | **Deprecated.** ~~This property is deprecated since 2.0.0, use tserver.scan.executors.default.threads instead. The maximum number of concurrent read ahead that will execute. This effectively limits the number of long running scans that can run concurrently per tserver."~~<br>~~**type:** COUNT~~, ~~**zk mutable:** yes~~, ~~**default value:** `16`~~ |
 | <a name="tserver_recovery_concurrent_max" class="prop"></a> tserver.recovery.concurrent.max | The maximum number of threads to use to sort logs during recovery<br>**type:** COUNT, **zk mutable:** yes, **default value:** `2` |
 | <a name="tserver_replication_batchwriter_replayer_memory" class="prop"></a> tserver.replication.batchwriter.replayer.memory | Memory to provide to batchwriter to replay mutations for replication<br>**type:** BYTES, **zk mutable:** yes, **default value:** `50M` |
-| <a name="tserver_replication_default_replayer" class="prop"></a> tserver.replication.default.replayer | Default AccumuloReplicationReplayer implementation<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** `org.apache.accumulo.tserver.replication.BatchWriterReplicationReplayer` |
+| <a name="tserver_replication_default_replayer" class="prop"></a> tserver.replication.default.replayer | Default AccumuloReplicationReplayer implementation<br>**type:** CLASSNAME, **zk mutable:** yes, **default value:** {% jlink -f org.apache.accumulo.tserver.replication.BatchWriterReplicationReplayer %} |
 | <a name="tserver_replication_replayer_prefix" class="prop"></a> **tserver.replication.replayer.*** | Allows configuration of implementation used to apply replicated data |
 | <a name="tserver_scan_executors_prefix" class="prop"></a> **tserver.scan.executors.*** | Prefix for defining executors to service scans. See [scan executors]({% durl administration/scan-executors %}) for an overview of why and how to use this property. For each executor the number of threads, thread priority, and an optional prioritizer can be configured. To configure a new executor, set `tserver.scan.executors.<name>.threads=<number>`.  Optionally, can also set `tserver.scan.executors [...]
 | <a name="tserver_scan_executors_default_prioritizer" class="prop"></a> tserver.scan.executors.default.prioritizer | Prioritizer for the default scan executor.  Defaults to none which results in FIFO priority.  Set to a class that implements org.apache.accumulo.core.spi.scan.ScanPrioritizer to configure one.<br>**type:** STRING, **zk mutable:** yes, **default value:** empty |
diff --git a/_docs-2-0/development/summaries.md b/_docs-2-0/development/summaries.md
index 04eb8b3..d8391db 100644
--- a/_docs-2-0/development/summaries.md
+++ b/_docs-2-0/development/summaries.md
@@ -22,7 +22,7 @@ dedicated cache for summary data on each tserver with a configurable size.  In
 order for summary data to fit in cache, it should probably be small.
 
 For information on writing a custom summarizer see the javadoc of the {% jlink org.apache.accumulo.core.client.summary.Summarizer %}
-class. The package {% jlink org.apache.accumulo.core.client.summary.summarizers %}
+class. The package {% jlink -f org.apache.accumulo.core.client.summary.summarizers %}
 contains summarizer implementations that ship with Accumulo and can be configured for use.
 
 ## Inaccuracies