Java Code Examples for org.apache.zookeeper.Watcher.Event.EventType
The following are top voted examples for showing how to use
org.apache.zookeeper.Watcher.Event.EventType. These examples are extracted from open source projects.
You can vote up the examples you like and your votes will be used in our system to generate
more good examples.
Example 1
Project: TakinRPC File: ZkClient.java View source code | 6 votes |
private void processDataOrChildChange(WatchedEvent event) { final String path = event.getPath(); if (event.getType() == EventType.NodeChildrenChanged || event.getType() == EventType.NodeCreated || event.getType() == EventType.NodeDeleted) { Set<IZkChildListener> childListeners = _childListener.get(path); if (childListeners != null && !childListeners.isEmpty()) { fireChildChangedEvents(path, childListeners); } } if (event.getType() == EventType.NodeDataChanged || event.getType() == EventType.NodeDeleted || event.getType() == EventType.NodeCreated) { Set<IZkDataListener> listeners = _dataListener.get(path); if (listeners != null && !listeners.isEmpty()) { fireDataChangedEvents(event.getPath(), listeners); } } }
Example 2
Project: ZooKeeper File: DataTree.java View source code | 6 votes |
public Stat setData(String path, byte data[], int version, long zxid, long time) throws KeeperException.NoNodeException { Stat s = new Stat(); DataNode n = nodes.get(path); if (n == null) { throw new KeeperException.NoNodeException(); } byte lastdata[] = null; synchronized (n) { lastdata = n.data; n.data = data; n.stat.setMtime(time); n.stat.setMzxid(zxid); n.stat.setVersion(version); n.copyStat(s); } // now update if the path is in a quota subtree. String lastPrefix; if((lastPrefix = getMaxPrefixWithQuota(path)) != null) { this.updateBytes(lastPrefix, (data == null ? 0 : data.length) - (lastdata == null ? 0 : lastdata.length)); } dataWatches.triggerWatch(path, EventType.NodeDataChanged); return s; }
Example 3
Project: TITAN File: MasterElection.java View source code | 6 votes |
@Override public void process(WatchedEvent event) { ZooKeeper zkClient = zookeeperConnManager.getZkClient(); try { /* 重新注册节点 */ zkClient.exists(nodePath, this); EventType eventType = event.getType(); switch (eventType) { case NodeDeleted: election(); break; default: break; } } catch (Exception e) { log.error("error", e); } }
Example 4
Project: TITAN File: WatchAgents.java View source code | 6 votes |
@Override public void process(WatchedEvent event) { ZooKeeper zkClient = zookeeperConnManager.getZkClient(); try { /* 重新注册节点 */ List<String> childrens = zkClient.getChildren(nodePath, this); EventType eventType = event.getType(); switch (eventType) { case NodeChildrenChanged: log.info("当前注册中心内的成功注册的agent数量-->" + childrens.stream().filter(children -> children.startsWith("agent")).count()); break; default: break; } } catch (Exception e) { log.error("error", e); } }
Example 5
Project: fuck_zookeeper File: DataTree.java View source code | 6 votes |
public Stat setData(String path, byte data[], int version, long zxid, long time) throws KeeperException.NoNodeException { Stat s = new Stat(); DataNode n = nodes.get(path); if (n == null) { throw new KeeperException.NoNodeException(); } byte lastdata[] = null; synchronized (n) { lastdata = n.data; n.data = data; n.stat.setMtime(time); n.stat.setMzxid(zxid); n.stat.setVersion(version); n.copyStat(s); } // now update if the path is in a quota subtree. String lastPrefix; if((lastPrefix = getMaxPrefixWithQuota(path)) != null) { this.updateBytes(lastPrefix, (data == null ? 0 : data.length) - (lastdata == null ? 0 : lastdata.length)); } dataWatches.triggerWatch(path, EventType.NodeDataChanged); return s; }
Example 6
Project: ZooKeeper File: WatchEventWhenAutoReset.java View source code | 6 votes |
@Test public void testNodeCreated() throws Exception { QuorumUtil qu = new QuorumUtil(1); qu.startAll(); EventsWatcher watcher = new EventsWatcher(); ZooKeeper zk1 = createClient(qu, 1, watcher); ZooKeeper zk2 = createClient(qu, 2); String path = "/test1-created"; zk1.exists(path, watcher); qu.shutdown(1); zk2.create(path, new byte[2], ZooDefs.Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); qu.start(1); watcher.waitForConnected(TIMEOUT * 1000L); watcher.assertEvent(TIMEOUT, EventType.NodeCreated); qu.shutdownAll(); }
Example 7
Project: fuck_zookeeper File: WatcherFuncTest.java View source code | 6 votes |
public void process(WatchedEvent event) { if (event.getState() == KeeperState.SyncConnected) { if (latch != null) { latch.countDown(); } } if (event.getType() == EventType.None) { return; } try { events.put(event); } catch (InterruptedException e) { Assert.assertTrue("interruption unexpected", false); } }
Example 8
Project: fuck_zookeeper File: WatchEventWhenAutoReset.java View source code | 6 votes |
@Test public void testNodeCreated() throws Exception { QuorumUtil qu = new QuorumUtil(1); qu.startAll(); EventsWatcher watcher = new EventsWatcher(); ZooKeeper zk1 = createClient(qu, 1, watcher); ZooKeeper zk2 = createClient(qu, 2); String path = "/test1-created"; zk1.exists(path, watcher); qu.shutdown(1); zk2.create(path, new byte[2], ZooDefs.Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); qu.start(1); watcher.waitForConnected(TIMEOUT * 1000L); watcher.assertEvent(TIMEOUT, EventType.NodeCreated); qu.shutdownAll(); }
Example 9
Project: fuck_zookeeper File: WatchEventWhenAutoReset.java View source code | 6 votes |
@Test public void testNodeChildrenChanged() throws Exception { QuorumUtil qu = new QuorumUtil(1); qu.startAll(); EventsWatcher watcher = new EventsWatcher(); ZooKeeper zk1 = createClient(qu, 1, watcher); ZooKeeper zk2 = createClient(qu, 2); String path = "/test-children-changed"; zk1.create(path, new byte[1], ZooDefs.Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); zk1.getChildren(path, watcher); qu.shutdown(1); zk2.create(path + "/children-1", new byte[2], ZooDefs.Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); qu.start(1); watcher.waitForConnected(TIMEOUT * 1000L); watcher.assertEvent(TIMEOUT, EventType.NodeChildrenChanged); qu.shutdownAll(); }
Example 10
Project: fuck_zookeeper File: ZooInspectorManagerImpl.java View source code | 6 votes |
public void process(WatchedEvent event) { if (!closed) { try { if (event.getType() != EventType.NodeDeleted) { Stat s = zooKeeper.exists(nodePath, this); if (s != null) { zookeeper.getChildren(nodePath, this); } } } catch (Exception e) { LoggerFactory.getLogger().error( "Error occured re-adding node watcherfor node " + nodePath, e); } nodeListener.processEvent(event.getPath(), event.getType() .name(), null); } }
Example 11
Project: otter-G File: ZkClientx.java View source code | 6 votes |
private void processDataOrChildChange(WatchedEvent event) { final String path = event.getPath(); if (event.getType() == EventType.NodeChildrenChanged || event.getType() == EventType.NodeCreated || event.getType() == EventType.NodeDeleted) { Set<IZkChildListener> childListeners = _childListener.get(path); if (childListeners != null && !childListeners.isEmpty()) { fireChildChangedEvents(path, childListeners); } } if (event.getType() == EventType.NodeDataChanged || event.getType() == EventType.NodeDeleted || event.getType() == EventType.NodeCreated) { Set<IZkDataListener> listeners = _dataListener.get(path); if (listeners != null && !listeners.isEmpty()) { fireDataChangedEvents(event.getPath(), listeners); } } }
Example 12
Project: https-github.com-apache-zookeeper File: ClientCnxn.java View source code | 6 votes |
private void queueEvent(WatchedEvent event, Set<Watcher> materializedWatchers) { if (event.getType() == EventType.None && sessionState == event.getState()) { return; } sessionState = event.getState(); final Set<Watcher> watchers; if (materializedWatchers == null) { // materialize the watchers based on the event watchers = watcher.materialize(event.getState(), event.getType(), event.getPath()); } else { watchers = new HashSet<Watcher>(); watchers.addAll(materializedWatchers); } WatcherSetEventPair pair = new WatcherSetEventPair(watchers, event); // queue the pair (watch set & event) for later processing waitingEvents.add(pair); }
Example 13
Project: ZooKeeper File: ZooInspectorManagerImpl.java View source code | 6 votes |
public void process(WatchedEvent event) { if (!closed) { try { if (event.getType() != EventType.NodeDeleted) { Stat s = zooKeeper.exists(nodePath, this); if (s != null) { zookeeper.getChildren(nodePath, this); } } } catch (Exception e) { LoggerFactory.getLogger().error( "Error occurred re-adding node watcherfor node " + nodePath, e); } nodeListener.processEvent(event.getPath(), event.getType() .name(), null); } }
Example 14
Project: https-github.com-apache-zookeeper File: RemoveWatchesCmdTest.java View source code | 6 votes |
/** * Test verifies deletion of NodeChildrenChanged watches */ @Test(timeout = 30000) public void testRemoveNodeChildrenChangedWatches() throws Exception { List<EventType> expectedEvents = new ArrayList<Watcher.Event.EventType>(); expectedEvents.add(EventType.ChildWatchRemoved); MyWatcher myWatcher = new MyWatcher("/testnode1", expectedEvents, 1); zk.create("/testnode1", "data".getBytes(), Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); LOG.info("Adding child changed watcher"); zk.getChildren("/testnode1", myWatcher); String cmdstring = "removewatches /testnode1 -c"; LOG.info("Remove watchers using shell command : {}", cmdstring); zkMain.cl.parseCommand(cmdstring); Assert.assertTrue("Removewatches cmd fails to remove child watches", zkMain.processZKCmd(zkMain.cl)); myWatcher.matches(); Assert.assertEquals( "Failed to remove child watches : " + zk.getChildWatches(), 0, zk.getChildWatches().size()); }
Example 15
Project: https-github.com-apache-zookeeper File: WatcherFuncTest.java View source code | 6 votes |
public void process(WatchedEvent event) { if (event.getState() == KeeperState.SyncConnected) { if (latch != null) { latch.countDown(); } } if (event.getType() == EventType.None) { return; } try { events.put(event); } catch (InterruptedException e) { Assert.assertTrue("interruption unexpected", false); } }
Example 16
Project: ZooKeeper File: ZooInspectorManagerImpl.java View source code | 6 votes |
public void process(WatchedEvent event) { if (!closed) { try { if (event.getType() != EventType.NodeDeleted) { Stat s = zooKeeper.exists(nodePath, this); if (s != null) { zookeeper.getChildren(nodePath, this); } } } catch (Exception e) { LoggerFactory.getLogger().error( "Error occurred re-adding node watcherfor node " + nodePath, e); } nodeListener.processEvent(event.getPath(), event.getType() .name(), null); } }
Example 17
Project: https-github.com-apache-zookeeper File: WatchEventWhenAutoResetTest.java View source code | 6 votes |
@Test public void testNodeCreated() throws Exception { QuorumUtil qu = new QuorumUtil(1); qu.startAll(); EventsWatcher watcher = new EventsWatcher(); ZooKeeper zk1 = createClient(qu, 1, watcher); ZooKeeper zk2 = createClient(qu, 2); String path = "/test1-created"; zk1.exists(path, watcher); qu.shutdown(1); zk2.create(path, new byte[2], ZooDefs.Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); qu.start(1); watcher.waitForConnected(TIMEOUT * 1000L); watcher.assertEvent(TIMEOUT, EventType.NodeCreated); qu.shutdownAll(); }
Example 18
Project: https-github.com-apache-zookeeper File: WatchEventWhenAutoResetTest.java View source code | 6 votes |
@Test public void testNodeChildrenChanged() throws Exception { QuorumUtil qu = new QuorumUtil(1); qu.startAll(); EventsWatcher watcher = new EventsWatcher(); ZooKeeper zk1 = createClient(qu, 1, watcher); ZooKeeper zk2 = createClient(qu, 2); String path = "/test-children-changed"; zk1.create(path, new byte[1], ZooDefs.Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); zk1.getChildren(path, watcher); qu.shutdown(1); zk2.create(path + "/children-1", new byte[2], ZooDefs.Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); qu.start(1); watcher.waitForConnected(TIMEOUT * 1000L); watcher.assertEvent(TIMEOUT, EventType.NodeChildrenChanged); qu.shutdownAll(); }
Example 19
Project: ZooKeeper File: WatcherFuncTest.java View source code | 6 votes |
public void process(WatchedEvent event) { if (event.getState() == KeeperState.SyncConnected) { if (latch != null) { latch.countDown(); } } if (event.getType() == EventType.None) { return; } try { events.put(event); } catch (InterruptedException e) { Assert.assertTrue("interruption unexpected", false); } }
Example 20
Project: jsf-core File: ZkClient.java View source code | 6 votes |
private void processDataOrChildChange(WatchedEvent event) { final String path = event.getPath(); if (event.getType() == EventType.NodeChildrenChanged || event.getType() == EventType.NodeCreated || event.getType() == EventType.NodeDeleted) { Set<IZkChildListener> childListeners = _childListener.get(path); if (childListeners != null && !childListeners.isEmpty()) { fireChildChangedEvents(path, childListeners); } } if (event.getType() == EventType.NodeDataChanged || event.getType() == EventType.NodeDeleted || event.getType() == EventType.NodeCreated) { Set<IZkDataListener> listeners = _dataListener.get(path); if (listeners != null && !listeners.isEmpty()) { fireDataChangedEvents(event.getPath(), listeners); } } }
Example 21
Project: ZooKeeper File: DataTreeV1.java View source code | 6 votes |
public Stat setData(String path, byte data[], int version, long zxid, long time) throws KeeperException.NoNodeException { Stat s = new Stat(); DataNodeV1 n = nodes.get(path); if (n == null) { throw new KeeperException.NoNodeException(); } synchronized (n) { n.data = data; n.stat.setMtime(time); n.stat.setMzxid(zxid); n.stat.setVersion(version); n.copyStat(s); } dataWatches.triggerWatch(path, EventType.NodeDataChanged); return s; }
Example 22
Project: ZooKeeper File: Zab1_0Test.java View source code | 5 votes |
@Override public void process(WatchedEvent event) { if (event.getType() == EventType.NodeDataChanged) { synchronized(this) { changed = true; notifyAll(); } } }
Example 23
Project: ZooKeeper File: DisconnectedWatcherTest.java View source code | 5 votes |
@Test public void testDefaultWatcherAutoResetWithChroot() throws Exception { ZooKeeper zk1 = createClient(); zk1.create("/ch1", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); MyWatcher watcher = new MyWatcher(); ZooKeeper zk2 = createClient(watcher, hostPort + "/ch1"); zk2.getChildren("/", true ); // this call shouldn't trigger any error or watch zk1.create("/youdontmatter1", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); // this should trigger the watch zk1.create("/ch1/youshouldmatter1", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); WatchedEvent e = watcher.events.poll(TIMEOUT, TimeUnit.MILLISECONDS); Assert.assertNotNull(e); Assert.assertEquals(EventType.NodeChildrenChanged, e.getType()); Assert.assertEquals("/", e.getPath()); zk2.getChildren("/", true ); stopServer(); watcher.waitForDisconnected(3000); startServer(); watcher.waitForConnected(3000); // this should trigger the watch zk1.create("/ch1/youshouldmatter2", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); e = watcher.events.poll(TIMEOUT, TimeUnit.MILLISECONDS); Assert.assertNotNull(e); Assert.assertEquals(EventType.NodeChildrenChanged, e.getType()); Assert.assertEquals("/", e.getPath()); }
Example 24
Project: ZooKeeper File: WatcherTest.java View source code | 5 votes |
public void process(WatchedEvent event) { super.process(event); if (event.getType() != Event.EventType.None) { timeOfLastWatcherInvocation = System.currentTimeMillis(); try { events.put(event); } catch (InterruptedException e) { LOG.warn("ignoring interrupt during event.put"); } } }
Example 25
Project: ZooKeeper File: ClientCnxn.java View source code | 5 votes |
public void queueEvent(WatchedEvent event) { if (event.getType() == EventType.None && sessionState == event.getState()) { return; } sessionState = event.getState(); // materialize the watchers based on the event WatcherSetEventPair pair = new WatcherSetEventPair( watcher.materialize(event.getState(), event.getType(), event.getPath()), event); // queue the pair (watch set & event) for later processing waitingEvents.add(pair); }
Example 26
Project: ZooKeeper File: EventTypeTest.java View source code | 5 votes |
@Test public void testIntConversion() { // Ensure that we can convert all valid integers to EventTypes EnumSet<EventType> allTypes = EnumSet.allOf(EventType.class); for(EventType et : allTypes) { Assert.assertEquals(et, EventType.fromInt( et.getIntValue() ) ); } }
Example 27
Project: ZooKeeper File: WatchEventWhenAutoReset.java View source code | 5 votes |
@Test public void testNodeDataChanged() throws Exception { QuorumUtil qu = new QuorumUtil(1); qu.startAll(); EventsWatcher watcher = new EventsWatcher(); ZooKeeper zk1 = createClient(qu, 1, watcher); ZooKeeper zk2 = createClient(qu, 2); String path = "/test-changed"; zk1.create(path, new byte[1], ZooDefs.Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); zk1.getData(path, watcher, null); qu.shutdown(1); zk2.delete(path, -1); zk2.create(path, new byte[2], ZooDefs.Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); qu.start(1); watcher.waitForConnected(TIMEOUT); watcher.assertEvent(TIMEOUT, EventType.NodeDataChanged); zk1.exists(path, watcher); qu.shutdown(1); zk2.delete(path, -1); zk2.create(path, new byte[2], ZooDefs.Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); qu.start(1); watcher.waitForConnected(TIMEOUT * 1000L); watcher.assertEvent(TIMEOUT, EventType.NodeDataChanged); qu.shutdownAll(); }
Example 28
Project: fuck_zookeeper File: ClientCnxn.java View source code | 5 votes |
private void startConnect() throws IOException { state = States.CONNECTING; InetSocketAddress addr; if (rwServerAddress != null) { addr = rwServerAddress; rwServerAddress = null; } else { addr = hostProvider.next(1000); } setName(getName().replaceAll("\\(.*\\)", "(" + addr.getHostName() + ":" + addr.getPort() + ")")); if (ZooKeeperSaslClient.isEnabled()) { try { String principalUserName = System.getProperty( ZK_SASL_CLIENT_USERNAME, "zookeeper"); zooKeeperSaslClient = new ZooKeeperSaslClient( principalUserName+"/"+addr.getHostName()); } catch (LoginException e) { // An authentication error occurred when the SASL client tried to initialize: // for Kerberos this means that the client failed to authenticate with the KDC. // This is different from an authentication error that occurs during communication // with the Zookeeper server, which is handled below. LOG.warn("SASL configuration failed: " + e + " Will continue connection to Zookeeper server without " + "SASL authentication, if Zookeeper server allows it."); eventThread.queueEvent(new WatchedEvent( Watcher.Event.EventType.None, Watcher.Event.KeeperState.AuthFailed, null)); saslLoginFailed = true; } } logStartConnect(addr); clientCnxnSocket.connect(addr); }
Example 29
Project: fuck_zookeeper File: ClientCnxn.java View source code | 5 votes |
/** * Callback invoked by the ClientCnxnSocket once a connection has been * established. * * @param _negotiatedSessionTimeout * @param _sessionId * @param _sessionPasswd * @param isRO * @throws IOException */ void onConnected(int _negotiatedSessionTimeout, long _sessionId, byte[] _sessionPasswd, boolean isRO) throws IOException { negotiatedSessionTimeout = _negotiatedSessionTimeout; if (negotiatedSessionTimeout <= 0) { state = States.CLOSED; eventThread.queueEvent(new WatchedEvent( Watcher.Event.EventType.None, Watcher.Event.KeeperState.Expired, null)); eventThread.queueEventOfDeath(); String warnInfo; warnInfo = "Unable to reconnect to ZooKeeper service, session 0x" + Long.toHexString(sessionId) + " has expired"; LOG.warn(warnInfo); throw new SessionExpiredException(warnInfo); } if (!readOnly && isRO) { LOG.error("Read/write client got connected to read-only server"); } readTimeout = negotiatedSessionTimeout * 2 / 3; connectTimeout = negotiatedSessionTimeout / hostProvider.size(); hostProvider.onConnected(); sessionId = _sessionId; sessionPasswd = _sessionPasswd; state = (isRO) ? States.CONNECTEDREADONLY : States.CONNECTED; seenRwServerBefore |= !isRO; LOG.info("Session establishment complete on server " + clientCnxnSocket.getRemoteSocketAddress() + ", sessionid = 0x" + Long.toHexString(sessionId) + ", negotiated timeout = " + negotiatedSessionTimeout + (isRO ? " (READ-ONLY mode)" : "")); KeeperState eventState = (isRO) ? KeeperState.ConnectedReadOnly : KeeperState.SyncConnected; eventThread.queueEvent(new WatchedEvent( Watcher.Event.EventType.None, eventState, null)); }
Example 30
Project: fuck_zookeeper File: GenerateLoad.java View source code | 5 votes |
public void process(WatchedEvent event) { System.err.println(event); synchronized (this) { if (event.getType() == EventType.None) { connected = (event.getState() == KeeperState.SyncConnected); notifyAll(); } } }
Example 31
Project: fuck_zookeeper File: GenerateLoad.java View source code | 5 votes |
public void process(WatchedEvent event) { if (event.getType() == Watcher.Event.EventType.None) { synchronized (this) { connected = event.getState() == Watcher.Event.KeeperState.SyncConnected; notifyAll(); } } }
Example 32
Project: fuck_zookeeper File: ClientTest.java View source code | 5 votes |
public void process(WatchedEvent event) { super.process(event); if (event.getType() != EventType.None) { try { events.put(event); } catch (InterruptedException e) { LOG.warn("ignoring interrupt during event.put"); } } }
Example 33
Project: fuck_zookeeper File: WatchedEventTest.java View source code | 5 votes |
@Test public void testConvertingToEventWrapper() { WatchedEvent we = new WatchedEvent(EventType.NodeCreated, KeeperState.Expired, "blah"); WatcherEvent wew = we.getWrapper(); Assert.assertEquals(EventType.NodeCreated.getIntValue(), wew.getType()); Assert.assertEquals(KeeperState.Expired.getIntValue(), wew.getState()); Assert.assertEquals("blah", wew.getPath()); }
Example 34
Project: fuck_zookeeper File: DisconnectedWatcherTest.java View source code | 5 votes |
public void process(WatchedEvent event) { super.process(event); if (event.getType() != Event.EventType.None) { try { events.put(event); } catch (InterruptedException e) { LOG.warn("ignoring interrupt during event.put"); } } }
Example 35
Project: fuck_zookeeper File: DisconnectedWatcherTest.java View source code | 5 votes |
@Test public void testChildWatcherAutoResetWithChroot() throws Exception { ZooKeeper zk1 = createClient(); zk1.create("/ch1", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); MyWatcher watcher = new MyWatcher(); ZooKeeper zk2 = createClient(watcher, hostPort + "/ch1"); zk2.getChildren("/", true ); // this call shouldn't trigger any error or watch zk1.create("/youdontmatter1", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); // this should trigger the watch zk1.create("/ch1/youshouldmatter1", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); WatchedEvent e = watcher.events.poll(TIMEOUT, TimeUnit.MILLISECONDS); Assert.assertNotNull(e); Assert.assertEquals(EventType.NodeChildrenChanged, e.getType()); Assert.assertEquals("/", e.getPath()); MyWatcher childWatcher = new MyWatcher(); zk2.getChildren("/", childWatcher); stopServer(); watcher.waitForDisconnected(3000); startServer(); watcher.waitForConnected(3000); // this should trigger the watch zk1.create("/ch1/youshouldmatter2", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); e = childWatcher.events.poll(TIMEOUT, TimeUnit.MILLISECONDS); Assert.assertNotNull(e); Assert.assertEquals(EventType.NodeChildrenChanged, e.getType()); Assert.assertEquals("/", e.getPath()); }
Example 36
Project: fuck_zookeeper File: DisconnectedWatcherTest.java View source code | 5 votes |
@Test public void testDefaultWatcherAutoResetWithChroot() throws Exception { ZooKeeper zk1 = createClient(); zk1.create("/ch1", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); MyWatcher watcher = new MyWatcher(); ZooKeeper zk2 = createClient(watcher, hostPort + "/ch1"); zk2.getChildren("/", true ); // this call shouldn't trigger any error or watch zk1.create("/youdontmatter1", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); // this should trigger the watch zk1.create("/ch1/youshouldmatter1", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); WatchedEvent e = watcher.events.poll(TIMEOUT, TimeUnit.MILLISECONDS); Assert.assertNotNull(e); Assert.assertEquals(EventType.NodeChildrenChanged, e.getType()); Assert.assertEquals("/", e.getPath()); zk2.getChildren("/", true ); stopServer(); watcher.waitForDisconnected(3000); startServer(); watcher.waitForConnected(3000); // this should trigger the watch zk1.create("/ch1/youshouldmatter2", null, Ids.OPEN_ACL_UNSAFE, CreateMode.PERSISTENT); e = watcher.events.poll(TIMEOUT, TimeUnit.MILLISECONDS); Assert.assertNotNull(e); Assert.assertEquals(EventType.NodeChildrenChanged, e.getType()); Assert.assertEquals("/", e.getPath()); }
Example 37
Project: ZooKeeper File: DisconnectedWatcherTest.java View source code | 5 votes |
public void process(WatchedEvent event) { super.process(event); if (event.getType() != Event.EventType.None) { try { events.put(event); } catch (InterruptedException e) { LOG.warn("ignoring interrupt during event.put"); } } }
Example 38
Project: fuck_zookeeper File: WatcherFuncTest.java View source code | 5 votes |
@Override public void setUp() throws Exception { super.setUp(); client_latch = new CountDownLatch(1); client_dwatch = new SimpleWatcher(client_latch); client = createClient(client_dwatch, client_latch); lsnr_latch = new CountDownLatch(1); lsnr_dwatch = new SimpleWatcher(lsnr_latch); lsnr = createClient(lsnr_dwatch, lsnr_latch); expected = new ArrayList<EventType>(); }
Example 39
Project: fuck_zookeeper File: WatchEventWhenAutoReset.java View source code | 5 votes |
@Override public void process(WatchedEvent event) { super.process(event); try { if (event.getType() != Event.EventType.None) { dataEvents.put(event); } } catch (InterruptedException e) { LOG.warn("ignoring interrupt during EventsWatcher process"); } }
Example 40
Project: fuck_zookeeper File: WatchEventWhenAutoReset.java View source code | 5 votes |
public void assertEvent(long timeout, EventType eventType) { try { WatchedEvent event = dataEvents.poll(timeout, TimeUnit.MILLISECONDS); Assert.assertNotNull("do not receive a " + eventType, event); Assert.assertEquals(eventType, event.getType()); } catch (InterruptedException e) { LOG.warn("ignoring interrupt during EventsWatcher assertEvent"); } }