-
axis.com.probe.service.sensor.SensorSoapHttpBindingStub.subscribe()
-
bot.RxEventEmitter.subscribe()
-
br.com.jteam.jfcm.controller.EventDispatchService.subscribe()
Cadastra um Subscriber a ser notificado para ocorrências de uma tipo de evento.
@param eventClass Classe do evento.
@param subscriber Objeto a ser notificado.
@throws IllegalArgumentException Caso um dos parâmetros seja nulo.
-
com.alibaba.dubbo.registry.Registry.subscribe()
-
com.alibaba.dubbo.registry.RegistryService.subscribe()
53.10/com.alibaba.foo.BarService?version=1.0.0&application=kylin
@param listener 变更事件监听器,不允许为空
-
com.alibaba.dubbo.registry.integration.RegistryDirectory.subscribe()
-
com.alibaba.otter.canal.meta.MixedMetaManager.subscribe()
-
com.alibaba.rocketmq.client.consumer.DefaultMQPushConsumer.subscribe()
-
com.aliyun.openservices.ons.api.Consumer.subscribe()
订阅消息
@param topic 消息主题
@param subExpression 订阅过滤表达式字符串,ONS服务器依据此表达式进行过滤。只支持或运算
eg: "tag1 || tag2 || tag3"
如果subExpression等于null或者*,则表示全部订阅
@param listener 消息回调监听器
-
com.aliyun.openservices.ons.api.order.OrderConsumer.subscribe()
订阅消息
@param topic 消息主题
@param subExpression 订阅过滤表达式字符串,broker依据此表达式进行过滤。目前只支持或运算
eg: "tag1 || tag2 || tag3"
如果subExpression等于null或者*,则表示全部订阅
@param listener 消息回调监听器
-
com.amazonaws.services.sns.AmazonSNSClient.subscribe()
The Subscribe
action prepares to subscribe an endpoint by sending the endpoint a confirmation message. To actually create a subscription, the endpoint owner must call the ConfirmSubscription
action with the token from the confirmation message. Confirmation tokens are valid for three days.
@param subscribeRequest Container for the necessary parameters toexecute the Subscribe service method on AmazonSNS.
@return The response from the Subscribe service method, as returned byAmazonSNS.
@throws NotFoundException
@throws AuthorizationErrorException
@throws InternalErrorException
@throws SubscriptionLimitExceededException
@throws InvalidParameterException
@throws AmazonClientException If any internal errors are encountered inside the client while attempting to make the request or handle the response. For example if a network connection is not available.
@throws AmazonServiceException If an error response is returned by AmazonSNS indicating either a problem with the data in the request, or a server side issue.
-
com.bloomberglp.blpapi.Session.subscribe()
-
com.collective2.signalEntry.adapter.DynamicSimulationAdapter.subscribe()
-
com.collective2.signalEntry.adapter.dynamicSimulator.SystemManager.subscribe()
-
com.comcast.cns.persistence.CNSSubscriptionCassandraPersistence.subscribe()
-
com.comcast.cns.persistence.ICNSSubscriptionPersistence.subscribe()
Make a subscription request. Initially the subscription will be unconfirmed / inactive. CNS will automatically send a confirmation request containing a token to the specified end point using the desired protocol. It is the client's responsibility to parse out the token and call confirmSubscritpion. If topic owner and subscription owner are the same no confirmation is necessary and no request will be sent.
@param endpoint end point
@param protocol HTTP, HTTPS, EMAIL, EMAIL-JASON, CQS
@param topicArn topic arn
@param userId user id
@return
@throws Exception
-
com.couchbase.client.vbucket.ConfigurationProvider.subscribe()
Subscribes for configuration updates.
@param bucketName bucket name to receive configuration for
@param rec reconfigurable that will receive updates
@throws ConfigurationException
-
com.couchbase.client.vbucket.ConfigurationProviderHTTP.subscribe()
Subscribes for configuration updates.
@param bucketName bucket name to receive configuration for
@param rec reconfigurable that will receive updates
-
com.couchbase.client.vbucket.provider.ConfigurationProvider.subscribe()
Subscribes for configuration updates.
@param rec reconfigurable that will receive updates
@throws ConfigurationException
-
com.cxy.redisclient.service.PubSubService.subscribe()
-
com.darylteo.nio.DirectoryWatcher.subscribe()
-
com.discoverydns.dnsapiclient.framework.command.CommandProcessor.subscribe()
-
com.discoverydns.dnsapiclient.framework.impl.basic.BasicCommandProcessor.subscribe()
-
com.gitblit.fanout.FanoutClient.subscribe()
-
com.goodow.realtime.channel.Bus.subscribe()
-
com.google.appengine.api.prospectivesearch.ProspectiveSearchService.subscribe()
-
com.intellij.util.messages.MessageBusConnection.subscribe()
Subscribes given handler to the target endpoint within the current connection.
@param topic target endpoint
@param handler target handler to use for incoming messages
@param < L> interface for working with the target topic
@throws IllegalStateException if there is already registered handler for the target endpoint within the current connection.Note that that previously registered handler is not replaced by the given one then
@see MessageBus#syncPublisher(Topic)
-
com.opengamma.livedata.LiveDataClient.subscribe()
Creates a non-persistent subscription to market data. Returns immediately without waiting for a reply from the server. The reply will be sent later to the listener.
@param user the user credentials, checked to ennsure user is authorized to access the data, not null
@param requestedSpecification what market data you want to subscribe to, and in which standardized format you want the server to give it to you.
@param listener the listener that receives the results of the subscription request
-
com.peterhi.obsolete.RemoteRegistry.subscribe()
-
com.peterhi.working.Registry.subscribe()
-
com.sun.grid.jgdi.EventClient.subscribe()
-
com.taobao.metamorphosis.client.consumer.MessageConsumer.subscribe()
����ָ������Ϣ������MessageListener��������Ϣ�ﵽ��ʱ������֪ͨMessageListener����ע�⣬ ���ô˷���������ʹ���Ĺ�ϵ������Ч�� ֻ���ڵ���complete���������Ч���˷���������ʽ����
@param topic ���ĵ�topic
@param maxSize ����ÿ�ν��յ�������ݴ�С
@param messageListener ��Ϣ������
-
com.taobao.metaq.client.MetaPushConsumer.subscribe()
-
dao.DaoUser.subscribe()
-
de.zib.scalaris.PubSub.subscribe()
Subscribes a url to a topic.
@param topic the topic to subscribe the url to
@param url the url of the subscriber (this is where the events are send to)
@throws ConnectionException if the connection is not active or a communication error occurs or an exit signal was received or the remote node sends a message containing an invalid cookie
@throws TimeoutException if a timeout occurred while trying to write the value
@throws AbortException if the commit of the subscribe failed
@throws UnknownException if any other error occurs
-
dojox.cometd.Channel.subscribe()
-
gov.nasa.arc.mct.platform.spi.SubscriptionManager.subscribe()
Subscribe to the specified feed. The mechanism for subscription (and even whether it is necessary) is at the sole discretion of the providers.
@param feedIDs opaque strings representing a unique identifier for the feed (this string must be recognized uniquely among multiple feeds). A concrete example of this would be the URL for an ATOM feed.
-
net.engio.mbassy.bus.MBassador.subscribe()
-
net.engio.mbassy.bus.common.IMessageBus.subscribe()
-
net.ser1.stomp.Client.subscribe()
-
org.activemq.ws.notification.NotificationProducer.Subscribe()
-
org.apache.activemq.transport.stomp.StompConnection.subscribe()
-
org.apache.airavata.wsmg.client.WseMsgBrokerClient.subscribe()
-
org.apache.airavata.wsmg.client.WsntMsgBrokerClient.subscribe()
-
org.apache.airavata.wsmg.client.amqp.rabbitmq.AMQPBroadcastReceiverImpl.Subscribe()
-
org.apache.airavata.wsmg.client.amqp.rabbitmq.AMQPTopicReceiverImpl.Subscribe()
-
org.apache.cocoon.portal.event.EventManager.subscribe()
Subscribes a receiver for a specific type of event.
-
org.apache.cometd.bayeux.Channel.subscribe()
Subscribes a client to a channel.
@param subscriber - the client to be subscribed. If the clientalready is subscribed, this call will not create a duplicate subscription.
-
org.apache.cxf.wsn.client.NotificationBroker.subscribe()
-
org.apache.hedwig.client.api.Subscriber.subscribe()
Subscribe to the given topic for the inputted subscriberId.
@param topic Topic name of the subscription
@param subscriberId ID of the subscriber
@param mode Whether to prohibit, tolerate, or require an existing subscription.
@throws CouldNotConnectException If we are not able to connect to the server host
@throws ClientAlreadySubscribedException If client is already subscribed to the topic
@throws ServiceDownException If unable to subscribe to topic
@throws InvalidSubscriberIdException If the subscriberId is not valid. We may want to set aside certain formats of subscriberId's for different purposes. e.g. local vs. hub subscriber
-
org.apache.muse.ws.notification.NotificationProducer.subscribe()
Registers a consumer resource to receive events that are published to a certain topic (along with other filtering rules). Registration results in the creation of a subscription resource, which exposes the WS-N SubscriptionManager port type and can be managed as a regular WS-RF implied resource. Once subscription is complete, the event consumer will receive notifications on the topic until the subscription is terminated (via WS-RL) or the producer shuts down.
@param consumer The EPR of the resource that will receive the notifications from the producing resource. This does not have to be the same component that is making the subscribe() request. An orchestrating service may be subscribing for the consumer.
@param filter Optional filter that allows for messages to be published if they meet a certain criteria. Filter types include topic names, message patterns (XPath), and current state (WSRP doc).
@param policy Optional filter that allows for more complex analysis on the conditions needed to send a message. The implementation must provide one or more policy languages (dialects) that clients can use to express how and when a message that is published to a topic should be sent. If this parameter is null, no policy is applied.
@param terminationTime Because subscriptions are WS-resources, they may be terminated with scheduled termination (specifically, the WS-RL TerminationTime property). If this parameter is null, no termination time is set.
@return The new subscription resource.
-
org.apache.muse.ws.notification.remote.NotificationProducerClient.subscribe()
-
org.apache.qpid.proton.messenger.Messenger.subscribe()
0.0" will bind to any local interface and listen for incoming messages.
-
org.apache.qpid.proton.messenger.impl.MessengerImpl.subscribe()
-
org.apache.servicemix.wsn.client.NotificationBroker.subscribe()
-
org.apache.tomcat.bayeux.ChannelImpl.subscribe()
-
org.apache.vysper.xmpp.modules.extension.xep0060_pubsub.model.LeafNode.subscribe()
Add a new subscriber with the given id.
@param id subscription ID
@param subscriber the subscriber
-
org.apache.ws.muws.interop.client.ResourceStub.subscribe()
-
org.apache.ws.notification.NotificationManager.subscribe()
Subscribes a notification consumer to a set of topics as defined in the given request.
@param subscriptionRequest contains all the information needed to create the subscription
@return the EPR for the subscription
@throws BaseFaultException if failed to create the subscription
-
org.axonframework.commandhandling.CommandBus.subscribe()
Subscribe the given
handler
to commands of type
commandType
.
If a subscription already exists for the given type, the behavior is undefined. Implementations may throw an Exception to refuse duplicate subscription or alternatively decide whether the existing or new
handler
gets the subscription.
@param commandName The name of the command to subscribe the handler to
@param handler The handler instance that handles the given type of command
@param < C> The Type of command
-
org.axonframework.commandhandling.SimpleCommandBus.subscribe()
Subscribe the given handler
to commands of type commandType
. If a subscription already exists for the given type, then the new handler takes over the subscription.
@param commandName The type of command to subscribe the handler to
@param handler The handler instance that handles the given type of command
@param < T> The Type of command
-
org.axonframework.eventhandling.Cluster.subscribe()
Subscribe the given {@code eventListener} to this cluster. If the listener is already subscribed, nothinghappens.
While the Event Listeners is subscribed, it will receive all messages published to the cluster.
@param eventListener the Event Listener instance to subscribe
-
org.axonframework.eventhandling.ClusteringEventBus.subscribe()
-
org.axonframework.eventhandling.EventBus.subscribe()
Subscribe the given
eventListener
to this bus. When subscribed, it will receive all events published to this bus.
If the given
eventListener
is already subscribed, nothing happens.
@param eventListener The event listener to subscribe
@throws EventListenerSubscriptionFailedException if the listener could not be subscribed
-
org.axonframework.eventhandling.SimpleEventBus.subscribe()
{@inheritDoc}
-
org.axonframework.saga.annotation.AnnotatedSagaManager.subscribe()
-
org.cometd.Channel.subscribe()
-
org.cometd.bayeux.client.ClientSessionChannel.subscribe()
Equivalent to {@link #subscribe(ClientSessionChannel.MessageListener,ClientSessionChannel.MessageListener) subscribe(listener, null)}.
@param listener the listener to register and invoke when a message arrives on this channel.
-
org.cspoker.server.embedded.chat.room.TableChatRoom.subscribe()
-
org.directwebremoting.Hub.subscribe()
Called to create a subscription so that future publishes to a similarly named topic alert the MessageListener that a publish has happened.
Warning Currently the topic is a simple string pattern match. This more closely resembles JMS rather than the OpenAjax hub because we're taking the simplistic approach for now. I'm sure there will be some nasty problems that fall out of this.
The OpenAjax hub allows subscriber data that is passed back to the subscriber when the event happens. Since listeners are an ideal place for this data it isn't supported here. The OAA hub also allows for filters, but I'm thinking that this can be easily supported by the listener. What am I missing?
@param topicName The topic to subscribe to.
@param listener The object to notify of matching calls to publish()
-
org.eclipse.ecf.pubsub.IPublishedService.subscribe()
-
org.eclipse.ecf.pubsub.IPublishedServiceRequestor.subscribe()
-
org.fusesource.mqtt.client.BlockingConnection.subscribe()
-
org.jboss.errai.bus.client.api.messaging.MessageBus.subscribe()
Subscribe a listener to the specified subject.
@param subject
@param receiver
-
org.jboss.errai.bus.client.framework.ClientMessageBus.subscribe()
-
org.jboss.errai.bus.client.framework.ClientMessageBusImpl.subscribe()
Add a subscription for the specified subject
@param subject - the subject to add a subscription for
@param callback - function called when the message is dispatched
-
org.jboss.errai.bus.client.framework.MessageBus.subscribe()
Subscribe a listener to the specified subject.
@param subject
@param receiver
-
org.jboss.ws.extensions.eventing.mgmt.SubscriptionManagerMBean.subscribe()
-
org.jivesoftware.smackx.pubsub.Node.subscribe()
The user subscribes to the node using the supplied jid. The bare jid portion of this one must match the jid for the connection. Please note that the {@link Subscription.State} should be checked on return since more actions may be required by the caller. {@link Subscription.State#pending} - The owner must approve the subscription request before messages will be received. {@link Subscription.State#unconfigured} - If the {@link Subscription#isConfigRequired()} is true, the caller must configure the subscription before messages will be received. If it is false the caller can configure it but is not required to do so.
@param jid The jid to subscribe as.
@return The subscription
@exception XMPPException
-
org.jresearch.gossip.dao.ForumDAO.subscribe()
DOCUMENT ME!
@param tid
@param email
@param name
@throws SQLException DOCUMENT ME!
-
org.olat.course.run.calendar.CourseCalendarSubscription.subscribe()
-
org.projectodd.stilts.stomp.client.StompClient.subscribe()
-
org.red5.server.api.scope.IBroadcastScope.subscribe()
Connect to a consumer.
@param consumer Consumer
@param paramMap Parameters map
@return true when successfully subscribed,false otherwise.
-
org.red5.server.messaging.IPipe.subscribe()
Connect to a consumer.
@param consumer Consumer
@param paramMap Parameters map
@return true when successfully subscribed,false otherwise.
-
org.red5.server.messaging.InMemoryPullPullPipe.subscribe()
{@inheritDoc}
-
org.red5.server.messaging.InMemoryPushPushPipe.subscribe()
{@inheritDoc}
-
org.richfaces.application.push.Session.subscribe()
Subscribe this session to given topics
-
org.rioproject.monitor.service.channel.ServiceChannel.subscribe()
-
org.serviceconnector.api.cln.SCPublishService.subscribe()
Subscribe to SC with default operation timeout.
Once a subscribe is called a unsubscribe need to be done at the end of a communication.
@param scSubscribeMessage the SC subscribe message
@param scMessageCallback the SC message callback
@return the SC subscribe message
@throws SCMPValidatorException subscribe message is null
callback is null
mask is invalid
@throws SCServiceException instance already subscribed before
subscribe to host failed
error message received from SC
-
org.serviceconnector.server.StatefulServer.subscribe()
Subscribe.
@param msgToForward the message to forward
@param callback the callback
@param timeoutMillis the timeout millis
@throws ConnectionPoolBusyException the connection pool busy exception
-
org.servicemix.ws.notification.NotificationProducer.Subscribe()
-
org.servicemix.wspojo.notification.NotificationProducer.subscribe()
-
org.springframework.data.keyvalue.redis.connection.Subscription.subscribe()
Adds the given channels to the current subscription.
@param channels channel names
-
org.springframework.integration.channel.DirectChannel.subscribe()
-
org.springframework.integration.channel.ExecutorChannel.subscribe()
-
org.springframework.integration.channel.PublishSubscribeChannel.subscribe()
-
org.springframework.integration.core.SubscribableChannel.subscribe()
-
org.springframework.messaging.SubscribableChannel.subscribe()
Register a message handler.
@return {@code true} if the handler was subscribed or {@code false} if itwas already subscribed.
-
org.springframework.messaging.support.ExecutorSubscribableChannel.subscribe()
-
org.syncany.operations.watch.NotificationListener.subscribe()
-
org.terasology.rendering.nui.widgets.UIButton.subscribe()
-
org.terasology.world.block.internal.BlockManagerImpl.subscribe()
-
org.wso2.carbon.broker.core.BrokerService.subscribe()
subscribe to a pirticulare broker configuration. When the Broker receives the message it send that to the user through the listener interface.
@param brokerConfiguration - Configuration details of the broker
@param topicName - topic to subscribe
@param brokerListener - listener interface to notify
@throws org.wso2.carbon.broker.core.exception.BrokerEventProcessingException - if problem happen when subscribing
-
org.wso2.carbon.event.client.broker.BrokerClient.subscribe()
-
org.wso2.carbon.event.core.EventBroker.subscribe()
subscribe using the gvien subscription details.
@param subscription
@return
@throws org.wso2.carbon.event.core.exception.EventBrokerException
-
org.wso2.carbon.registry.eventing.services.EventingService.subscribe()
Creates a subscription.
@param subscription subscription object to add.
@return unique identifier corresponding to the subscription made.
-
org.xmlBlaster.client.I_XmlBlasterAccess.subscribe()
org/xmlBlaster/doc/requirements/interface.subscribe.html">interface.subscribe requirement
@throws XmlBlasterException like ErrorCode.USER_NOT_CONNECTED and others
-
org.xmlBlaster.contrib.dbwatcher.mom.XmlBlasterPublisher.subscribe()
Not available via interface, used by test suite only.
@param topic If the topic starts with "XPATH:" the prefix will be strippedand an Xpath subscription is done.
@param momCb Incoming messages are forwarded to this interface
@return A unique identifier of the subscription
@throws Exception Typically a XmlBlasterException
-
org.xmlBlaster.engine.admin.I_AdminSession.subscribe()
@param qos The qos XML string (e.g. "" or "
")
@return The status string
-
org.zeromq.ZMQ.Socket.subscribe()
-
org.zkoss.zk.ui.event.EventQueue.subscribe()
Subscribes a listener to this queue. It is the same as
subscribe(listener, false)
( {@link #subscribe(EventListener,boolean)}. In other words, it subscribes a synchronous listener.
Note: this method must be called within an activated exection (i.e., {@link org.zkoss.zk.ui.Executions#getCurrent} not null),no matter what scope the event queue is.
Note: the listener could access the component associated with the event ( {@link Event#getTarget}), only if this is an {@link EventQueues#DESKTOP}event queue.
An event listener can be subscribed multiple times, and it will be invoked multiple times if an event is published.
Even if this is a {@link EventQueues#GROUP}, {@link EventQueues#SESSION}, or {@link EventQueues#APPLICATION} event queue,the listener is subscribed for the current desktop only, i.e., it can only access the components belong to the subscribed desktop. If you want to use the same listener to manipulate multiple desktops, you have to subscribe them separately when the corresponding execution is available.
@see #subscribe(EventListener,EventListener)
@see #subscribe(EventListener,boolean)
-
org.zkoss.zss.model.Book.subscribe()
Subscribe a listener to listener to this book
@param listener
-
reactor.rx.Stream.subscribe()
Subscribe the {@link reactor.rx.action.CombineAction#input()} to this Stream. Combining action through {@link reactor.rx.action.Action#combine()} allows for easy distribution of a full flow.
@param subscriber the combined actions to subscribe
@since 2.0
-
redis.clients.jedis.Jedis.subscribe()