You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@curator.apache.org by ra...@apache.org on 2014/05/31 20:42:37 UTC

[4/9] git commit: Fixed a bunch of encoding issues on the confluence doc files

Fixed a bunch of encoding issues on the confluence doc files


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

Branch: refs/heads/curator-rpc
Commit: bef0b8b7683b65cbeb8bd6dfaf5b54858936180b
Parents: cab78e6
Author: randgalt <ra...@apache.org>
Authored: Sat May 31 11:08:52 2014 -0500
Committer: randgalt <ra...@apache.org>
Committed: Sat May 31 11:08:52 2014 -0500

----------------------------------------------------------------------
 .../src/site/confluence/index.confluence        | 14 ++++----
 .../src/site/confluence/index.confluence        | 12 +++----
 .../distributed-delay-queue.confluence          |  4 +--
 .../confluence/distributed-id-queue.confluence  |  2 +-
 .../distributed-priority-queue.confluence       |  4 +--
 .../confluence/distributed-queue.confluence     |  6 ++--
 .../src/site/confluence/index.confluence        | 38 ++++++++++----------
 .../src/site/confluence/leader-latch.confluence |  2 +-
 .../src/site/confluence/path-cache.confluence   |  2 +-
 .../site/confluence/shared-counter.confluence   |  2 +-
 .../confluence/shared-reentrant-lock.confluence |  2 +-
 .../shared-reentrant-read-write-lock.confluence | 14 ++++----
 .../site/confluence/shared-semaphore.confluence |  2 +-
 .../simple-distributed-queue.confluence         |  4 +--
 .../src/site/confluence/index.confluence        |  4 +--
 .../src/site/confluence/index.confluence        | 18 +++++-----
 .../src/site/confluence/index.confluence        |  2 +-
 src/site/confluence/errors.confluence           |  8 ++---
 src/site/confluence/exhibitor.confluence        | 12 +++----
 src/site/confluence/getting-started.confluence  |  4 +--
 src/site/confluence/index.confluence            | 24 ++++++-------
 src/site/confluence/utilities.confluence        |  8 ++---
 22 files changed, 94 insertions(+), 94 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-client/src/site/confluence/index.confluence
----------------------------------------------------------------------
diff --git a/curator-client/src/site/confluence/index.confluence b/curator-client/src/site/confluence/index.confluence
index 7d827db..d81bfab 100644
--- a/curator-client/src/site/confluence/index.confluence
+++ b/curator-client/src/site/confluence/index.confluence
@@ -1,18 +1,18 @@
 h1. Client
 
 h2. IMPORTANT NOTE
-The Curator Client is a low-level API. It is strongly recommended that you use the Curator [[Framework|../curator-framework/index.html]]
+The Curator Client is a low\-level API. It is strongly recommended that you use the Curator [[Framework|../curator-framework/index.html]]
 instead of directly using CuratorZookeeperClient.
 
 h2. Background
 CuratorZookeeperClient is a wrapper around ZooKeeper's Java client that makes client access to ZooKeeper much simpler and
 less error prone. It provides the following features:
 
-* Continuous connection management - ZooKeeper has many caveats regarding connection management (see the ZooKeeper FAQ for
+* Continuous connection management \- ZooKeeper has many caveats regarding connection management (see the ZooKeeper FAQ for
 details). CuratorZookeeperClient takes care of most of them automatically.
 
-* Operation retry utilities - a method for retrying operations is provided
-* Test ZooKeeper server - an in-process, self-contained ZooKeeper test server is provided that can be used for test cases and experimentation
+* Operation retry utilities \- a method for retrying operations is provided
+* Test ZooKeeper server \- an in\-process, self\-contained ZooKeeper test server is provided that can be used for test cases and experimentation
 
 h2. Method Documentation
 ||Method||Description||
@@ -22,10 +22,10 @@ h2. Method Documentation
 |blockUntilConnectedOrTimedOut()|A convenience method that blocks until the initial connection is successful or times out|
 |close()|Close the connection|
 |setRetryPolicy()|Change the retry policy|
-|newRetryLoop()|Allocate a new Retry Loop - see details below|
+|newRetryLoop()|Allocate a new Retry Loop \- see details below|
 
 h2. Retry Loop
-For a variety of reasons, operations on a ZooKeeper cluster can fail. Best practices dictate that these operations should be retried. The Retry Loop mechanism provides the means to do this. <b>Every operation should be wrapped in a retry loop</b>. Here's the canonical usage:
+For a variety of reasons, operations on a ZooKeeper cluster can fail. Best practices dictate that these operations should be retried. The Retry Loop mechanism provides the means to do this. *Every operation should be wrapped in a retry loop*. Here's the canonical usage:
 {code}
 RetryLoop retryLoop = client.newRetryLoop();
 while ( retryLoop.shouldContinue() )
@@ -45,7 +45,7 @@ while ( retryLoop.shouldContinue() )
 }
 {code}
 
-The Retry Loop maintains a count of retries and determines if a given error is retry-able. If an operation is a candidate for retrying, the Retry Policy is invoked to determine if the retry should proceed.
+The Retry Loop maintains a count of retries and determines if a given error is retry\-able. If an operation is a candidate for retrying, the Retry Policy is invoked to determine if the retry should proceed.
 
 As a convenience, RetryLoop has a static method that takes a Callable to perform a complete retry loop on. E.g.
 {code}

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-framework/src/site/confluence/index.confluence
----------------------------------------------------------------------
diff --git a/curator-framework/src/site/confluence/index.confluence b/curator-framework/src/site/confluence/index.confluence
index 072acff..84f794f 100644
--- a/curator-framework/src/site/confluence/index.confluence
+++ b/curator-framework/src/site/confluence/index.confluence
@@ -1,6 +1,6 @@
 h1. Framework
 
-The Curator Framework is a high-level API that greatly simplifies using ZooKeeper. It adds many features that build on
+The Curator Framework is a high\-level API that greatly simplifies using ZooKeeper. It adds many features that build on
 ZooKeeper and handles the complexity of managing connections to the ZooKeeper cluster and retrying operations. Some of the features are:
 
 * Automatic connection management:
@@ -9,7 +9,7 @@ ZooKeeper and handles the complexity of managing connections to the ZooKeeper cl
 * Cleaner API:
 ** simplifies the raw ZooKeeper methods, events, etc.
 ** provides a modern, fluent interface
-* Recipe implementations (see [[Recipes|../curator-recipes/index.html]]):
+* Recipe implementations (see [[Recipes|../curator\-recipes/index.html]]):
 ** Leader election
 ** Shared lock
 ** Path cache and watcher
@@ -19,15 +19,15 @@ ZooKeeper and handles the complexity of managing connections to the ZooKeeper cl
 
 h2. Allocating a Curator Framework Instance
 CuratorFrameworks are allocated using the CuratorFrameworkFactory which provides both factory methods and a builder for
-creating instances. IMPORTANT: CuratorFramework instances are fully thread-safe. You should share one CuratorFramework per
+creating instances. IMPORTANT: CuratorFramework instances are fully thread\-safe. You should share one CuratorFramework per
 ZooKeeper cluster in your application.
 
 The factory methods (newClient()) provide a simplified way of creating an instance. The Builder gives control over all
 parameters. Once you have a CuratorFramework instance, you must call the start() method. At the end of your application, you should call close().
 
 h2. CuratorFramework API
-The CuratorFramework uses a Fluent-style interface. Operations are constructed using builders returned by the CuratorFramework
-instance. When strung together, the methods form sentence-like statements. e.g.
+The CuratorFramework uses a Fluent\-style interface. Operations are constructed using builders returned by the CuratorFramework
+instance. When strung together, the methods form sentence\-like statements. e.g.
 {code}
 client.create().forPath("/head", new byte[0]);
 client.delete().inBackground().forPath("/head");
@@ -52,7 +52,7 @@ CuratorFramework instance using the addListener() method. The listener implement
 <td>clientClosedDueToError()|An unrecoverable error has occurred. The CuratorFramework instance has been shut down|
 
 h3. ClientEvent
-The ClientEvent object is a super-set POJO that can hold every type of background notification and triggered watch. The useful fields of
+The ClientEvent object is a super\-set POJO that can hold every type of background notification and triggered watch. The useful fields of
 ClientEvent depend on the type of event which is exposed via the getType() method.
 
 ||Event Type||Event Methods||

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/distributed-delay-queue.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/distributed-delay-queue.confluence b/curator-recipes/src/site/confluence/distributed-delay-queue.confluence
index 2755a96..9765c16 100644
--- a/curator-recipes/src/site/confluence/distributed-delay-queue.confluence
+++ b/curator-recipes/src/site/confluence/distributed-delay-queue.confluence
@@ -1,6 +1,6 @@
 h1. Distributed Delay Queue
 
-h2. *IMPORTANT* - We recommend that you do NOT use ZooKeeper for Queues. Please see [[Tech Note 4|https://cwiki.apache.org/confluence/display/CURATOR/TN4]] for details.
+h2. *IMPORTANT* \- We recommend that you do NOT use ZooKeeper for Queues. Please see [[Tech Note 4|https://cwiki.apache.org/confluence/display/CURATOR/TN4]] for details.
 
 h2. Description
 An implementation of a Distributed Delay Queue. A Delay Queue is similar to a Priority Queue. When items are added to the queue,
@@ -46,7 +46,7 @@ is a future epoch (milliseconds) when this item will be available to consumers.
 h2. Lock Safety
 In the general usage case, the message is removed from the queue prior to the consumer being called. A more atomic mode is provided
 that removes the item from the queue only after the consumer successfully returns. To enable this mode, call the {{lockPath()}}
-method of the Queue Builder. This uses a lock to make the message recoverable. A lock is held while the message is being processed - this
+method of the Queue Builder. This uses a lock to make the message recoverable. A lock is held while the message is being processed \- this
 prevents other processes from taking the message. The message will not be removed from the queue until the consumer functor returns. Thus,
 if there is a failure or the process dies, the message will get sent to another process. There is a small performance penalty for this behavior however.
 

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/distributed-id-queue.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/distributed-id-queue.confluence b/curator-recipes/src/site/confluence/distributed-id-queue.confluence
index 7afdd15..9c0b117 100644
--- a/curator-recipes/src/site/confluence/distributed-id-queue.confluence
+++ b/curator-recipes/src/site/confluence/distributed-id-queue.confluence
@@ -1,6 +1,6 @@
 h1. Distributed ID Queue
 
-h2. *IMPORTANT* - We recommend that you do NOT use ZooKeeper for Queues. Please see [[Tech Note 4|https://cwiki.apache.org/confluence/display/CURATOR/TN4]] for details.
+h2. *IMPORTANT* \- We recommend that you do NOT use ZooKeeper for Queues. Please see [[Tech Note 4|https://cwiki.apache.org/confluence/display/CURATOR/TN4]] for details.
 
 h2. Description
 This is an alternate version of [[Distributed Queue|distributed-queue.html]] that supports assigning IDs to the items

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/distributed-priority-queue.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/distributed-priority-queue.confluence b/curator-recipes/src/site/confluence/distributed-priority-queue.confluence
index c69234a..a45834b 100644
--- a/curator-recipes/src/site/confluence/distributed-priority-queue.confluence
+++ b/curator-recipes/src/site/confluence/distributed-priority-queue.confluence
@@ -1,6 +1,6 @@
 h1. Distributed Priority Queue
 
-h2. *IMPORTANT* - We recommend that you do NOT use ZooKeeper for Queues. Please see [[Tech Note 4|https://cwiki.apache.org/confluence/display/CURATOR/TN4]] for details.
+h2. *IMPORTANT* \- We recommend that you do NOT use ZooKeeper for Queues. Please see [[Tech Note 4|https://cwiki.apache.org/confluence/display/CURATOR/TN4]] for details.
 
 h2. Description
 An implementation of the Distributed Priority Queue ZK recipe.
@@ -62,7 +62,7 @@ h2. Lock Safety
 In the general usage case, the message is removed from the queue prior to the consumer being called. A more atomic mode is
 provided that removes the item from the queue only after the consumer successfully returns. To enable this mode, call the
 {{lockPath()}} method of the Queue Builder. This uses a lock to make the message recoverable. A lock is held while the
-message is being processed - this prevents other processes from taking the message. The message will not be removed from the queue
+message is being processed \- this prevents other processes from taking the message. The message will not be removed from the queue
 until the consumer functor returns. Thus, if there is a failure or the process dies, the message will get sent to another process.
 There is a small performance penalty for this behavior however.
 

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/distributed-queue.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/distributed-queue.confluence b/curator-recipes/src/site/confluence/distributed-queue.confluence
index f3102e4..e80f015 100644
--- a/curator-recipes/src/site/confluence/distributed-queue.confluence
+++ b/curator-recipes/src/site/confluence/distributed-queue.confluence
@@ -1,6 +1,6 @@
 h1. Distributed Queue
 
-h2. *IMPORTANT* - We recommend that you do NOT use ZooKeeper for Queues. Please see [[Tech Note 4|https://cwiki.apache.org/confluence/display/CURATOR/TN4]] for details.
+h2. *IMPORTANT* \- We recommend that you do NOT use ZooKeeper for Queues. Please see [[Tech Note 4|https://cwiki.apache.org/confluence/display/CURATOR/TN4]] for details.
 
 h2. Description
 An implementation of the Distributed Queue ZK recipe. Items put into the queue are guaranteed to be ordered (by means of ZK's PERSISTENT_SEQUENTIAL node). If a single consumer takes items out of the queue, they will be ordered FIFO. If ordering is important, use a LeaderSelector to nominate a single consumer.
@@ -45,7 +45,7 @@ h2. Lock Safety
 In the general usage case, the message is removed from the queue prior to the consumer being called. A more
 atomic mode is provided that removes the item from the queue only after the consumer successfully returns. To
 enable this mode, call the {{lockPath()}} method of the Queue Builder. This uses a lock to make the
-message recoverable. A lock is held while the message is being processed - this prevents other processes
+message recoverable. A lock is held while the message is being processed \- this prevents other processes
 from taking the message. The message will not be removed from the queue until the consumer functor returns.
 Thus, if there is a failure or the process dies, the message will get sent to another process. There is a
 small performance penalty for this behavior however.
@@ -58,7 +58,7 @@ The Distributed queue writes messages using this format:
 |4|1|Opcode: 0x01 = message, 0x02 = End of data|
 |5|4|Message byte length|
 |9|n|Message: serialized message bytes|
-|9 + n|...|Next set of opcode-size-bytes until end of data|
+|9 + n|...|Next set of opcode\-size\-bytes until end of data|
 
 h2. Error Handling
 The {{QueueConsumer}} class extends {{ConnectionStateListener}}. When the queue is started,

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/index.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/index.confluence b/curator-recipes/src/site/confluence/index.confluence
index c37b0de..0b00ed2 100644
--- a/curator-recipes/src/site/confluence/index.confluence
+++ b/curator-recipes/src/site/confluence/index.confluence
@@ -3,34 +3,34 @@ h1. Recipes
 Curator implements all of the recipes listed on the ZooKeeper recipes doc (except two phase commit). Click on the recipe name below for detailed documentation.
 
 ||Elections||
-|[[Leader Latch|leader-latch.html]] - In distributed computing, leader election is the process of designating a single process as the organizer of some task distributed among several computers (nodes). Before the task is begun, all network nodes are unaware which node will serve as the "leader," or coordinator, of the task. After a leader election algorithm has been run, however, each node throughout the network recognizes a particular, unique node as the task leader.|
-|[[Leader Election|leader-election.html]] - Initial Curator leader election recipe.|
+|[[Leader Latch|leader-latch.html]] \- In distributed computing, leader election is the process of designating a single process as the organizer of some task distributed among several computers (nodes). Before the task is begun, all network nodes are unaware which node will serve as the "leader," or coordinator, of the task. After a leader election algorithm has been run, however, each node throughout the network recognizes a particular, unique node as the task leader.|
+|[[Leader Election|leader-election.html]] \- Initial Curator leader election recipe.|
 
 ||Locks||
-|[[Shared Reentrant Lock|shared-reentrant-lock.html]] - Fully distributed locks that are globally synchronous, meaning at any snapshot in time no two clients think they hold the same lock.|
-|[[Shared Lock|shared-lock.html]] - Similar to Shared Reentrant Lock but not reentrant.|
-|[[Shared Reentrant Read Write Lock|shared-reentrant-read-write-lock.html]] - A re-entrant read/write mutex that works across JVMs. A read write lock maintains a pair of associated locks, one for read-only operations and one for writing. The read lock may be held simultaneously by multiple reader processes, so long as there are no writers. The write lock is exclusive.|
-|[[Shared Semaphore|shared-semaphore.html]] - A counting semaphore that works across JVMs. All processes in all JVMs that use the same lock path will achieve an inter-process limited set of leases. Further, this semaphore is mostly "fair" - each user will get a lease in the order requested (from ZK's point of view).|
-|[[Multi Shared Lock|multi-shared-lock.html]] - A container that manages multiple locks as a single entity. When acquire() is called, all the locks are acquired. If that fails, any paths that were acquired are released. Similarly, when release() is called, all locks are released (failures are ignored).|
+|[[Shared Reentrant Lock|shared-reentrant-lock.html]] \- Fully distributed locks that are globally synchronous, meaning at any snapshot in time no two clients think they hold the same lock.|
+|[[Shared Lock|shared-lock.html]] \- Similar to Shared Reentrant Lock but not reentrant.|
+|[[Shared Reentrant Read Write Lock|shared-reentrant-read-write-lock.html]] \- A re\-entrant read/write mutex that works across JVMs. A read write lock maintains a pair of associated locks, one for read\-only operations and one for writing. The read lock may be held simultaneously by multiple reader processes, so long as there are no writers. The write lock is exclusive.|
+|[[Shared Semaphore|shared-semaphore.html]] \- A counting semaphore that works across JVMs. All processes in all JVMs that use the same lock path will achieve an inter\-process limited set of leases. Further, this semaphore is mostly "fair" \- each user will get a lease in the order requested (from ZK's point of view).|
+|[[Multi Shared Lock|multi-shared-lock.html]] \- A container that manages multiple locks as a single entity. When acquire() is called, all the locks are acquired. If that fails, any paths that were acquired are released. Similarly, when release() is called, all locks are released (failures are ignored).|
 
 ||Barriers||
-|[[Barrier|barrier.html]] - Distributed systems use barriers to block processing of a set of nodes until a condition is met at which time all the nodes are allowed to proceed.|
-|[[Double Barrier|double-barrier.html]] - Double barriers enable clients to synchronize the beginning and the end of a computation. When enough processes have joined the barrier, processes start their computation and leave the barrier once they have finished.|
+|[[Barrier|barrier.html]] \- Distributed systems use barriers to block processing of a set of nodes until a condition is met at which time all the nodes are allowed to proceed.|
+|[[Double Barrier|double-barrier.html]] \- Double barriers enable clients to synchronize the beginning and the end of a computation. When enough processes have joined the barrier, processes start their computation and leave the barrier once they have finished.|
 
 ||Counters||
-|[[Shared Counter|shared-counter.html]] - Manages a shared integer. All clients watching the same path will have the up-to-date value of the shared integer (considering ZK's normal consistency guarantees).|
-|[[Distributed Atomic Long|distributed-atomic-long.html]] - A counter that attempts atomic increments. It first tries using optimistic locking. If that fails, an optional InterProcessMutex is taken. For both optimistic and mutex, a retry policy is used to retry the increment.|
+|[[Shared Counter|shared-counter.html]] \- Manages a shared integer. All clients watching the same path will have the up\-to\-date value of the shared integer (considering ZK's normal consistency guarantees).|
+|[[Distributed Atomic Long|distributed-atomic-long.html]] \- A counter that attempts atomic increments. It first tries using optimistic locking. If that fails, an optional InterProcessMutex is taken. For both optimistic and mutex, a retry policy is used to retry the increment.|
 
 ||Caches||
-|[[Path Cache|path-cache.html]] - A Path Cache is used to watch a ZNode. Whenever a child is added, updated or removed, the Path Cache will change its state to contain the current set of children, the children's data and the children's state. Path caches in the Curator Framework are provided by the PathChildrenCache class. Changes to the path are passed to registered PathChildrenCacheListener instances.|
-|[[Node Cache|node-cache.html]] - A utility that attempts to keep the data from a node locally cached. This class will watch the node, respond to update/create/delete events, pull down the data, etc. You can register a listener that will get notified when changes occur.|
+|[[Path Cache|path-cache.html]] \- A Path Cache is used to watch a ZNode. Whenever a child is added, updated or removed, the Path Cache will change its state to contain the current set of children, the children's data and the children's state. Path caches in the Curator Framework are provided by the PathChildrenCache class. Changes to the path are passed to registered PathChildrenCacheListener instances.|
+|[[Node Cache|node-cache.html]] \- A utility that attempts to keep the data from a node locally cached. This class will watch the node, respond to update/create/delete events, pull down the data, etc. You can register a listener that will get notified when changes occur.|
 
 ||Nodes||
-|[[Persistent Ephemeral Node|persistent-ephemeral-node.html]] - An ephemeral node that attempts to stay present in ZooKeeper, even through connection and session interruptions..|
+|[[Persistent Ephemeral Node|persistent-ephemeral-node.html]] \- An ephemeral node that attempts to stay present in ZooKeeper, even through connection and session interruptions..|
 
 ||Queues||
-|[[Distributed Queue|distributed-queue.html]] - An implementation of the Distributed Queue ZK recipe. Items put into the queue are guaranteed to be ordered (by means of ZK's PERSISTENT_SEQUENTIAL node). If a single consumer takes items out of the queue, they will be ordered FIFO. If ordering is important, use a LeaderSelector to nominate a single consumer.|
-|[[Distributed Id Queue|distributed-id-queue.html]] - A version of DistributedQueue that allows IDs to be associated with queue items. Items can then be removed from the queue if needed.|
-|[[Distributed Priority Queue|distributed-priority-queue.html]] - An implementation of the Distributed Priority Queue ZK recipe.|
-|[[Distributed Delay Queue|distributed-delay-queue.html]] - An implementation of a Distributed Delay Queue.|
-|[[Simple Distributed Queue|simple-distributed-queue.html]] - A drop-in replacement for the DistributedQueue that comes with the ZK distribution.|
+|[[Distributed Queue|distributed-queue.html]] \- An implementation of the Distributed Queue ZK recipe. Items put into the queue are guaranteed to be ordered (by means of ZK's PERSISTENT_SEQUENTIAL node). If a single consumer takes items out of the queue, they will be ordered FIFO. If ordering is important, use a LeaderSelector to nominate a single consumer.|
+|[[Distributed Id Queue|distributed-id-queue.html]] \- A version of DistributedQueue that allows IDs to be associated with queue items. Items can then be removed from the queue if needed.|
+|[[Distributed Priority Queue|distributed-priority-queue.html]] \- An implementation of the Distributed Priority Queue ZK recipe.|
+|[[Distributed Delay Queue|distributed-delay-queue.html]] \- An implementation of a Distributed Delay Queue.|
+|[[Simple Distributed Queue|simple-distributed-queue.html]] \- A drop\-in replacement for the DistributedQueue that comes with the ZK distribution.|

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/leader-latch.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/leader-latch.confluence b/curator-recipes/src/site/confluence/leader-latch.confluence
index 2d6421a..b8b24c7 100644
--- a/curator-recipes/src/site/confluence/leader-latch.confluence
+++ b/curator-recipes/src/site/confluence/leader-latch.confluence
@@ -75,6 +75,6 @@ leaderLatch.close();
 {code}
 
 h2. Error Handling
-LeaderLatch instances add a ConnectionStateListener to watch for connection problems. If SUSPENDED or LOST is reported, the LeaderLatch that is the leader will report that it is no longer the leader (i.e. there will not be a leader until the connection is re-established). If a LOST connection is RECONNECTED, the LeaderLatch will delete its previous ZNode and create a new one.
+LeaderLatch instances add a ConnectionStateListener to watch for connection problems. If SUSPENDED or LOST is reported, the LeaderLatch that is the leader will report that it is no longer the leader (i.e. there will not be a leader until the connection is re\-established). If a LOST connection is RECONNECTED, the LeaderLatch will delete its previous ZNode and create a new one.
 
 Users of LeaderLatch must take account that connection issues can cause leadership to be lost. i.e. hasLeadership() returns true but some time later the connection is SUSPENDED or LOST. At that point hasLeadership() will return false. It is highly recommended that LeaderLatch users register a ConnectionStateListener.

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/path-cache.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/path-cache.confluence b/curator-recipes/src/site/confluence/path-cache.confluence
index 072fa5a..a8f2320 100644
--- a/curator-recipes/src/site/confluence/path-cache.confluence
+++ b/curator-recipes/src/site/confluence/path-cache.confluence
@@ -24,7 +24,7 @@ cacheData - if true, node contents are cached in addition to the stat
 h2. General Usage
 The cache must be started by calling {{start()}}. Call {{close()}} when you are through with the cache.
 
-There are two versions of {{start()}}. The no-arg version gives default behavior. The other version takes an enumeration that allows you to control how the initial cache is warmed:
+There are two versions of {{start()}}. The no\-arg version gives default behavior. The other version takes an enumeration that allows you to control how the initial cache is warmed:
 
 {code}
 public enum StartMode

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/shared-counter.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/shared-counter.confluence b/curator-recipes/src/site/confluence/shared-counter.confluence
index e05b060..3041ff1 100644
--- a/curator-recipes/src/site/confluence/shared-counter.confluence
+++ b/curator-recipes/src/site/confluence/shared-counter.confluence
@@ -1,7 +1,7 @@
 h1. Shared Counter
 
 h2. Description
-Manages a shared integer. All clients watching the same path will have the up-to-date value of the shared integer
+Manages a shared integer. All clients watching the same path will have the up\-to\-date value of the shared integer
 (considering ZK's normal consistency guarantees).
 
 h2. Participating Classes

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/shared-reentrant-lock.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/shared-reentrant-lock.confluence b/curator-recipes/src/site/confluence/shared-reentrant-lock.confluence
index ce3784c..f1e91de 100644
--- a/curator-recipes/src/site/confluence/shared-reentrant-lock.confluence
+++ b/curator-recipes/src/site/confluence/shared-reentrant-lock.confluence
@@ -43,7 +43,7 @@ Perform one release of the mutex if the calling thread is the same thread that a
 thread had made multiple calls to acquire, the mutex will still be held when this method returns.
 {code}
 
-*NOTE:* A InterProcessMutex instance is reusable. i.e. don't create a new instance every time. Re-use a single instance.
+*NOTE:* A InterProcessMutex instance is reusable. i.e. don't create a new instance every time. Re\-use a single instance.
 
 h3. Revoking
 InterProcessMutex supports a cooperative revocation mechanism as described on the ZooKeeper recipes wiki.

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/shared-reentrant-read-write-lock.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/shared-reentrant-read-write-lock.confluence b/curator-recipes/src/site/confluence/shared-reentrant-read-write-lock.confluence
index e24c57a..749680f 100644
--- a/curator-recipes/src/site/confluence/shared-reentrant-read-write-lock.confluence
+++ b/curator-recipes/src/site/confluence/shared-reentrant-read-write-lock.confluence
@@ -1,20 +1,20 @@
 h1. Shared Reentrant Read Write Lock
 
 h2. Description
-A re-entrant read/write mutex that works across JVMs. Uses Zookeeper to hold the lock. All processes in all
-JVMs that use the same lock path will achieve an inter-process critical section. Further, this mutex is "fair" -
+A re\-entrant read/write mutex that works across JVMs. Uses Zookeeper to hold the lock. All processes in all
+JVMs that use the same lock path will achieve an inter\-process critical section. Further, this mutex is "fair" -
 each user will get the mutex in the order requested (from ZK's point of view).
 
-A read write lock maintains a pair of associated locks, one for read-only operations and one for writing. The read
+A read write lock maintains a pair of associated locks, one for read\-only operations and one for writing. The read
 lock may be held simultaneously by multiple reader processes, so long as there are no writers. The write lock is exclusive.
 
 _Reentrancy_
-This lock allows both readers and writers to reacquire read or write locks in the style of a re-entrant lock.
-Non-re-entrant readers are not allowed until all write locks held by the writing thread/process have been released.
-Additionally, a writer can acquire the read lock, but not vice-versa. If a reader tries to acquire the write lock it will never succeed.
+This lock allows both readers and writers to reacquire read or write locks in the style of a re\-entrant lock.
+Non\-re\-entrant readers are not allowed until all write locks held by the writing thread/process have been released.
+Additionally, a writer can acquire the read lock, but not vice\-versa. If a reader tries to acquire the write lock it will never succeed.
 
 _Lock Downgrading_
-Re-entrancy also allows downgrading from the write lock to a read lock, by acquiring the write lock, then the read
+Re\-entrancy also allows downgrading from the write lock to a read lock, by acquiring the write lock, then the read
 lock and then releasing the write lock. However, upgrading from a read lock to the write lock is not possible.
 
 h2. Participating Classes

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/shared-semaphore.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/shared-semaphore.confluence b/curator-recipes/src/site/confluence/shared-semaphore.confluence
index 45d3d3a..2ab2de9 100644
--- a/curator-recipes/src/site/confluence/shared-semaphore.confluence
+++ b/curator-recipes/src/site/confluence/shared-semaphore.confluence
@@ -1,7 +1,7 @@
 h1. Shared Semaphore
 
 h2. Description
-A counting semaphore that works across JVMs. All processes in all JVMs that use the same lock path will achieve an inter-process limited set of leases. Further, this semaphore is mostly "fair" - each user will get a lease in the order requested (from ZK's point of view).
+A counting semaphore that works across JVMs. All processes in all JVMs that use the same lock path will achieve an inter\-process limited set of leases. Further, this semaphore is mostly "fair" \- each user will get a lease in the order requested (from ZK's point of view).
 
 There are two modes for determining the max leases for the semaphore. In the first mode the max leases is a convention maintained by the users of a given path. In the second mode a SharedCountReader is used as the method for semaphores of a given path to determine the max leases.
 

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-recipes/src/site/confluence/simple-distributed-queue.confluence
----------------------------------------------------------------------
diff --git a/curator-recipes/src/site/confluence/simple-distributed-queue.confluence b/curator-recipes/src/site/confluence/simple-distributed-queue.confluence
index eea6741..711d4e1 100644
--- a/curator-recipes/src/site/confluence/simple-distributed-queue.confluence
+++ b/curator-recipes/src/site/confluence/simple-distributed-queue.confluence
@@ -1,10 +1,10 @@
 h1. Simple Distributed Queue
 
-h2. *IMPORTANT* - We recommend that you do NOT use ZooKeeper for Queues. Please see [[Tech Note 4|https://cwiki.apache.org/confluence/display/CURATOR/TN4]] for details.
+h2. *IMPORTANT* \- We recommend that you do NOT use ZooKeeper for Queues. Please see [[Tech Note 4|https://cwiki.apache.org/confluence/display/CURATOR/TN4]] for details.
 
 h2. Description
 
-A drop-in replacement for the DistributedQueue that comes with the ZK distribution.
+A drop\-in replacement for the DistributedQueue that comes with the ZK distribution.
 
 h2. Participating Classes
 

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-test/src/site/confluence/index.confluence
----------------------------------------------------------------------
diff --git a/curator-test/src/site/confluence/index.confluence b/curator-test/src/site/confluence/index.confluence
index a9466dd..507b423 100644
--- a/curator-test/src/site/confluence/index.confluence
+++ b/curator-test/src/site/confluence/index.confluence
@@ -1,10 +1,10 @@
 h1. Testing Utilities
 
 h2. Test Server
-In the curator-test sub-model the {{TestingServer}} class is provided. This class creates a local, in-process ZooKeeper server that can be used for testing.
+In the curator\-test sub\-model the {{TestingServer}} class is provided. This class creates a local, in\-process ZooKeeper server that can be used for testing.
 
 h2. Test Cluster
-In the curator-test sub-model the {{TestingCluster}} class is provided. This class creates an internally running ensemble of ZooKeeper servers.
+In the curator\-test sub\-model the {{TestingCluster}} class is provided. This class creates an internally running ensemble of ZooKeeper servers.
 
 h2. Usage
 Look at the various Curator unit tests to see how these utilities are used.

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-x-discovery-server/src/site/confluence/index.confluence
----------------------------------------------------------------------
diff --git a/curator-x-discovery-server/src/site/confluence/index.confluence b/curator-x-discovery-server/src/site/confluence/index.confluence
index 2ff1b01..df253e9 100644
--- a/curator-x-discovery-server/src/site/confluence/index.confluence
+++ b/curator-x-discovery-server/src/site/confluence/index.confluence
@@ -1,17 +1,17 @@
 h1. Service Discovery Server
 
 h2. Packaging
-Curator Service Discovery is in its own package in Maven Central: {{curator-x-discovery-server}}
+Curator Service Discovery is in its own package in Maven Central: curator\-x\-discovery\-server
 
 h2. Description
-The Service Discovery Server bridges non-Java or legacy applications with the Curator [[Service Discovery|../curator-x-discovery/index.html]].
+The Service Discovery Server bridges non\-Java or legacy applications with the Curator [[Service Discovery|../curator-x-discovery/index.html]].
 It exposes RESTful web services to register, remove, query, etc. services.
 
-The Service Discovery Server provides JAX-RS components that can be incorporated into a container of your choice
-(Tomcat, Jetty, etc.). You can also choose any JAX-RS provider (Jersey, RESTEasy, etc.).
+The Service Discovery Server provides JAX\-RS components that can be incorporated into a container of your choice
+(Tomcat, Jetty, etc.). You can also choose any JAX\-RS provider (Jersey, RESTEasy, etc.).
 
 h2. Deploying the Server
-The server must be combined with a JAX-RS implementation (Jersey, etc.) and a container (Tomcat, Jetty, etc.).
+The server must be combined with a JAX\-RS implementation (Jersey, etc.) and a container (Tomcat, Jetty, etc.).
 
 Several singletons need to be injected:
 
@@ -21,9 +21,9 @@ Several singletons need to be injected:
 * JsonServiceInstancesMarshaller
 * JsonServiceNamesMarshaller
 
-Additionally the JAX-RS Resource class must be injected. Due to how most JAX-RS implementations are written, you must
+Additionally the JAX\-RS Resource class must be injected. Due to how most JAX\-RS implementations are written, you must
 create a concrete class that extends this using your payload type. The concrete class should have the base path that you'd like to use.
-Because the JAX-RS implementation can create a new instance of the resource for every request, your concrete class must
+Because the JAX\-RS implementation can create a new instance of the resource for every request, your concrete class must
 use a context resolver to access the DiscoveryContext. Or, if you are using an IoC framework, you can access it that way.
 
 Here's a version that has no payload (i.e. a Void payload):
@@ -46,7 +46,7 @@ h2. putService
 *Request Entity:* ServiceInstance \\
 *Response Entity:* n/a \\
 *Description:* {name} is the service name, {id} is the instance id. The request entity is a _ServiceInstance_. This
-method registers a service instance. If the ServiceType is STATIC, the instance is registered only for the pre-defined period
+method registers a service instance. If the ServiceType is STATIC, the instance is registered only for the pre\-defined period
 (defined in the DiscoveryContext). STATIC services must call putService at least once per period. PERMANENT services are registered
 until they are manually deleted.
 
@@ -87,4 +87,4 @@ h2. getAny
 *Description:* {name} is the service name. Return a random instance from the given service or 404.
 
 h2. JSON specs
-The JSON specifications for the REST entities are documented here: https://git-wip-us.apache.org/repos/asf?p=curator.git;a=blob_plain;f=curator-x-discovery-server/README.txt;hb=HEAD
+The JSON specifications for the REST entities are documented here: [[https://git-wip-us.apache.org/repos/asf?p=curator.git;a=blob_plain;f=curator-x-discovery-server/README.txt;hb=HEAD]]

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/curator-x-discovery/src/site/confluence/index.confluence
----------------------------------------------------------------------
diff --git a/curator-x-discovery/src/site/confluence/index.confluence b/curator-x-discovery/src/site/confluence/index.confluence
index 6111fe2..2a92782 100644
--- a/curator-x-discovery/src/site/confluence/index.confluence
+++ b/curator-x-discovery/src/site/confluence/index.confluence
@@ -2,7 +2,7 @@ h1. Service Discovery
 
 h2. Packaging
 
-Curator Service Discovery is in its own package in Maven Central: {{curator-x-discovery}}
+Curator Service Discovery is in its own package in Maven Central: curator\-x\-discovery
 
 h2. What Is a Discovery Service?
 

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/src/site/confluence/errors.confluence
----------------------------------------------------------------------
diff --git a/src/site/confluence/errors.confluence b/src/site/confluence/errors.confluence
index 24639fb..28805e0 100644
--- a/src/site/confluence/errors.confluence
+++ b/src/site/confluence/errors.confluence
@@ -23,10 +23,10 @@ Curator exposes several listenable interfaces for clients to monitor the state o
 appropriate action. These are the possible state changes:
 
 |CONNECTED|Sent for the first successful connection to the server. NOTE: You will only get one of these messages for any CuratorFramework instance.|
-|SUSPENDED|There has been a loss of connection. Leaders, locks, etc. should suspend until the connection is re-established. If the connection times-out you will receive a LOST notice.|
-|RECONNECTED|A suspended or lost connection has been re-established.|
-|LOST|The connection is confirmed to be lost. Close any locks, leaders, etc. and attempt to re-create them. NOTE: it is possible to get a RECONNECTED state after this but you should still consider any locks, etc. as dirty/unstable.|
-|READ_ONLY|The connection has gone into read-only mode. This can only happen if you pass true for CuratorFrameworkFactory.Builder.canBeReadOnly(). See the ZooKeeper doc regarding read only connections: [[http://wiki.apache.org/hadoop/ZooKeeper/GSoCReadOnlyMode]]. The connection will remain in read only mode until another state change is sent.|
+|SUSPENDED|There has been a loss of connection. Leaders, locks, etc. should suspend until the connection is re\-established. If the connection times\-out you will receive a LOST notice.|
+|RECONNECTED|A suspended or lost connection has been re\-established.|
+|LOST|The connection is confirmed to be lost. Close any locks, leaders, etc. and attempt to re\-create them. NOTE: it is possible to get a RECONNECTED state after this but you should still consider any locks, etc. as dirty/unstable.|
+|READ_ONLY|The connection has gone into read\-only mode. This can only happen if you pass true for CuratorFrameworkFactory.Builder.canBeReadOnly(). See the ZooKeeper doc regarding read only connections: [[http://wiki.apache.org/hadoop/ZooKeeper/GSoCReadOnlyMode]]. The connection will remain in read only mode until another state change is sent.|
 
 {{UnhandledErrorListener}} is called when a background task, etc. catches an exception. In general, Curator users shouldn't care
 about these as they are logged. However, you can listen for them if you choose.

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/src/site/confluence/exhibitor.confluence
----------------------------------------------------------------------
diff --git a/src/site/confluence/exhibitor.confluence b/src/site/confluence/exhibitor.confluence
index 7df24fa..156ff50 100644
--- a/src/site/confluence/exhibitor.confluence
+++ b/src/site/confluence/exhibitor.confluence
@@ -12,13 +12,13 @@ using the framework). Pass an {{EnsembleProvider}} to the {{ensembleProvider()}}
 h2. EnsembleProvider
 
 For Exhibitor, construct an instance of {{ExhibitorEnsembleProvider}} to pass to the builder. It takes a number of arguments:
-* exhibitors - a list of the exhibitor instances. This is the initial set of Exhibitor instances. This set will get automatically updated if it changes.
-* restClient - a simple facade to access the Exhibitor instances via REST. Use the provided {{DefaultExhibitorRestClient}} or something else of your choosing.
-* restUriPath - the REST path to use. In most cases this should be: {{/exhibitor/v1/cluster/list}}
-* pollingMs - how often to poll the Exhibitor instances
-* retryPolicy - the retry policy to use when polling the Exhibitor instances.
+* exhibitors \- a list of the exhibitor instances. This is the initial set of Exhibitor instances. This set will get automatically updated if it changes.
+* restClient \- a simple facade to access the Exhibitor instances via REST. Use the provided {{DefaultExhibitorRestClient}} or something else of your choosing.
+* restUriPath \- the REST path to use. In most cases this should be: {{/exhibitor/v1/cluster/list}}
+* pollingMs \- how often to poll the Exhibitor instances
+* retryPolicy \- the retry policy to use when polling the Exhibitor instances.
 
 h2. Details
 
-Once configured, Curator will poll the Exhibitors for changes in the ensemble. If Curator should need to re-create the ZooKeeper
+Once configured, Curator will poll the Exhibitors for changes in the ensemble. If Curator should need to re\-create the ZooKeeper
 instance (due to a SysDisconnected event, etc.) it will use the updated ensemble list to do so.

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/src/site/confluence/getting-started.confluence
----------------------------------------------------------------------
diff --git a/src/site/confluence/getting-started.confluence b/src/site/confluence/getting-started.confluence
index 03a77db..3199ddb 100644
--- a/src/site/confluence/getting-started.confluence
+++ b/src/site/confluence/getting-started.confluence
@@ -9,8 +9,8 @@ h2. Using Curator
 The Curator JARs are available from Maven Central. The various artifacts are listed on the [[main page|index.html]]. Users
 of Maven, Gradle, Ant, etc. can easily include Curator into their build script.
 
-Most users will want to use one of Curator's pre-built recipes. So, the {{curator-recipes}} is the correct artifact to use. If you only
-want a wrapper around ZooKeeper that adds connection management and retry policies, use {{curator-framework}}.
+Most users will want to use one of Curator's pre\-built recipes. So, the curator-recipes is the correct artifact to use. If you only
+want a wrapper around ZooKeeper that adds connection management and retry policies, use curator-framework.
 
 h2. Getting a Connection
 

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/src/site/confluence/index.confluence
----------------------------------------------------------------------
diff --git a/src/site/confluence/index.confluence b/src/site/confluence/index.confluence
index b67a6a7..724097c 100644
--- a/src/site/confluence/index.confluence
+++ b/src/site/confluence/index.confluence
@@ -2,7 +2,7 @@ h1. Welcome to Apache Curator
 
 h2. What is Curator?
 
-Curator _n &#x02c8;kyoor&#x035d;&#x02cc;&#x0101;t&#x0259;r_: a keeper or custodian of a museum or other collection - A ZooKeeper Keeper.
+Curator _n &#x02c8;kyoor&#x035d;&#x02cc;&#x0101;t&#x0259;r_: a keeper or custodian of a museum or other collection \- A ZooKeeper Keeper.
 
 !images/ph-quote.png!
 
@@ -13,22 +13,22 @@ See the page for quick start: [[Getting Started|getting-started.html]].
 h2. Components
 
 |[[Recipes|curator-recipes/index.html]]|Implementations of some of the common ZooKeeper "recipes". The implementations are built on top of the Curator Framework.|
-|[[Framework|curator-framework/index.html]]|The Curator Framework is a high-level API that greatly simplifies using ZooKeeper. It adds many features that build on ZooKeeper and handles the complexity of managing connections to the ZooKeeper cluster and retrying operations.|
+|[[Framework|curator-framework/index.html]]|The Curator Framework is a high\-level API that greatly simplifies using ZooKeeper. It adds many features that build on ZooKeeper and handles the complexity of managing connections to the ZooKeeper cluster and retrying operations.|
 |[[Utilities|utilities.html]]|Various utilities that are useful when using ZooKeeper.|
-|[[Client|curator-client/index.html]]|A replacement for the bundled {{ZooKeeper}} class that takes care of some low-level housekeeping and provides some useful utilities.|
+|[[Client|curator-client/index.html]]|A replacement for the bundled {{ZooKeeper}} class that takes care of some low\-level housekeeping and provides some useful utilities.|
 |[[Errors|errors.html]]|How Curator deals with errors, connection issues, recoverable exceptions, etc.|
-|Extensions|The curator-recipes package implements the common recipes that are described in the ZooKeeper documentation. To avoid bloating that package, recipes/applications that have a vertical appeal will be put in separate "extension" packages using the naming convention curator-x-name.|
+|Extensions|The curator\-recipes package implements the common recipes that are described in the ZooKeeper documentation. To avoid bloating that package, recipes/applications that have a vertical appeal will be put in separate "extension" packages using the naming convention curator\-x\-name.|
 
 h2. Maven / Artifacts
 
 Curator binaries are published to Maven Central. Curator consists of several artifacts. Which artifacts to use depends on your needs. For
-most users, the only artifact you need is {{curator-recipes}}.
+most users, the only artifact you need is curator\-recipes.
 
 ||GroupID/Org||ArtifactID/Name||Description||
-|org.apache.curator|curator-recipes|All of the recipes. Note: this artifact has dependencies on client and framework and, so, Maven (or whatever tool you're using) should pull those in automatically.|
-|org.apache.curator|curator-framework|The Curator Framework high level API. This is built on top of the client and should pull it in automatically.|
-|org.apache.curator|curator-client|The Curator Client - replacement for the ZooKeeper class in the ZK distribution.|
-|org.apache.curator|curator-test|Contains the TestingServer, the TestingCluster and a few other tools useful for testing.|
-|org.apache.curator|curator-examples|Example usages of various Curator features.|
-|org.apache.curator|curator-x-discovery|A Service Discovery implementation built on the Curator Framework.|
-|org.apache.curator|curator-x-discovery-server|A RESTful server that can be used with Curator Discovery.|
+|org.apache.curator|curator\-recipes|All of the recipes. Note: this artifact has dependencies on client and framework and, so, Maven (or whatever tool you're using) should pull those in automatically.|
+|org.apache.curator|curator\-framework|The Curator Framework high level API. This is built on top of the client and should pull it in automatically.|
+|org.apache.curator|curator\-client|The Curator Client \- replacement for the ZooKeeper class in the ZK distribution.|
+|org.apache.curator|curator\-test|Contains the TestingServer, the TestingCluster and a few other tools useful for testing.|
+|org.apache.curator|curator\-examples|Example usages of various Curator features.|
+|org.apache.curator|curator\-x\-discovery|A Service Discovery implementation built on the Curator Framework.|
+|org.apache.curator|curator\-x\-discovery-server|A RESTful server that can be used with Curator Discovery.|

http://git-wip-us.apache.org/repos/asf/curator/blob/bef0b8b7/src/site/confluence/utilities.confluence
----------------------------------------------------------------------
diff --git a/src/site/confluence/utilities.confluence b/src/site/confluence/utilities.confluence
index d4b5ccb..7a8e95f 100644
--- a/src/site/confluence/utilities.confluence
+++ b/src/site/confluence/utilities.confluence
@@ -1,10 +1,10 @@
 h1. Utilities
 
 h2. Test Server
-In the curator-test sub-model the {{TestingServer}} class is provided. This class creates a local, in-process ZooKeeper server that can be used for testing.
+In the curator\-test sub\-model the {{TestingServer}} class is provided. This class creates a local, in\-process ZooKeeper server that can be used for testing.
 
 h2. Test Cluster
-In the curator-test sub-model the {{TestingCluster}} class is provided. This class creates an internally running ensemble of ZooKeeper servers.
+In the curator\-test sub\-model the {{TestingCluster}} class is provided. This class creates an internally running ensemble of ZooKeeper servers.
 
 h2. ZKPaths
 Various static methods to help with using ZooKeeper ZNode paths:
@@ -16,7 +16,7 @@ Various static methods to help with using ZooKeeper ZNode paths:
 
 h2. EnsurePath
 Utility to ensure that a particular path is created.
-The first time it is used, a synchronized call to {{ZKPaths.mkdirs(ZooKeeper, String)}} is made to ensure that the entire path has been created (with an empty byte array if needed). Subsequent calls with the instance are un-synchronized NOPs.
+The first time it is used, a synchronized call to {{ZKPaths.mkdirs(ZooKeeper, String)}} is made to ensure that the entire path has been created (with an empty byte array if needed). Subsequent calls with the instance are un\-synchronized NOPs.
 
 Usage:
 {code}
@@ -40,7 +40,7 @@ A queue consumer that provides behavior similar to a the JDK's BlockingQueue.
 
 h2. QueueSharder
 
-Due to limitations in ZooKeeper's transport layer, a single queue will break if it has more than 10K-ish items in it. This class
+Due to limitations in ZooKeeper's transport layer, a single queue will break if it has more than 10K\-ish items in it. This class
 provides a facade over multiple distributed queues. It monitors the queues and if any one of them goes over a threshold, a new
 queue is added. Puts are distributed amongst the queues.