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 2017/07/21 16:12:57 UTC

[14/18] curator git commit: Squashed commit of the following:

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcChildData.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcChildData.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcChildData.java
deleted file mode 100644
index 2cb4462..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcChildData.java
+++ /dev/null
@@ -1,57 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftField;
-import com.facebook.swift.codec.ThriftStruct;
-import org.apache.curator.framework.recipes.cache.ChildData;
-
-@ThriftStruct("ChildData")
-public class RpcChildData
-{
-    @ThriftField(1)
-    public String path;
-
-    @ThriftField(2)
-    public RpcStat stat;
-
-    @ThriftField(3)
-    public byte[] data;
-
-    public RpcChildData()
-    {
-    }
-
-    public RpcChildData(ChildData data)
-    {
-        if ( data != null )
-        {
-            this.path = data.getPath();
-            this.stat = RpcCuratorEvent.toRpcStat(data.getStat());
-            this.data = data.getData();
-        }
-    }
-
-    public RpcChildData(String path, RpcStat stat, byte[] data)
-    {
-        this.path = path;
-        this.stat = stat;
-        this.data = data;
-    }
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCreateMode.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCreateMode.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCreateMode.java
deleted file mode 100644
index 020f283..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCreateMode.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftEnum;
-
-@ThriftEnum("CreateMode")
-public enum RpcCreateMode
-{
-    PERSISTENT,
-    PERSISTENT_SEQUENTIAL,
-    EPHEMERAL,
-    EPHEMERAL_SEQUENTIAL,
-    CONTAINER
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCuratorEvent.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCuratorEvent.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCuratorEvent.java
deleted file mode 100644
index 18591a5..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCuratorEvent.java
+++ /dev/null
@@ -1,224 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftField;
-import com.facebook.swift.codec.ThriftStruct;
-import com.google.common.base.Function;
-import com.google.common.collect.Lists;
-import org.apache.curator.framework.api.CuratorEvent;
-import org.apache.curator.framework.state.ConnectionState;
-import org.apache.zookeeper.WatchedEvent;
-import org.apache.zookeeper.data.ACL;
-import org.apache.zookeeper.data.Stat;
-import javax.annotation.Nullable;
-import java.util.List;
-
-@SuppressWarnings("deprecation")
-@ThriftStruct("CuratorEvent")
-public class RpcCuratorEvent
-{
-    @ThriftField(2)
-    public RpcCuratorEventType type;
-
-    @ThriftField(3)
-    public int resultCode;
-
-    @ThriftField(4)
-    public String path;
-
-    @ThriftField(5)
-    public String context;
-
-    @ThriftField(6)
-    public RpcStat stat;
-
-    @ThriftField(7)
-    public byte[] data;
-
-    @ThriftField(8)
-    public String name;
-
-    @ThriftField(9)
-    public List<String> children;
-
-    @ThriftField(10)
-    public List<RpcAcl> aclList;
-
-    @ThriftField(11)
-    public RpcWatchedEvent watchedEvent;
-
-    @ThriftField(12)
-    public LeaderEvent leaderEvent;
-
-    @ThriftField(13)
-    public RpcPathChildrenCacheEvent childrenCacheEvent;
-
-    public RpcCuratorEvent()
-    {
-        this.type = RpcCuratorEventType.PING;
-        this.resultCode = 0;
-        this.path = null;
-        this.context = null;
-        this.stat = null;
-        this.data = null;
-        this.name = null;
-        this.children = null;
-        this.aclList = null;
-        this.watchedEvent = null;
-        this.leaderEvent = null;
-        this.childrenCacheEvent = null;
-    }
-
-    public RpcCuratorEvent(RpcCuratorEventType type, String path)
-    {
-        this.type = type;
-        this.resultCode = 0;
-        this.path = path;
-        this.context = null;
-        this.stat = null;
-        this.data = null;
-        this.name = null;
-        this.children = null;
-        this.aclList = null;
-        this.watchedEvent = null;
-        this.leaderEvent = null;
-        this.childrenCacheEvent = null;
-    }
-
-    public RpcCuratorEvent(RpcPathChildrenCacheEvent childrenCacheEvent)
-    {
-        this.type = RpcCuratorEventType.PATH_CHILDREN_CACHE;
-        this.resultCode = 0;
-        this.path = null;
-        this.context = null;
-        this.stat = null;
-        this.data = null;
-        this.name = null;
-        this.children = null;
-        this.aclList = null;
-        this.watchedEvent = null;
-        this.leaderEvent = null;
-        this.childrenCacheEvent = childrenCacheEvent;
-    }
-
-    public RpcCuratorEvent(CuratorEvent event)
-    {
-        this.type = RpcCuratorEventType.valueOf(event.getType().name());
-        this.resultCode = event.getResultCode();
-        this.path = event.getPath();
-        this.context = (event.getContext() != null) ? String.valueOf(event.getContext()) : null;
-        this.stat = toRpcStat(event.getStat());
-        this.data = event.getData();
-        this.name = event.getName();
-        this.children = event.getChildren();
-        this.aclList = toRpcAclList(event.getACLList());
-        this.watchedEvent = toRpcWatchedEvent(event.getWatchedEvent());
-        this.leaderEvent = null;
-        this.childrenCacheEvent = null;
-    }
-
-    public RpcCuratorEvent(ConnectionState newState)
-    {
-        this.type = RpcCuratorEventType.valueOf("CONNECTION_" + newState.name());
-        this.resultCode = 0;
-        this.path = null;
-        this.context = null;
-        this.stat = null;
-        this.data = null;
-        this.name = null;
-        this.children = null;
-        this.aclList = null;
-        this.watchedEvent = null;
-        this.leaderEvent = null;
-        this.childrenCacheEvent = null;
-    }
-
-    public RpcCuratorEvent(WatchedEvent event)
-    {
-        this.type = RpcCuratorEventType.WATCHED;
-        this.resultCode = 0;
-        this.path = event.getPath();
-        this.context = null;
-        this.stat = null;
-        this.data = null;
-        this.name = null;
-        this.children = null;
-        this.aclList = null;
-        this.watchedEvent = new RpcWatchedEvent(RpcKeeperState.valueOf(event.getState().name()), RpcEventType.valueOf(event.getType().name()), event.getPath());
-        this.leaderEvent = null;
-        this.childrenCacheEvent = null;
-    }
-
-    public RpcCuratorEvent(LeaderEvent event)
-    {
-        this.type = RpcCuratorEventType.LEADER;
-        this.resultCode = 0;
-        this.path = event.path;
-        this.context = null;
-        this.stat = null;
-        this.data = null;
-        this.name = null;
-        this.children = null;
-        this.aclList = null;
-        this.watchedEvent = null;
-        this.leaderEvent = event;
-        this.childrenCacheEvent = null;
-    }
-
-    public static RpcStat toRpcStat(Stat stat)
-    {
-        if ( stat != null )
-        {
-            return new RpcStat(stat);
-        }
-        return null;
-    }
-
-    private List<RpcAcl> toRpcAclList(List<ACL> aclList)
-    {
-        if ( aclList != null )
-        {
-            return Lists.transform
-            (
-                aclList,
-                new Function<ACL, RpcAcl>()
-                {
-                    @Nullable
-                    @Override
-                    public RpcAcl apply(ACL acl)
-                    {
-                        RpcId id = new RpcId(acl.getId().getScheme(), acl.getId().getId());
-                        return new RpcAcl(acl.getPerms(), id);
-                    }
-                }
-            );
-        }
-        return null;
-    }
-
-    private RpcWatchedEvent toRpcWatchedEvent(WatchedEvent watchedEvent)
-    {
-        if ( watchedEvent != null )
-        {
-            return new RpcWatchedEvent(watchedEvent);
-        }
-        return null;
-    }
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCuratorEventType.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCuratorEventType.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCuratorEventType.java
deleted file mode 100644
index 88b4a1f..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcCuratorEventType.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftEnum;
-
-@ThriftEnum("CuratorEventType")
-public enum RpcCuratorEventType
-{
-    PING,
-    CREATE,
-    DELETE,
-    EXISTS,
-    GET_DATA,
-    SET_DATA,
-    CHILDREN,
-    SYNC,
-    GET_ACL,
-    SET_ACL,
-    WATCHED,
-    CLOSING,
-    CONNECTION_CONNECTED,
-    CONNECTION_SUSPENDED,
-    CONNECTION_RECONNECTED,
-    CONNECTION_LOST,
-    CONNECTION_READ_ONLY,
-    LEADER,
-    PATH_CHILDREN_CACHE,
-    NODE_CACHE
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcEventType.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcEventType.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcEventType.java
deleted file mode 100644
index d20adb0..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcEventType.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftEnum;
-
-@ThriftEnum("EventType")
-public enum RpcEventType
-{
-    None,
-    NodeCreated,
-    NodeDeleted,
-    NodeDataChanged,
-    NodeChildrenChanged
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcId.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcId.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcId.java
deleted file mode 100644
index 233736b..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcId.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftField;
-import com.facebook.swift.codec.ThriftStruct;
-
-@ThriftStruct("Id")
-public class RpcId
-{
-    @ThriftField(1)
-    public String scheme;
-
-    @ThriftField(2)
-    public String id;
-
-    public RpcId()
-    {
-    }
-
-    public RpcId(String scheme, String id)
-    {
-        this.scheme = scheme;
-        this.id = id;
-    }
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcKeeperState.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcKeeperState.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcKeeperState.java
deleted file mode 100644
index 8839a1d..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcKeeperState.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftEnum;
-
-@ThriftEnum("KeeperState")
-public enum RpcKeeperState
-{
-    Unknown,
-    Disconnected,
-    NoSyncConnected,
-    SyncConnected,
-    AuthFailed,
-    ConnectedReadOnly,
-    SaslAuthenticated,
-    Expired
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcParticipant.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcParticipant.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcParticipant.java
deleted file mode 100644
index f573b21..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcParticipant.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftField;
-import com.facebook.swift.codec.ThriftStruct;
-
-@ThriftStruct("Participant")
-public class RpcParticipant
-{
-    @ThriftField(1)
-    public String id;
-
-    @ThriftField(2)
-    public boolean isLeader;
-
-    public RpcParticipant()
-    {
-    }
-
-    public RpcParticipant(String id, boolean isLeader)
-    {
-        this.id = id;
-        this.isLeader = isLeader;
-    }
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPathChildrenCacheEvent.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPathChildrenCacheEvent.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPathChildrenCacheEvent.java
deleted file mode 100644
index 7f243a7..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPathChildrenCacheEvent.java
+++ /dev/null
@@ -1,54 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftField;
-import com.facebook.swift.codec.ThriftStruct;
-import org.apache.curator.framework.recipes.cache.PathChildrenCacheEvent;
-
-@ThriftStruct("PathChildrenCacheEvent")
-public class RpcPathChildrenCacheEvent
-{
-    @ThriftField(1)
-    public String cachedPath;
-
-    @ThriftField(2)
-    public RpcPathChildrenCacheEventType type;
-
-    @ThriftField(3)
-    public RpcChildData data;
-
-    public RpcPathChildrenCacheEvent()
-    {
-    }
-
-    public RpcPathChildrenCacheEvent(String cachedPath, PathChildrenCacheEvent event)
-    {
-        this.cachedPath = cachedPath;
-        type = RpcPathChildrenCacheEventType.valueOf(event.getType().name());
-        data = (event.getData() != null) ? new RpcChildData(event.getData()) : null;
-    }
-
-    public RpcPathChildrenCacheEvent(String cachedPath, RpcPathChildrenCacheEventType type, RpcChildData data)
-    {
-        this.cachedPath = cachedPath;
-        this.type = type;
-        this.data = data;
-    }
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPathChildrenCacheEventType.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPathChildrenCacheEventType.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPathChildrenCacheEventType.java
deleted file mode 100644
index 72da6d0..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPathChildrenCacheEventType.java
+++ /dev/null
@@ -1,33 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftEnum;
-
-@ThriftEnum("PathChildrenCacheEventType")
-public enum RpcPathChildrenCacheEventType
-{
-    CHILD_ADDED,
-    CHILD_UPDATED,
-    CHILD_REMOVED,
-    CONNECTION_SUSPENDED,
-    CONNECTION_RECONNECTED,
-    CONNECTION_LOST,
-    INITIALIZED
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPersistentEphemeralNodeMode.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPersistentEphemeralNodeMode.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPersistentEphemeralNodeMode.java
deleted file mode 100644
index 0e73dd3..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcPersistentEphemeralNodeMode.java
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftEnum;
-
-@ThriftEnum("PersistentEphemeralNodeMode")
-public enum RpcPersistentEphemeralNodeMode
-{
-    EPHEMERAL,
-    EPHEMERAL_SEQUENTIAL,
-    PROTECTED_EPHEMERAL,
-    PROTECTED_EPHEMERAL_SEQUENTIAL
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcStat.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcStat.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcStat.java
deleted file mode 100644
index 5e62f15..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcStat.java
+++ /dev/null
@@ -1,95 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftField;
-import com.facebook.swift.codec.ThriftStruct;
-import org.apache.zookeeper.data.Stat;
-
-@ThriftStruct("Stat")
-public class RpcStat
-{
-    @ThriftField(1)
-    public long czxid;
-
-    @ThriftField(2)
-    public long mzxid;
-
-    @ThriftField(3)
-    public long ctime;
-
-    @ThriftField(4)
-    public long mtime;
-
-    @ThriftField(5)
-    public int version;
-
-    @ThriftField(6)
-    public int cversion;
-
-    @ThriftField(7)
-    public int aversion;
-
-    @ThriftField(8)
-    public long ephemeralOwner;
-
-    @ThriftField(9)
-    public int dataLength;
-
-    @ThriftField(10)
-    public int numChildren;
-
-    @ThriftField(11)
-    public long pzxid;
-
-    public RpcStat()
-    {
-    }
-
-    public RpcStat(Stat stat)
-    {
-        czxid = stat.getCzxid();
-        mzxid = stat.getMzxid();
-        ctime = stat.getCtime();
-        mtime = stat.getMtime();
-        version = stat.getVersion();
-        cversion = stat.getCversion();
-        aversion = stat.getAversion();
-        ephemeralOwner = stat.getEphemeralOwner();
-        dataLength = stat.getDataLength();
-        numChildren = stat.getNumChildren();
-        pzxid = stat.getPzxid();
-    }
-
-    public RpcStat(long czxid, long mzxid, long ctime, long mtime, int version, int cversion, int aversion, long ephemeralOwner, int dataLength, int numChildren, long pzxid)
-    {
-        this.czxid = czxid;
-        this.mzxid = mzxid;
-        this.ctime = ctime;
-        this.mtime = mtime;
-        this.version = version;
-        this.cversion = cversion;
-        this.aversion = aversion;
-        this.ephemeralOwner = ephemeralOwner;
-        this.dataLength = dataLength;
-        this.numChildren = numChildren;
-        this.pzxid = pzxid;
-    }
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcWatchedEvent.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcWatchedEvent.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcWatchedEvent.java
deleted file mode 100644
index cc7e818..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/RpcWatchedEvent.java
+++ /dev/null
@@ -1,54 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftField;
-import com.facebook.swift.codec.ThriftStruct;
-import org.apache.zookeeper.WatchedEvent;
-
-@ThriftStruct("WatchedEvent")
-public class RpcWatchedEvent
-{
-    @ThriftField(1)
-    public RpcKeeperState keeperState;
-
-    @ThriftField(2)
-    public RpcEventType eventType;
-
-    @ThriftField(3)
-    public String path;
-
-    public RpcWatchedEvent()
-    {
-    }
-
-    public RpcWatchedEvent(WatchedEvent watchedEvent)
-    {
-        keeperState = RpcKeeperState.valueOf(watchedEvent.getState().name());
-        eventType = RpcEventType.valueOf(watchedEvent.getType().name());
-        path = watchedEvent.getPath();
-    }
-
-    public RpcWatchedEvent(RpcKeeperState keeperState, RpcEventType eventType, String path)
-    {
-        this.keeperState = keeperState;
-        this.eventType = eventType;
-        this.path = path;
-    }
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/SetDataSpec.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/SetDataSpec.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/SetDataSpec.java
deleted file mode 100644
index 0814699..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/SetDataSpec.java
+++ /dev/null
@@ -1,58 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftField;
-import com.facebook.swift.codec.ThriftStruct;
-
-@ThriftStruct
-public class SetDataSpec
-{
-    @ThriftField(1)
-    public String path;
-
-    @ThriftField(2)
-    public boolean watched;
-
-    @ThriftField(3)
-    public String asyncContext;
-
-    @ThriftField(4)
-    public boolean compressed;
-
-    @ThriftField(5)
-    public Version version;
-
-    @ThriftField(6)
-    public byte[] data;
-
-    public SetDataSpec()
-    {
-    }
-
-    public SetDataSpec(String path, boolean watched, String asyncContext, boolean compressed, Version version, byte[] data)
-    {
-        this.path = path;
-        this.watched = watched;
-        this.asyncContext = asyncContext;
-        this.compressed = compressed;
-        this.version = version;
-        this.data = data;
-    }
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/Version.java
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/Version.java b/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/Version.java
deleted file mode 100644
index 0812cdf..0000000
--- a/curator-x-rpc/src/main/java/org/apache/curator/x/rpc/idl/structs/Version.java
+++ /dev/null
@@ -1,38 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.curator.x.rpc.idl.structs;
-
-import com.facebook.swift.codec.ThriftField;
-import com.facebook.swift.codec.ThriftStruct;
-
-@ThriftStruct
-public class Version
-{
-    @ThriftField(1)
-    public int version;
-
-    public Version()
-    {
-    }
-
-    public Version(int version)
-    {
-        this.version = version;
-    }
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/resources/curator/help.txt
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/resources/curator/help.txt b/curator-x-rpc/src/main/resources/curator/help.txt
deleted file mode 100644
index 7479e23..0000000
--- a/curator-x-rpc/src/main/resources/curator/help.txt
+++ /dev/null
@@ -1,72 +0,0 @@
-Curator RPC - an RPC server for using Apache Curator APIs and recipes from non JVM languages.
-
-Arguments:
-    <none>    show this help
-    <config>  either a path to a JSON or YAML configuration file or a JSON/YAML object for
-              configuration
-
-Curator RPC uses Dropwizard for configuration. The format is JSON or YAML (your choice). Here is
-the model configuration shown in JSON with added comments. Required fields have "*" in the comment.
-
-{
-    "thrift": { // * Thrift server configuration
-        "bindAddress": "string", // address to bind to. Default is "localhost"
-        "port": int, // * port to listen on
-        "acceptBacklog": int, // default is 1024
-        "connectionLimit": int, // max concurrent connections. Default is unlimited.
-        "acceptorThreadCount": int, // default is 1
-        "ioThreadCount": int, // default is 2 * number of processors
-        "idleConnectionTimeout": "Duration", // default is 60 seconds
-        "transportName": "string", // default is "framed"
-        "protocolName": "string" // default is "binary"
-    },
-
-    "projectionExpiration": "Duration", // time for projections to expire if unused. Default is 3
-                                        // minutes.
-
-    "pingTime": "Duration", // time that the EventService will return PING if no other events.
-                            // Default is 5 seconds.
-
-    "connections": [ // * list of ZooKeeper connections
-        "name": "string", // * unique name for the connection
-        "connectionString": "string", // * ZooKeeper connection string (e.g. "host1:2181,host2:2181")
-        "sessionLength": "Duration", // duration for the session. Default is 1 minute.
-        "connectionTimeout": "Duration", // duration for connecting. Default is 15 seconds.
-        "authorization": { // Authorization spec. Default is NULL.
-            "scheme": "string", // * the authorization scheme
-            "auth": "string" // * the authorization auth
-        },
-        "namespace": "string", // Curator namespace. Default is NULL.
-        "retry": {  // Retry policy. Default is an exponential-backoff policy.
-            "type": "string", // Policy type. Either "exponential-backoff",
-                              // "bounded-exponential-backoff" or "ntimes"
-            -- Remaining values depending on type. See below --
-        },
-    ],
-
-    "logging": { // logging config - Dropwizard's logging library is used
-        See http://dropwizard.readthedocs.org/en/latest/manual/configuration.html#logging
-    }
-}
-
-"Duration" is a string. E.g. "1s" (1 second), "10m" (10 minutes)
-
-Retry Policy Specs:
-    For type: "exponential-backoff"
-        {
-            "baseSleepTime": "Duration", // default is 100 milliseconds
-            "maxRetries": int // default is 3
-        }
-
-    For type: "bounded-exponential-backoff"
-        {
-            "baseSleepTime": "Duration", // default is 100 milliseconds
-            "maxSleepTime": "Duration",  // default is 30 seconds
-            "maxRetries": int // default is 3
-        }
-
-    For type: "ntimes"
-        {
-            "sleepBetweenRetries": "Duration", // default is 100 milliseconds
-            "n": int // default is 3
-        }

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/scripts/apply-thrift.sh
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/scripts/apply-thrift.sh b/curator-x-rpc/src/main/scripts/apply-thrift.sh
deleted file mode 100755
index 535765d..0000000
--- a/curator-x-rpc/src/main/scripts/apply-thrift.sh
+++ /dev/null
@@ -1,36 +0,0 @@
-#!/bin/bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-
-if (( $# == 0 )); then
-    echo -e "usage:\n\tapply-thrift.sh <language code> <optional target directory>"
-    exit
-fi
-
-DIR="$( cd "$( dirname "${BASH_SOURCE[0]}" )" && pwd )"
-BASE_DIR="$( cd "$DIR/../../../.." && pwd )"
-
-if (( $# == 2 )); then
-    TARGET_DIR="$2"
-else
-    TARGET_DIR="$BASE_DIR/curator-x-rpc/src/test/java"
-fi
-
-thrift -gen $1 -out "$TARGET_DIR" "$BASE_DIR/curator-x-rpc/src/main/thrift/curator.thrift"

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/scripts/generate.sh
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/scripts/generate.sh b/curator-x-rpc/src/main/scripts/generate.sh
deleted file mode 100755
index ddcbff4..0000000
--- a/curator-x-rpc/src/main/scripts/generate.sh
+++ /dev/null
@@ -1,56 +0,0 @@
-#!/bin/bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-
-if (( $# != 2 )); then
-    echo -e "usage:\n\tgenerate.sh <path to swift2thrift-generator-cli-N.N.N-standalone.jar> <path to zookeeper-N.N.N.jar>"
-    exit
-fi
-
-DIR="$( cd "$( dirname "${BASH_SOURCE[0]}" )" && pwd )"
-BASE_DIR="$( cd "$DIR/../../../.." && pwd )"
-
-RPC_PATH="$BASE_DIR/curator-x-rpc/target/classes"
-
-CLASSES=""
-
-for p in services structs exceptions discovery; do
-    for f in `ls -m1 $RPC_PATH/org/apache/curator/x/rpc/idl/$p/*.class | xargs -n 1 basename | sed s/\.[^\.]*$//`; do
-        if [[ $f != *[\$]* ]]; then
-            CLASSES="$CLASSES org.apache.curator.x.rpc.idl.$p.$f";
-        fi;
-    done;
-done;
-
-THRIFT_DIR="$BASE_DIR/curator-x-rpc/src/main/thrift"
-
-PATHS="$1:$2"
-PATHS="$PATHS:$BASE_DIR/curator-client/target/classes"
-PATHS="$PATHS:$BASE_DIR/curator-framework/target/classes"
-PATHS="$PATHS:$BASE_DIR/curator-recipes/target/classes"
-PATHS="$PATHS:$BASE_DIR/curator-x-discovery/target/classes"
-PATHS="$PATHS:$RPC_PATH"
-
-java -cp $PATHS com.facebook.swift.generator.swift2thrift.Main \
-    -allow_multiple_packages org.apache.curator \
-    -namespace cpp org.apache.curator.generated \
-    -namespace java org.apache.curator.generated \
-    -out "$THRIFT_DIR/curator.thrift" \
-    $CLASSES

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/main/thrift/curator.thrift
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/main/thrift/curator.thrift b/curator-x-rpc/src/main/thrift/curator.thrift
deleted file mode 100644
index 41f2362..0000000
--- a/curator-x-rpc/src/main/thrift/curator.thrift
+++ /dev/null
@@ -1,297 +0,0 @@
-namespace java.swift org.apache.curator
-namespace cpp org.apache.curator.generated
-namespace java org.apache.curator.generated
-
-
-enum PathChildrenCacheStartMode {
-  NORMAL, BUILD_INITIAL_CACHE, POST_INITIALIZED_EVENT
-}
-
-enum CreateMode {
-  PERSISTENT, PERSISTENT_SEQUENTIAL, EPHEMERAL, EPHEMERAL_SEQUENTIAL, CONTAINER
-}
-
-enum CuratorEventType {
-  PING, CREATE, DELETE, EXISTS, GET_DATA, SET_DATA, CHILDREN, SYNC, GET_ACL, SET_ACL, WATCHED, CLOSING, CONNECTION_CONNECTED, CONNECTION_SUSPENDED, CONNECTION_RECONNECTED, CONNECTION_LOST, CONNECTION_READ_ONLY, LEADER, PATH_CHILDREN_CACHE, NODE_CACHE
-}
-
-enum EventType {
-  None, NodeCreated, NodeDeleted, NodeDataChanged, NodeChildrenChanged
-}
-
-enum KeeperState {
-  Unknown, Disconnected, NoSyncConnected, SyncConnected, AuthFailed, ConnectedReadOnly, SaslAuthenticated, Expired
-}
-
-enum PathChildrenCacheEventType {
-  CHILD_ADDED, CHILD_UPDATED, CHILD_REMOVED, CONNECTION_SUSPENDED, CONNECTION_RECONNECTED, CONNECTION_LOST, INITIALIZED
-}
-
-enum PersistentEphemeralNodeMode {
-  EPHEMERAL, EPHEMERAL_SEQUENTIAL, PROTECTED_EPHEMERAL, PROTECTED_EPHEMERAL_SEQUENTIAL
-}
-
-enum ExceptionType {
-  GENERAL, ZOOKEEPER, NODE
-}
-
-enum NodeExceptionType {
-  NONODE, BADVERSION, NODEEXISTS, NOTEMPTY
-}
-
-enum ZooKeeperExceptionType {
-  SYSTEMERROR, RUNTIMEINCONSISTENCY, DATAINCONSISTENCY, CONNECTIONLOSS, MARSHALLINGERROR, UNIMPLEMENTED, OPERATIONTIMEOUT, BADARGUMENTS, APIERROR, NOAUTH, NOCHILDRENFOREPHEMERALS, INVALIDACL, AUTHFAILED, SESSIONEXPIRED, INVALIDCALLBACK, SESSIONMOVED, NOTREADONLY
-}
-
-enum DiscoveryInstanceType {
-  DYNAMIC, STATIC, PERMANENT
-}
-
-enum ProviderStrategyType {
-  RANDOM, STICKY_RANDOM, STICKY_ROUND_ROBIN, ROUND_ROBIN
-}
-
-struct CuratorProjection {
-  1: string id;
-}
-
-struct ExistsSpec {
-  1: string path;
-  2: bool watched;
-  3: string asyncContext;
-}
-
-struct GetChildrenSpec {
-  1: string path;
-  2: bool watched;
-  3: string asyncContext;
-}
-
-struct GetDataSpec {
-  1: string path;
-  2: bool watched;
-  3: string asyncContext;
-  4: bool decompressed;
-}
-
-struct LeaderEvent {
-  1: string path;
-  2: string participantId;
-  3: bool isLeader;
-}
-
-struct LeaderProjection {
-  1: string id;
-}
-
-struct LeaderResult {
-  1: LeaderProjection projection;
-  2: bool isLeader;
-}
-
-struct LeaseProjection {
-  1: string id;
-}
-
-struct LockProjection {
-  1: string id;
-}
-
-struct NodeCacheProjection {
-  1: string id;
-}
-
-struct OptionalChildrenList {
-  1: list<string> children;
-}
-
-struct OptionalData {
-  1: binary data;
-}
-
-struct OptionalLockProjection {
-  1: LockProjection lockProjection;
-}
-
-struct OptionalPath {
-  1: string path;
-}
-
-struct PathChildrenCacheProjection {
-  1: string id;
-}
-
-struct PersistentEphemeralNodeProjection {
-  1: string id;
-}
-
-struct Id {
-  1: string scheme;
-  2: string id;
-}
-
-struct Participant {
-  1: string id;
-  2: bool isLeader;
-}
-
-struct Stat {
-  1: i64 czxid;
-  2: i64 mzxid;
-  3: i64 ctime;
-  4: i64 mtime;
-  5: i32 version;
-  6: i32 cversion;
-  7: i32 aversion;
-  8: i64 ephemeralOwner;
-  9: i32 dataLength;
-  10: i32 numChildren;
-  11: i64 pzxid;
-}
-
-struct WatchedEvent {
-  1: KeeperState keeperState;
-  2: EventType eventType;
-  3: string path;
-}
-
-struct Version {
-  1: i32 version;
-}
-
-struct DiscoveryProjection {
-  1: string id;
-}
-
-struct DiscoveryProviderProjection {
-  1: string id;
-}
-
-struct CreateSpec {
-  1: string path;
-  2: binary data;
-  3: CreateMode mode;
-  4: string asyncContext;
-  5: bool compressed;
-  6: bool creatingParentsIfNeeded;
-  7: bool withProtection;
-  8: bool creatingParentContainersIfNeeded;
-}
-
-struct DeleteSpec {
-  1: string path;
-  2: bool guaranteed;
-  3: string asyncContext;
-  4: Version version;
-}
-
-struct OptionalStat {
-  1: Stat stat;
-}
-
-struct Acl {
-  1: i32 perms;
-  2: Id id;
-}
-
-struct ChildData {
-  1: string path;
-  2: Stat stat;
-  3: binary data;
-}
-
-struct PathChildrenCacheEvent {
-  1: string cachedPath;
-  2: PathChildrenCacheEventType type;
-  3: ChildData data;
-}
-
-struct SetDataSpec {
-  1: string path;
-  2: bool watched;
-  3: string asyncContext;
-  4: bool compressed;
-  5: Version version;
-  6: binary data;
-}
-
-exception CuratorException {
-  1: ExceptionType type;
-  2: ZooKeeperExceptionType zooKeeperException;
-  3: NodeExceptionType nodeException;
-  4: string message;
-}
-
-struct DiscoveryInstance {
-  1: string name;
-  2: string id;
-  3: string address;
-  4: i32 port;
-  5: i32 sslPort;
-  6: binary payload;
-  7: i64 registrationTimeUTC;
-  8: DiscoveryInstanceType serviceType;
-  9: string uriSpec;
-}
-
-struct CuratorEvent {
-  2: CuratorEventType type;
-  3: i32 resultCode;
-  4: string path;
-  5: string context;
-  6: Stat stat;
-  7: binary data;
-  8: string name;
-  9: list<string> children;
-  10: list<Acl> aclList;
-  11: WatchedEvent watchedEvent;
-  12: LeaderEvent leaderEvent;
-  13: PathChildrenCacheEvent childrenCacheEvent;
-}
-
-service CuratorService {
-  OptionalLockProjection acquireLock(1: CuratorProjection projection, 2: string path, 3: i32 maxWaitMs) throws (1: CuratorException ex1);
-  list<LeaseProjection> acquireSemaphore(1: CuratorProjection projection, 2: string path, 3: i32 acquireQty, 4: i32 maxWaitMs, 5: i32 maxLeases) throws (1: CuratorException ex1);
-  void closeCuratorProjection(1: CuratorProjection projection);
-  bool closeGenericProjection(1: CuratorProjection projection, 2: string id) throws (1: CuratorException ex1);
-  OptionalPath createNode(1: CuratorProjection projection, 2: CreateSpec spec) throws (1: CuratorException ex1);
-  void deleteNode(1: CuratorProjection projection, 2: DeleteSpec spec) throws (1: CuratorException ex1);
-  OptionalStat exists(1: CuratorProjection projection, 2: ExistsSpec spec) throws (1: CuratorException ex1);
-  OptionalChildrenList getChildren(1: CuratorProjection projection, 2: GetChildrenSpec spec) throws (1: CuratorException ex1);
-  OptionalData getData(1: CuratorProjection projection, 2: GetDataSpec spec) throws (1: CuratorException ex1);
-  list<Participant> getLeaderParticipants(1: CuratorProjection projection, 2: LeaderProjection leaderProjection) throws (1: CuratorException ex1);
-  ChildData getNodeCacheData(1: CuratorProjection projection, 2: NodeCacheProjection cacheProjection) throws (1: CuratorException ex1);
-  list<ChildData> getPathChildrenCacheData(1: CuratorProjection projection, 2: PathChildrenCacheProjection cacheProjection) throws (1: CuratorException ex1);
-  ChildData getPathChildrenCacheDataForPath(1: CuratorProjection projection, 2: PathChildrenCacheProjection cacheProjection, 3: string path) throws (1: CuratorException ex1);
-  bool isLeader(1: CuratorProjection projection, 2: LeaderProjection leaderProjection) throws (1: CuratorException ex1);
-  CuratorProjection newCuratorProjection(1: string connectionName) throws (1: CuratorException ex1);
-  oneway void pingCuratorProjection(1: CuratorProjection projection);
-  OptionalStat setData(1: CuratorProjection projection, 2: SetDataSpec spec) throws (1: CuratorException ex1);
-  LeaderResult startLeaderSelector(1: CuratorProjection projection, 2: string path, 3: string participantId, 4: i32 waitForLeadershipMs) throws (1: CuratorException ex1);
-  NodeCacheProjection startNodeCache(1: CuratorProjection projection, 2: string path, 3: bool dataIsCompressed, 4: bool buildInitial) throws (1: CuratorException ex1);
-  PathChildrenCacheProjection startPathChildrenCache(1: CuratorProjection projection, 2: string path, 3: bool cacheData, 4: bool dataIsCompressed, 5: PathChildrenCacheStartMode startMode) throws (1: CuratorException ex1);
-  PersistentEphemeralNodeProjection startPersistentEphemeralNode(1: CuratorProjection projection, 2: string path, 3: binary data, 4: PersistentEphemeralNodeMode mode) throws (1: CuratorException ex1);
-  void sync(1: CuratorProjection projection, 2: string path, 3: string asyncContext) throws (1: CuratorException ex1);
-}
-
-service EventService {
-  CuratorEvent getNextEvent(1: CuratorProjection projection) throws (1: CuratorException ex1);
-}
-
-service DiscoveryService {
-  list<DiscoveryInstance> getAllInstances(1: CuratorProjection projection, 2: DiscoveryProviderProjection providerProjection) throws (1: CuratorException ex1);
-  DiscoveryInstance getInstance(1: CuratorProjection projection, 2: DiscoveryProviderProjection providerProjection) throws (1: CuratorException ex1);
-  DiscoveryInstance makeDiscoveryInstance(1: string name, 2: binary payload, 3: i32 port) throws (1: CuratorException ex1);
-  void noteError(1: CuratorProjection projection, 2: DiscoveryProviderProjection providerProjection, 3: string instanceId) throws (1: CuratorException ex1);
-  DiscoveryProjection startDiscovery(1: CuratorProjection projection, 2: string basePath, 3: DiscoveryInstance yourInstance) throws (1: CuratorException ex1);
-  DiscoveryProviderProjection startProvider(1: CuratorProjection projection, 2: DiscoveryProjection discoveryProjection, 3: string serviceName, 4: ProviderStrategyType providerStrategy, 5: i32 downTimeoutMs, 6: i32 downErrorThreshold) throws (1: CuratorException ex1);
-}
-
-service DiscoveryServiceLowLevel {
-  DiscoveryInstance queryForInstance(1: CuratorProjection projection, 2: DiscoveryProjection discoveryProjection, 3: string name, 4: string id) throws (1: CuratorException ex1);
-  list<DiscoveryInstance> queryForInstances(1: CuratorProjection projection, 2: DiscoveryProjection discoveryProjection, 3: string name) throws (1: CuratorException ex1);
-  list<string> queryForNames(1: CuratorProjection projection, 2: DiscoveryProjection discoveryProjection) throws (1: CuratorException ex1);
-  void registerInstance(1: CuratorProjection projection, 2: DiscoveryProjection discoveryProjection, 3: DiscoveryInstance instance) throws (1: CuratorException ex1);
-  void unregisterInstance(1: CuratorProjection projection, 2: DiscoveryProjection discoveryProjection, 3: DiscoveryInstance instance) throws (1: CuratorException ex1);
-  void updateInstance(1: CuratorProjection projection, 2: DiscoveryProjection discoveryProjection, 3: DiscoveryInstance instance) throws (1: CuratorException ex1);
-}

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/site/confluence/configuration.confluence
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/site/confluence/configuration.confluence b/curator-x-rpc/src/site/confluence/configuration.confluence
deleted file mode 100644
index 56f6cfe..0000000
--- a/curator-x-rpc/src/site/confluence/configuration.confluence
+++ /dev/null
@@ -1,143 +0,0 @@
-[[Curator RPC Proxy|index.html]] / Configuration
-
-h1. Configuration
-
-h2. Introduction
-
-Curator RPC uses [[Dropwizard|http://dropwizard.readthedocs.org/en/latest/]] for configuration. You can write the configuration in JSON or YAML.
-It can be passed to Curator RPC via a file or directly on the command line. i.e.
-
-{noformat}
-# via command line
-java -jar curator-x-rpc-VERSION.jar '{"thrift":{"port": 8080}}'
-{noformat}
-
-{noformat}
-# via file
-java -jar curator-x-rpc-VERSION.jar path/to/config.json
-{noformat}
-
-h2. Example
-
-Here is an example JSON configuration file
-
-{noformat}
-{
-    "projectionExpiration": "15s",
-
-    "thrift": {
-        "port": 1234
-    },
-
-    "pingTime": "10s",
-
-    "logging": {
-        "level": "INFO",
-
-        "appenders": [
-            {
-                "type": "file",
-                "currentLogFilename": "logs/curator-rpc.log",
-                "archivedLogFilenamePattern": "logs/curator-rpc-%d.log.gz",
-                "archivedFileCount": 10,
-                "timeZone": "UTC"
-            },
-
-            {
-                "type": "console"
-            }
-        ]
-    },
-
-    "connections": [
-        {
-            "name": "main",
-            "connectionString": "one:1,two:2",
-            "sessionLength": "3m",
-            "connectionTimeout": "20s",
-            "retry": {
-                "type": "exponential-backoff",
-                "baseSleepTime": "1s",
-                "maxRetries": 10
-            }
-        },
-
-        {
-            "name": "alt",
-            "connectionString": "three:3,four:4",
-            "sessionLength": "4m",
-            "connectionTimeout": "30s",
-            "retry": {
-                "type": "ntimes",
-                "sleepBetweenRetries": "1m",
-                "n": 10
-            }
-        }
-    ]
-}
-{noformat}
-
-
-h2. Main
-
-||Name||Type||Default Value||Description||
-|thrift|Thrift|n/a|Thrift server configuration|
-|logging|Logging|n/a|log file configuration|
-|projectionExpiration|Duration|3 minutes|Curator Projection instances will be automatically closed if not accessed within this amount of time|
-|pingTime|Duration|5 seconds|The EventService will return a PING event if this time elapses without some other event being generated|
-|connections|List of Connection|n/a|List of ZooKeeper connections|
-
-h2. Duration
-
-Durations are strings that specify a time duration. Examples:
-* "10s" \- 10 seconds
-* "100ms" \- 100 milliseconds
-* "3h" \- 3 hours
-
-h2. Thrift
-
-||Name||Type||Default Value||Required||Description||
-|port|int|_none_|*Y*|port to listen on.|
-|bindAddress|string|"localhost"|\-|Address for server to bind to|
-|idleConnectionTimeout|int|60 seconds|\-|timeout period between receiving requests from a client connection. If the timeout is exceeded (no complete requests have arrived from the client within the timeout), the server will disconnect the idle client.|
-|transportName|string|"framed"|\-|the name of the transport (frame codec) that this server will handle. The available options by default are 'unframed', 'buffered', and 'framed'. Additional modules may install other options.|
-|protocolName|string|"binary"|\-|name of the protocol that this server will speak. The available options by default are 'binary' and 'compact'. Additional modules may install other options.|
-
-h2. Logging
-
-Dropwizard's logging module is used. See the [[Dropwizard Logging Doc|http://dropwizard.readthedocs.org/en/latest/manual/configuration.html#logging]] for details
-on specifying the logging configuration.
-
-h2. Connection
-
-||Name||Type||Default Value||Required||Description||
-|name|string|_none_|*Y*|Unique name for the connection.|
-|connectionString|string|_none_|*Y*|ZooKeeper connection string (e.g. "host1:2181,host2:2181").|
-|sessionLength|Duration|1 minute|\-|duration for the ZooKeeper session|
-|connectionTimeout|Duration|15 seconds|\-|duration for connecting|
-|retry|Retry|an exponential\-backoff policy|\-|The Retry Policy to use|
-|authorization|Authorization|null|\-|Authorization spec|
-
-h2. Retry
-
-The retry policy configuration depends on what type is used. There are three types supported:
-
-||Name||Type||Default Value||Description||
-|type|string|n/a|*exponential\-backoff*|
-|baseSleepTime|Duration|100 milliseconds|The base sleep time|
-|maxRetries|int|3|The max retries|
-|\_|\_|\_|\_|
-|type|string|n/a|*bounded\-exponential\-backoff*|
-|baseSleepTime|Duration|100 milliseconds|The base sleep time|
-|maxSleepTime|Duration|30 seconds|The max sleep time|
-|maxRetries|int|3|The max retries|
-|\_|\_|\_|\_|
-|type|string|n/a|*ntimes*|
-|sleepBetweenRetries|int|100 milliseconds|sleep time between retries|
-|n|int|3|the number of retries|
-
-h2. Authorization
-
-||Name||Type||Description||
-|scheme|string|the authorization scheme|
-|auth|string|the authorization auth|

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/site/confluence/deploy.confluence
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/site/confluence/deploy.confluence b/curator-x-rpc/src/site/confluence/deploy.confluence
deleted file mode 100644
index 3f5053b..0000000
--- a/curator-x-rpc/src/site/confluence/deploy.confluence
+++ /dev/null
@@ -1,31 +0,0 @@
-[[Curator RPC Proxy|index.html]] / Deployment
-
-h1. Deployment
-
-h2. Running
-
-Curator RPC is built as an "uber" Java JAR and can be downloaded from Maven Central. Go to [[http://search.maven.org/|http://search.maven.org/#search%7Cgav%7C1%7Cg%3A%22org.apache.curator%22%20AND%20a%3A%22curator-x-rpc%22]]
-and search for "curator\-x\-rpc" and download the JAR for the latest version. This JAR can be run directly ala:
-
-{noformat}
-java -jar curator-x-rpc-VERSION.jar <argument>
-{noformat}
-
-The argument is either a configuration file or a JSON or YAML string. Call without the argument for help text. See [[Configuration|configuration.html]] for details.
-
-h2. Deploying
-
-Curator RPC is designed to have an instance of its Thrift Server co\-located on each client instance that needs to connect to ZooKeeper
-(see the figure below). Each Curator RPC instance is configured (see [[Configuration|configuration.html]]) to connect to one or more
-ZooKeeper clusters. The Curator Framework instances are maintained inside of the Curator RPC instances and RPC clients reference these instances by name.
-
-How you configure your server to launch depends on your environment and other needs. Here are some suggestions:
-
-* [Airlift Launcher|https://github.com/airlift/airlift/tree/master/launcher]
-* [Docker|https://www.docker.io/]
-* [One-JAR|http://one-jar.sourceforge.net/]
-* [Capsule|https://github.com/puniverse/capsule]
-
-h2. Topology
-
-!images/topology.png!

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/site/confluence/events.confluence
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/site/confluence/events.confluence b/curator-x-rpc/src/site/confluence/events.confluence
deleted file mode 100644
index 6a3e29b..0000000
--- a/curator-x-rpc/src/site/confluence/events.confluence
+++ /dev/null
@@ -1,90 +0,0 @@
-[[Curator RPC Proxy|index.html]] / Events
-
-h1. Events
-
-h2. Event Loop
-
-In order to receive out\-of\-bounds messages (connection state changes, watcher triggers, etc.) you must have an event loop to recieve
-messages from the EventService. Here is pseudo code:
-
-{code}
-inThread => {
-    while isOpen {
-        event = eventService.getNextEvent(curatorProjection)
-        ... process event ...
-    }
-}
-{code}
-
-*IMPORTANT:* your event handling should operate as quickly as possible. You should return to calling getNextEvent() as soon as possible.
-
-h2. Schema
-
-h3. CuratorEvent
-
-||Field||Type||Description||
-|type|CuratorEventType|The event type|
-|resultCode|int|some event types have a result code (i.e. async API calls)|
-|path|string|if there is a path associated with the event|
-|context|string|async context for async API calls|
-|stat|Stat|some event types have a ZooKeeper Stat object|
-|data|bytes|ZNode data if the event type has it|
-|name|string|ZNode name if the event type has it|
-|children|list of string|list of node names if the event type has it|
-|aclList|list of Acl|list of ACL data if the event type has it|
-|watchedEvent|WatchedEvent|if the event type is WATCHED|
-|leaderEvent|LeaderEvent|if the event type is LEADER|
-|childrenCacheEvent|PathChildrenCacheEvent|if the event type is PATH\_CHILDREN\_CACHE|
-
-h3. CuratorEventType
-
-||Value||Description||
-|PING|Returned if no events have been generated within the [[configured|configuration.html]] pingTime|
-|CREATE|Async createNode() API completion|
-|DELETE|Async deleteNode() API completion|
-|EXISTS|Async exists() API completion|
-|GET\_DATA|Async getData() API completion|
-|SET\_DATA|Async setData() API completion|
-|CHILDREN|Async getChildren() API completion|
-|SYNC|Async sync() API completion|
-|WATCHED|A watcher has triggered|
-|CONNECTION\_CONNECTED|A Curator ConnectionStateListener is installed. This event is for the initial successful connection.|
-|CONNECTION\_SUSPENDED|A Curator ConnectionStateListener is installed. This event means the connection has been suspended.|
-|CONNECTION\_RECONNECTED|A Curator ConnectionStateListener is installed. This event means the connection has been reconnected.|
-|CONNECTION\_LOST|A Curator ConnectionStateListener is installed. This event means the connection has been lost.|
-|CONNECTION\_READ\_ONLY|A Curator ConnectionStateListener is installed. This event means the connection has changed to read only.|
-|LEADER|A Leader recipe event|
-|PATH\_CHILDREN\_CACHE|A path children cache event|
-|NODE\_CACHE|The node for a node cache has changed|
-
-h3. LeaderEvent
-
-||Field||Type||Description||
-|path|string|The leader's path|
-|participantId|string|The participant ID for the event being reported|
-|isLeader|bool|if true, this participant is being made leader. If false, it is losing leadership.|
-
-h3. PathChildrenCacheEvent
-
-||Field||Type||Description||
-|cachedPath|name|The path being cached|
-|type|PathChildrenCacheEventType|cache event type|
-|data|ChildData|data for the child ZNode|
-
-h3. PathChildrenCacheEventType
-
-Values:     CHILD\_ADDED,
-            CHILD\_UPDATED,
-            CHILD\_REMOVED,
-            CONNECTION\_SUSPENDED,
-            CONNECTION\_RECONNECTED,
-            CONNECTION\_LOST,
-            INITIALIZED
-
-h3. ChildData
-
-||Field||Type||Description||
-|path|string|The ZNode path|
-|stat|Stat|ZooKeeper Stat object|
-|data|bytes|ZNode data (if the cache is configured to cache data)|
-

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/site/confluence/index.confluence
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/site/confluence/index.confluence b/curator-x-rpc/src/site/confluence/index.confluence
deleted file mode 100644
index 70077ac..0000000
--- a/curator-x-rpc/src/site/confluence/index.confluence
+++ /dev/null
@@ -1,49 +0,0 @@
-h1. Curator RPC Proxy
-
-h2. Packaging
-
-Curator RPC Proxy is in its own package in Maven Central: curator\-x\-rpc
-
-h2. What Is a Curator RPC?
-
-The Curator RPC module implements a proxy that bridges non\-java environments with the Curator framework and recipes. It uses
-[[Apache Thrift|http://thrift.apache.org]] which supports a large set of languages and environments.
-
-The benefits of Curator RPC are:
-
-* Gives access to Curator to non JVM languages/environments
-** Curator has become the de\-facto JVM client library for ZooKeeper
-** Curator makes using Apache ZooKeeper much easier
-** Curator contains well\-tested recipes for many common ZooKeeper usages
-* Organizations can unify their ZooKeeper usage across languages/environments (i.e. use Curator's Service Discovery recipe)
-* The quality of ZooKeeper clients for some non\-JVM languages is lacking
-* There are Thrift implementations for a large number of languages/environments
-
-h2. Thrift File
-
-The current Curator RPC Thrift File can be found here: [[https://raw.githubusercontent.com/apache/curator/master/curator-x-rpc/src/main/thrift/curator.thrift]]. Use
-this to generate code for the language/environment you need.
-
-h2. Deployment
-
-See the [[Deployment Page|deploy.html]] for details on deploying the RPC proxy.
-
-h2. Usage
-
-See the [[Usage Page|usage.html]] for details on using the RPC proxy.
-
-h2. Configuration
-
-See [[Configuration|configuration.html]] for details on configuring the RPC proxy.
-
-h2. Events
-
-See [[Events|events.html]] for details on the Curator RPC event loop and its structure.
-
-h2. Reference
-
-See [[API Reference Page|reference.html]] for the API reference.
-
-----
-
-Special thanks to the [[Facebook Swift|https://github.com/facebook/swift/]] project which makes writing a Java Thrift server much easier.

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/site/confluence/reference.confluence
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/site/confluence/reference.confluence b/curator-x-rpc/src/site/confluence/reference.confluence
deleted file mode 100644
index bb7ea46..0000000
--- a/curator-x-rpc/src/site/confluence/reference.confluence
+++ /dev/null
@@ -1,120 +0,0 @@
-[[Curator RPC Proxy|index.html]] / Reference
-
-h1. API Reference
-
-h2. CuratorService
-
-||API||Arguments||Return Value||Description||
-|newCuratorProjection|connectionName|CuratorProjection|Allocates a projection to a configured CuratorFramework instance in the RPC server. "connectionName" is the name of a [[configured|configuration.html]] connection.|
-|closeCuratorProjection|CuratorProjection|void|Close a CuratorProjection. Also closes any recipes, etc. created for the projection.|
-|pingCuratorProjection|CuratorProjection|void|Keeps the CuratorProjection from timing out. NOTE: your [[EventService|events.html]] event loop will do this for you.|
-|createNode|CreateSpec|Created path name|Create a ZNode|
-|deleteNode|DeleteSpec|void|Delete a ZNode|
-|getData|GetDataSpec|bytes|Return a ZNode's data|
-|setData|SetDataSpec|Stat|Set a ZNode's data|
-|exists|ExistsSpec|Stat|Check if a ZNode exists|
-|getChildren|GetChildrenSpec|List of nodes|Get the child nodes for a ZNode|
-|sync|path and async context|void|Do a ZooKeeper sync|
-|closeGenericProjection|id|void|Closes any projection. All projections have an "id" field. This is the value to pass.|
-|acquireLock|path, maxWaitMs|optional lock projection|Acquire a lock for the given path. Will wait at most maxWaitMs to acquire the lock. If the acquisition fails, result will be null.|
-|startLeaderSelector|path, participantId, waitForLeadershipMs|LeaderResult|Start a leader selector on the given path. The instance will be assigned the specified participantId. If waitForLeadershipMs is non\-zero, the method will block for that amount of time waiting for leadership.|
-|getLeaderParticipants|leaderProjection|List of Participant|Return the participants in a leader selector|
-|isLeader|leaderProjection|bool|Return true if the specified projection is the current leader|
-|startPathChildrenCache|path, cacheData, dataIsCompressed, startMode|cache projection|Start a PathChildrenCache for the given path. Can optionally cache data, use compressed data.|
-|getPathChildrenCacheData|cacheProjection|List of ChildData|Get all the data for a path cache|
-|getPathChildrenCacheDataForPath|cacheProjection, path|ChildData|Get the data for a single ZNode in a path cache|
-|startNodeCache|path, dataIsCompressed, buildInitial|node cache projection|Start a node cache for the given path. Can optionally use compressed data and build the initial cache.|
-|getNodeCacheData|node cache projection|ChildData|Return the data for the cached node. If the node doesn't exist, the fields of the ChildData object will be null.|
-|startPersistentEphemeralNode|path, data, mode|projection|Start a PersistentEphemeralNode for the given path using the given data and mode.|
-|acquireSemaphore|path, acquireQty, maxWaitMs, maxLeases|List of lease projections|Acquire one or more leases for a semaphore on the given path. acquireQty is the number of leases to acquire. maxWaitMs is the max time to wait to get the leases. maxLeases is the maximum leases to allow for the semaphore. If the number of leases cannot be acquired within the max time, an empty list is returned.|
-
-h2. EventService
-
-||API||Arguments||Return Value||Description||
-|getNextEvent|CuratorProjection|CuratorEvent|Returns the next queued event for the given CuratorProjection. If no events are queued within the [[configured|configuration.html]] ping time, a PING event is returned.|
-
-See the [[Events Page|events.html]] for the CuratorEvent schema reference.
-
-h2. DiscoveryService
-
-||API||Arguments||Return Value||Description||
-|makeDiscoveryInstance|name, payload, port|DiscoveryInstance|Return a completed DiscoveryInstance using the RPC server's address and the given name, payload and port.|
-|startDiscovery|basePath, yourInstance|discovery projection|Start a Service Discovery instance on the given path. If yourInstance is not null it will be registered as the local service.|
-|startProvider|discoveryProjection, serviceName, providerStrategy, downTimeoutMs, downErrorThreshold|provider projection|start a Service Discovery Provider to return instances for the given service name using the given provider strategy. Specify "down" instance characteristics with downTimeoutMs and downErrorThreshold.|
-|getInstance|provider projection|DiscoveryInstance|Return a single instance for the given service|
-|getAllInstances|provider projection|list of DiscoveryInstance|Return all instances for the given service|
-|noteError|provider projection, service id|void|Note an error for the given service instance|
-
-h1. Struct Reference
-
-h2. CreateSpec
-
-||Field||Type||Required||Description||
-|path|string|*Y*|the ZNode path|
-|data|bytes|\-|data for the node|
-|mode|CreateMode|\-|PERSISTENT, PERSISTENT\_SEQUENTIAL, EPHEMERAL, or EPHEMERAL\_SEQUENTIAL|
-|asyncContext|string|\-|if not null, createNode() is performed asynchronously and this is the context used in the async message|
-|compressed|bool|\-|if true, compress the data|
-|creatingParentsIfNeeded|bool|\-|if true, create any needed parent nodes|
-|withProtection|bool|\-|if true, use Curator protection|
-|creatingParentContainersIfNeeded|bool|\-|if true, create any needed parent nodes as CONTAINERs|
-
-h2. DeleteSpec
-
-||Field||Type||Required||Description||
-|path|string|*Y*|the ZNode path|
-|guaranteed|bool|\-|if true, use guaranteed deletion|
-|asyncContext|string|\-|if not null, createNode() is performed asynchronously and this is the context used in the async message|
-|compressed|bool|\-|if true, compress the data|
-|version|Version|\-|if not null, uses Version.version when deleting the node. Otherwise, \-1 is used.|
-
-h2. GetDataSpec
-
-||Field||Type||Required||Description||
-|path|string|*Y*|the ZNode path|
-|watched|bool|\-|if true, trigger watch events for this node|
-|asyncContext|string|\-|if not null, createNode() is performed asynchronously and this is the context used in the async message|
-|decompressed|bool|\-|if true, decompress the data|
-
-h2. SetDataSpec
-
-||Field||Type||Required||Description||
-|path|string|*Y*|the ZNode path|
-|data|bytes|*Y*|data for the node|
-|watched|bool|\-|if true, trigger watch events for this node|
-|asyncContext|string|\-|if not null, createNode() is performed asynchronously and this is the context used in the async message|
-|compressed|bool|\-|if true, compress the data|
-|version|Version|\-|if not null, uses Version.version when setting the node data. Otherwise, \-1 is used.|
-
-h2. ExistsSpec
-
-||Field||Type||Required||Description||
-|path|string|*Y*|the ZNode path|
-|watched|bool|\-|if true, trigger watch events for this node|
-|asyncContext|string|\-|if not null, createNode() is performed asynchronously and this is the context used in the async message|
-
-h2. GetChildrenSpec
-
-||Field||Type||Required||Description||
-|path|string|*Y*|the ZNode path|
-|watched|bool|\-|if true, trigger watch events for this node|
-|asyncContext|string|\-|if not null, createNode() is performed asynchronously and this is the context used in the async message|
-
-h2. LeaderResult
-
-||Field||Type||Description||
-|projection|LeaderProjection|the projection of the leader|
-|isLeader|bool|true if this projection is the leader|
-
-h2. Participant
-
-||Field||Type||Description||
-|id|string|participant id|
-|isLeader|bool|true if this participant is the leader|
-
-h2. ChildData
-
-||Field||Type||Description||
-|path|string|the ZNode path|
-|stat|Stat|ZooKeeper stat for the node|
-|data|bytes|node data or null|

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/site/confluence/usage.confluence
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/site/confluence/usage.confluence b/curator-x-rpc/src/site/confluence/usage.confluence
deleted file mode 100644
index 047ae5e..0000000
--- a/curator-x-rpc/src/site/confluence/usage.confluence
+++ /dev/null
@@ -1,115 +0,0 @@
-[[Curator RPC Proxy|index.html]] / Usage
-
-h1. Usage
-
-h2. Thrift File
-
-The first step in using the RPC Proxy is to process the Curator RPC Thrift file into your desired language/environment.
-The current Curator RPC Thrift File can be found here: [[https://raw.githubusercontent.com/apache/curator/master/curator-x-rpc/src/main/thrift/curator.thrift]].
-Details on using Apache Thrift can be found here: [[http://thrift.apache.org]].
-
-h2. Prerequisites
-
-It's assumed you are already familiar with ZooKeeper and Curator. Also, familiarity with writing Thrift applications is helpful.
-
-h2. Services
-
-Three Thrift Services are included with the Curator RPC:
-
-||Service||Description||
-|CuratorService|The main service for accessing the Curator APIs and recipes|
-|EventService|Used to receive out\-of\-band messages for callbacks, watchers, etc. See [Events|events.html] for details.|
-|DiscoveryService|Curator's ServiceDiscovery recipe|
-
-h2. Concepts
-
-h4. Projections
-
-Many of the Curator RPC APIs refer to "projections" (e.g. CuratorProjection). A projection is an id that refers
-to a real object instance inside of the RPC server. The projection is a "handle" or "cookie" that directly refers to that instance.
-
-h4. Thrift Client Equals a Thread
-
-It's important to remember that each thrift client is the equivalent of a system thread. i.e. you cannot have multiple outstanding
-calls in multiple threads with a given client. For each thread, you should allocate a separate client. A Thrift Client maps directly
-to a single TCP/IP socket.
-
-h4. Event Loop
-
-You must dedicate a separate thread for getting events via the Curator RPC [EventService|events.html]. Curator will report async results,
-connection state changes, watcher triggers, etc. via this event loop.
-
-h4. CuratorProjection Expiration
-
-If you don't make an API call using a CuratorProjection within the [configured timeout|configuration.html] the projection instance
-will be closed and any open recipes, etc. associated with it will be closed. NOTE: calls to the EventService will cause the
-CuratorProjection to be "touched". So, as long as your event loop is running your CuratorProjection instance will be kept open.
-
-h2. Initialization
-
-After setting up Thrift, create a connection to the CuratorService and the EventService. If you plan on using Curator Discovery, create a connection
-to DiscoveryService. Allocate a CuratorProjection instance and then start a thread watching events for that instance. Here is pseudo code:
-
-{code}
-CuratorService.Client curatorService = new CuratorService.Client()
-EventService.Client eventService = new EventService.Client()
-
-curatorProjection = curatorService.newCuratorProjection(name)
-
-inThread => {
-    while isOpen {
-        event = eventService.getNextEvent(curatorProjection)
-        ... process event ...
-    }
-}
-
-... in your application shutdown
-client.closeCuratorProjection(curatorProjection)
-{code}
-
-h2. Usage
-
-Once initialized, use recipes/APIs as needed. Here is an example of using the lock recipe:
-
-{code}
-optionalLock = client.acquireLock(curatorProjection, "/mylock", 10000)
-if optionalLock.lockProjection == null {
-    // lock attempt failed. Throw exception, etc.
-}
-lockProjection = optionalLock.lockProjection
-
-try
-    // you now own the lock
-finally
-    client.closeGenericProjection(curatorProjection, lockProjection.id)
-{code}
-
-Here is an example of using the path cache:
-
-{code}
-cacheProjection = client.startPathChildrenCache(curatorProjection, "/path", true, false, BUILD_INITIAL_CACHE)
-
-...
-
-data = client.getPathChildrenCacheDataForPath(curatorProjection, cacheProjection, "/path/child")
-
-...
-
-// in your event loop, you will get events for the cache. e.g.
-event = eventService.getNextEvent(curatorProjection)
-if event.type == PATH_CHILDREN_CACHE {
-    if event.childrenCacheEvent.type == CHILD_UPDATED {
-        // node described by event.childrenCacheEvent.data has changed
-        // event.childrenCacheEvent.cachedPath is the path that was passed to startPathChildrenCache()
-    }
-}
-
-...
-
-// when done with the cache, close it
-client.closeGenericProjection(curatorProjection, cacheProjection.id)
-{code}
-
-h2. Reference
-
-See [[API Reference Page|reference.html]] for the API reference.

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/site/resources/images/topology.png
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/site/resources/images/topology.png b/curator-x-rpc/src/site/resources/images/topology.png
deleted file mode 100644
index cec7330..0000000
Binary files a/curator-x-rpc/src/site/resources/images/topology.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/curator/blob/95b70d2b/curator-x-rpc/src/site/site.xml
----------------------------------------------------------------------
diff --git a/curator-x-rpc/src/site/site.xml b/curator-x-rpc/src/site/site.xml
deleted file mode 100644
index fca1e73..0000000
--- a/curator-x-rpc/src/site/site.xml
+++ /dev/null
@@ -1,33 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-      http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-<project xmlns="http://maven.apache.org/DECORATION/1.1.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/DECORATION/1.1.0 http://maven.apache.org/xsd/decoration-1.1.0.xsd" name="Curator RPC Proxy">
-    <body>
-        <head>
-            <link rel="stylesheet" href="../css/site.css" />
-            <script type="text/javascript">
-                $(function(){
-                $('a[title="Curator RPC Proxy"]').parent().addClass("active");
-                });
-            </script>
-        </head>
-    </body>
-</project>