Examples of unsubscribe()


Examples of org.axonframework.saga.annotation.AsyncAnnotatedSagaManager.unsubscribe()

                                                                                                        (long) 0,
                                                                                                        new SimpleEvent(
                                                                                                                identifier),
                                                                                                        MetaData.emptyInstance());
        sagaManager.handle(event);
        sagaManager.unsubscribe();
        verify(sagaFactory).createSaga(eq(StubSaga.class));
        sagaManager.stop();

        verify(correlationDataProvider).correlationDataFor(event);
View Full Code Here

Examples of org.cometd.bayeux.client.ClientSessionChannel.unsubscribe()

            final ClientSessionChannel.MessageListener listener = listenerMap.remove(consumer);
            if (listener != null) {

                LOG.info("Unsubscribing from channel {}...", channelName);
                final ClientSessionChannel clientChannel = client.getChannel(channelName);
                clientChannel.unsubscribe(listener);

                // confirm unsubscribe
                try {
                    if (!latch.await(CHANNEL_TIMEOUT, SECONDS)) {
                        String message;
View Full Code Here

Examples of org.cspoker.server.embedded.chat.room.TableChatRoom.unSubscribe()

    TableChatRoom room=tables.get(id);
    if(room==null)
      throw new IllegalArgumentException("There exists no table with the given id!");
    if(room.getTable().hasAsJoinedPlayer(id2)){
      // only players who joined the table, are allowed to unsubscribe their listener
      room.unSubscribe(chatlistener);
    }
  }
}
View Full Code Here

Examples of org.directwebremoting.Hub.unsubscribe()

        ScriptSession session = webContext.getScriptSession();

        Map<String, BrowserMessageListener> subscriptions = (Map<String, BrowserMessageListener>) session.getAttribute(ATTRIBUTE_SUBSCRIPTIONS);
        BrowserMessageListener subscription = subscriptions.get(subscriptionId);

        return hub.unsubscribe(subscription.topic, subscription);
    }

    /**
     * A struct to collect the data we need to remember against a subscription
     */
 
View Full Code Here

Examples of org.fusesource.mqtt.client.BlockingConnection.unsubscribe()

            msg = connection.receive(1000, TimeUnit.MILLISECONDS);
            assertNotNull(msg);
            assertEquals(topic, new String(msg.getPayload()));
            msg.ack();

            connection.unsubscribe(new String[] { topic });
        }
        connection.disconnect();

        // test wildcard patterns with above topics
        String[] wildcards = { "#", "+", "+/#", "/+", "+/", "+/+", "+/+/", "+/+/+" };
View Full Code Here

Examples of org.infinispan.objectfilter.impl.predicateindex.be.PredicateNode.unsubscribe()

      FilterSubscriptionImpl filterSubscriptionImpl = (FilterSubscriptionImpl) filterSubscription;
      filterSubscriptions.remove(filterSubscriptionImpl);
      for (BENode node : filterSubscriptionImpl.getBETree().getNodes()) {
         if (node instanceof PredicateNode) {
            PredicateNode predicateNode = (PredicateNode) node;
            predicateNode.unsubscribe();
         }
      }
   }
}
View Full Code Here

Examples of org.jboss.jms.client.JBossSession.unsubscribe()

         receiveMessage("consumerHA", consumerHA, true, true);

         session.commit();

         consumerHA.close();
         session.unsubscribe("T1");
      }
      finally
      {
         if (conn!=null)
         {
View Full Code Here

Examples of org.jboss.jms.delegate.SessionEndpoint.unsubscribe()

      if (endpoint == null)
      {
         throw new IllegalStateException("Cannot find object in dispatcher with id " + objectId);
      }
     
      endpoint.unsubscribe(subName);
     
      return null;
   }

   public void write(DataOutputStream os) throws Exception
View Full Code Here

Examples of org.jboss.jms.server.endpoint.SessionEndpoint.unsubscribe()

      if (endpoint == null)
      {
         throw new IllegalStateException("Cannot find object in dispatcher with id " + objectId);
      }
     
      endpoint.unsubscribe(subName);
     
      return null;
   }

   public void write(DataOutputStream os) throws Exception
View Full Code Here

Examples of org.jboss.seam.remoting.messaging.RemoteSubscriber.unsubscribe()

      {
        RemoteSubscriber subscriber = SubscriptionRegistry.instance().
                                      getSubscription(token);
        if (subscriber != null)
        {
          subscriber.unsubscribe();
        }
      }
    }
    finally
    {
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.