Examples of subscribe()


Examples of axis.com.probe.service.sensor.SensorSoapHttpBindingStub.subscribe()

         EndpointReferenceType     sensorEpr = endpointReferences[i];
         SensorSoapHttpBindingStub sensor = getSensorService( sensorEpr );

         // build the request to subscribe to the sensor services' change notifications
         Subscribe         subscribeRequest  = buildSubscribe( sensorEpr );
         SubscribeResponse subscribeResponse = sensor.subscribe( subscribeRequest );

         // the subscription request succeeded - remember the EPR to the new subscription in case we need to unsubscribe
         m_subscriptions.add( subscribeResponse.getSubscriptionReference(  ) );
      }
View Full Code Here

Examples of bot.RxEventEmitter.subscribe()

    public void it() {
        final RxEventEmitter eventsToSubscriberAdapter = new RxEventEmitter();
        Observable<Event> events = Observable.create(new Observable.OnSubscribe<Event>() {
            @Override
            public void call(final Subscriber<? super Event> subscriber) {
                eventsToSubscriberAdapter.subscribe(subscriber);
            }
        }).observeOn(Schedulers.newThread());

        events.subscribe(new Action1<Event>() {
            @Override
View Full Code Here

Examples of br.com.jteam.jfcm.controller.EventDispatchService.subscribe()

  public void createContentContainer()
  {
    TreePanel treePanel = new TreePanel();
    ContentPanel contentPanel = new ContentPanel();
    EventDispatchService service = EventDispatchService.getInstance();
    service.subscribe(OpenFileEvent.class, treePanel);
    service.subscribe(OpenHistoryFileEvent.class, treePanel);
    service.subscribe(OpenHistoryFileEvent.class, contentPanel);
    service.subscribe(OpenFileEvent.class, contentPanel);
    service.subscribe(ShowImageEvent.class, contentPanel);
    service.subscribe(ShowTextEvent.class, contentPanel);
View Full Code Here

Examples of com.alibaba.dubbo.registry.Registry.subscribe()

        final Registry registry = getRegistry(originInvoker);
        final URL registedProviderUrl = getRegistedProviderUrl(originInvoker);
        registry.register(registedProviderUrl);
        // 订阅override数据
        // FIXME 提供者订阅时,会影响同一JVM即暴露服务,又引用同一服务的的场景,因为subscribed以服务名为缓存的key,导致订阅信息覆盖。
        registry.subscribe(registedProviderUrl.setProtocol(Constants.PROVIDER_PROTOCOL)
                .addParameters(Constants.CATEGORY_KEY, Constants.CONFIGURATORS_CATEGORY,
                        Constants.CHECK_KEY, String.valueOf(false)), listener);
        return registry;
    }
View Full Code Here

Examples of com.alibaba.dubbo.registry.RegistryService.subscribe()

        RegistryService registryService = proxyFactory.getProxy(registryInvoker);
        DubboRegistry registry = new DubboRegistry(registryInvoker, registryService);
        directory.setRegistry(registry);
        directory.setProtocol(protocol);
        directory.notify(urls);
        registryService.subscribe(new URL(Constants.SUBSCRIBE_PROTOCOL, NetUtils.getLocalHost(), 0, RegistryService.class.getName(), url.getParameters()), directory);
        return registry;
    }
   
    private static URL getRegistryURL(URL url) {
        return url.setPath(RegistryService.class.getName())
View Full Code Here

Examples of com.alibaba.dubbo.registry.integration.RegistryDirectory.subscribe()

    @Test
    public void testDestroy_WithDestroyRegistry() {
        RegistryDirectory registryDirectory = getRegistryDirectory();
        CountDownLatch latch = new CountDownLatch(1);
        registryDirectory.setRegistry(new MockRegistry(latch));
        registryDirectory.subscribe(URL.valueOf("consumer://" + NetUtils.getLocalHost() + "/DemoService?category=providers"));
        registryDirectory.destroy();
        Assert.assertEquals(0, latch.getCount());
    }

    @Test
View Full Code Here

Examples of com.alibaba.otter.canal.meta.MixedMetaManager.subscribe()

        MetaLogPositionManager logPositionManager = new MetaLogPositionManager();
        logPositionManager.setMetaManager(metaManager);
        logPositionManager.start();
        // 构建meta信息
        ClientIdentity client1 = new ClientIdentity(destination, (short) 1);
        metaManager.subscribe(client1);

        PositionRange range1 = buildRange(1);
        metaManager.updateCursor(client1, range1.getEnd());

        PositionRange range2 = buildRange(2);
View Full Code Here

Examples of com.alibaba.rocketmq.client.consumer.DefaultMQPushConsumer.subscribe()

public class Consumer {

    public static void main(String[] args) throws InterruptedException, MQClientException {
        DefaultMQPushConsumer consumer = new DefaultMQPushConsumer("please_rename_unique_group_name_4");

        consumer.subscribe("TopicTest", "*");

        consumer.registerMessageListener(new MessageListenerConcurrently() {

            @Override
            public ConsumeConcurrentlyStatus consumeMessage(List<MessageExt> msgs,
View Full Code Here

Examples of com.aliyun.openservices.ons.api.Consumer.subscribe()

        Properties properties = new Properties();
        properties.put(PropertyKeyConst.ConsumerId, "ConsumerId1");
        properties.put(PropertyKeyConst.MessageModel, PropertyValueConst.BROADCASTING);
        Consumer consumer = ONSFactory.createConsumer(properties);

        consumer.subscribe("TopicTestONS", "*", new MessageListener() {

            @Override
            public Action consume(Message message, ConsumeContext context) {
                System.out.println(message);
                return Action.CommitMessage;
View Full Code Here

Examples of com.aliyun.openservices.ons.api.order.OrderConsumer.subscribe()

    public static void main(String[] args) {
        Properties properties = new Properties();
        properties.put(PropertyKeyConst.ConsumerId, "ConsumerId1");
        OrderConsumer consumer = ONSFactory.createOrderedConsumer(properties);

        consumer.subscribe("TopicTestONS", "*", new MessageOrderListener() {

            @Override
            public OrderAction consume(Message message, ConsumeOrderContext context) {
                System.out.println(message);
                return OrderAction.ConsumeSuccessfully;
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.