-
EDU.oswego.cs.dl.util.concurrent.Callable.send()
-
akka.actor.Inbox.send()
-
akka.testkit.JavaTestKit.send()
-
akka.testkit.TestProbe.send()
-
aleph.comm.CommunicationManager.send()
Sends a message
@param pe destination PE
@param message what to send
-
api.http.HttpRequest.send()
send a HTTP request to url.
@return the response after the HTTP request is sent.
@throws IOException the url is not exist or something wrong of the serverof target url.
-
au.com.cahaya.asas.net.mail.JavaMailClient.send()
-
backtype.storm.messaging.IConnection.send()
send a message with taskId and payload
@param taskId task ID
@param payload
-
br.com.visualmidia.core.server.Communicate.send()
-
ca.weblite.objc.Client.send()
Sends a message to an Objective-C object.
{@code String hello = (String)Client.getInstance() .send(cls("NSString"), sel("stringWithUTF8String:"), "Hello");}
@param receiver A pointer to the object to which the message is being sent.
@param selector A pointer to the selector to call on the target.
@param args Variable arguments of the message.
@return The return value of the message call.
-
ca.weblite.objc.Proxy.send()
Sends a message to the peer.
@param selector The selector to send to.
@param args Variable argument list.
@return The result of the message call.
-
ccw.repl.SafeConnection.send()
-
ch.ethz.inf.vs.californium.coap.Request.send()
Sends the request over the default endpoint to its destination and expects a response back.
-
ch.marcsladek.jrtnp.connection.Connection.send()
Sends an Object to the socket's OutputStream
@param obj Object to be sent
@return sending success
@throws IOException when unable to write Object to the Stream
-
ch.usi.dslab.bezerra.netwrapper.tcp.TCPSender.send()
-
cn.com.zjtelecom.smgp.Client.Send()
-
co.cask.cdap.test.StreamWriter.send()
Sends a UTF-8 encoded string to the stream.
@param content Data to be sent.
@throws java.io.IOException If there is error writing to the stream.
-
co.paralleluniverse.actors.Actor.send()
-
co.paralleluniverse.actors.ActorRef.send()
-
co.paralleluniverse.galaxy.jgroups.ControlChannel.send()
-
co.paralleluniverse.strands.channels.IntChannel.send()
-
com.acelet.lib.SendEmail.send()
-
com.aelitis.net.udp.uc.PRUDPPacketHandler.send()
Send only
@param request_packet
@param destination_address
@throws PRUDPPacketHandlerException
-
com.aicontest.visualizer.js.dom.XMLHttpRequest.send()
-
com.alibaba.dubbo.remoting.Channel.send()
-
com.alibaba.dubbo.remoting.exchange.ExchangeClient.send()
-
com.alibaba.dubbo.remoting.exchange.support.header.HeaderExchangeClient.send()
-
com.alibaba.rocketmq.client.producer.DefaultMQProducer.send()
-
com.alibaba.rocketmq.client.producer.MQProducer.send()
发送消息,同步调用
@param msg 消息
@return 发送结果
@throws InterruptedException
@throws MQBrokerException
@throws RemotingException
@throws MQClientException
-
com.alipay.bluewhale.core.messaging.IConnection.send()
-
com.aliyun.openservices.ons.api.Producer.send()
同步发送消息,只要不抛异常就表示成功
@param message
@return 发送结果,含消息Id
-
com.aliyun.openservices.ons.api.bean.ProducerBean.send()
-
com.aliyun.openservices.ons.api.order.OrderProducer.send()
发送顺序消息
@param message 消息
@param selector 消息选择器
@param arg 应用自定义参数,会回传到selector.select()方法中
@return 发送结果,含消息Id
-
com.aliyun.openservices.ons.api.transaction.TransactionProducer.send()
-
com.almende.eve.agent.AgentInterface.send()
Do a RPC call to another agent.
@param < T> the generic type
@param url the url
@param method the method
@param params the params
@param type the type
@return the t
@throws IOException Signals that an I/O exception has occurred.
@throws JSONRPCException the jSONRPC exception
-
com.almende.eve.transport.TransportService.send()
Send a message to an other agent
@param senderId
@oaran receiverUrl
@param request
@response response
-
com.anzsoft.client.XMPP.mandioca.XmppSession.send()
-
com.art.anette.server.network.ClientThread.send()
-
com.atlassian.mail.server.SMTPMailServer.send()
-
com.baasbox.service.push.PushService.send()
-
com.baasbox.service.push.providers.IPushServer.send()
-
com.barchart.udt.SocketUDT.send()
send from byte[] array upto size=array.length
bytes
@param array array to send
@return -1
: no buffer space (non-blocking only)
=0
: timeout expired (blocking only)
>0
: normal send, actual sent byte count
@see #send0(int,int,int,boolean,byte[])
-
com.bergerkiller.bukkit.common.MessageBuilder.send()
Sends all of the messages to a receiver without clearing them
@param sender to send to
@return This Message Builder
-
com.bergerkiller.bukkit.common.scoreboards.CommonTeam.send()
Send all team data to a speciafic player
@param player to receive team data
-
com.bj58.spat.gaea.client.communication.socket.CSocket.send()
-
com.calclab.emite.im.chat.PairChat.send()
Send a message to the uri of this chat
@param message the message
@throws RuntimeException if chat status != ready
-
com.calclab.emite.xep.muc.client.Room.send()
-
com.calexo.openhra.serveur.Javixo4OpenHRA.send()
-
com.chenshuo.muduo.example.multiplexer.MockClient.send()
-
com.cloudbreakers.producers.SoProducer.send()
-
com.cloudcontrolled.api.client.CloudControlClient.send()
{@inheritDoc}
-
com.collective2.signalEntry.Signal.send()
-
com.couchbase.client.core.endpoint.Endpoint.send()
Sends a {@link CouchbaseRequest} into the endpoint and eventually returns a {@link CouchbaseResponse}.
@param request the request to send.
-
com.couchbase.client.core.service.Service.send()
Sends a {@link CouchbaseRequest} into the service and eventually returns a {@link CouchbaseResponse}. The {@link CouchbaseResponse} is not returned directly, but is wrapped into a {@link Observable}.
@param request the request to send.
-
com.crackj2ee.mail.MailEngine.send()
-
com.cubusmail.mail.MessageHandler.send()
@throws MessagingException
@throws IOException
-
com.cubusmail.server.mail.MessageHandler.send()
@throws MessagingException
@throws IOException
-
com.davfx.ninio.http.HttpClient.send()
-
com.davfx.ninio.http.util.SimpleHttpClient.send()
-
com.dianping.cat.message.io.MessageSender.send()
-
com.dotcms.repackage.org.xbill.DNS.ExtendedResolver.send()
-
com.dotcms.repackage.org.xbill.DNS.Resolver.send()
-
com.dotmarketing.business.DotGuavaCacheAdministratorImpl.send()
@param msg
@return True if the message was sent without any problem, false otherwise.
-
com.dp.nebula.wormhole.common.BufferedLineExchanger.send()
Put one {@link ILine} into {@link Storage}.
@param line {@link ILine} of data pushed into {@link Storage}.
@return true for OK, false for failure.
-
com.ericsson.otp.erlang.OtpConnection.send()
Send a message to a process on a remote node.
@param dest the Erlang PID of the remote process.
@param msg the message to send.
@exception java.io.IOException if the connection is not active or a communication error occurs.
-
com.ericsson.otp.erlang.OtpMbox.send()
Send a message to a remote {@link OtpErlangPid pid}, representing either another {@link OtpMbox mailbox} or an Erlang process.
@param to the {@link OtpErlangPid pid} identifying the intendedrecipient of the message.
@param msg the body of the message to send.
-
com.esri.gpt.catalog.lucene.RemoteIndexer.send()
Sends an indexing request to a remote service.
@param context the request context
@param action the action(publish|delete)
@param uuid the document uuid
-
com.esri.gpt.framework.mail.MailRequest.send()
Sends the E-Mail message.
@throws AddressException if an E-Mail address is invalid
@throws MessagingException if an exception occurs
-
com.etown.util.email.EMailSender.send()
单发
@param mailMessage
@return
@throws NoSuchProviderException
@throws MessagingException
-
com.facebook.presto.jdbc.internal.jetty.client.HttpRequest.send()
-
com.facebook.presto.jdbc.internal.jetty.client.api.Request.send()
Sends this request and returns the response.
This method should be used when a simple blocking semantic is needed, and when it is known that the response content can be buffered without exceeding memory constraints.
For example, this method is not appropriate to download big files from a server; consider using {@link #send(Response.CompleteListener)} instead, passing your own {@link Response.Listener} or a utilitylistener such as {@link InputStreamResponseListener}.
The method returns when the {@link Response.CompleteListener complete event} is fired.
@return a {@link ContentResponse} for this request
@see Response.CompleteListener#onComplete(Result)
-
com.firefly.net.support.TcpConnection.send()
-
com.firefly.net.support.wrap.client.TcpConnection.send()
-
com.fly.test.activemqTest.ProducerService.send()
-
com.founder.fix.fixflow.core.impl.util.MailUtil.send()
发送邮件
-
com.github.dreamhead.moco.helper.MocoSocketHelper.send()
-
com.github.kevinsawicki.http.HttpRequest.send()
Write contents of file to request body
@param input
@return this request
@throws HttpRequestException
-
com.google.analytics.tracking.android.Tracker.send()
-
com.google.android.gcm.server.Sender.send()
Sends a message to one device, retrying in case of unavailability.
Note: this method uses exponential back-off to retry in case of service unavailability and hence could block the calling thread for many seconds.
@param message message to be sent, including the device's registration id.
@param registrationId device where the message will be sent.
@param retries number of retries in case of service unavailability errors.
@return result of the request (see its javadoc for more details)
@throws IllegalArgumentException if registrationId is {@literal null}.
@throws InvalidRequestException if GCM didn't returned a 200 or 503 status.
@throws IOException if message could not be sent.
-
com.google.api.explorer.client.base.rest.RestApiRequest.send()
-
com.google.appengine.api.mail.MailService.send()
-
com.google.checkout.checkout.CheckoutShoppingCartRequest.send()
-
com.google.checkout.orderprocessing.AddMerchantOrderNumberRequest.send()
-
com.google.checkout.orderprocessing.ArchiveOrderRequest.send()
-
com.google.checkout.orderprocessing.AuthorizeOrderRequest.send()
-
com.google.checkout.orderprocessing.CancelOrderRequest.send()
-
com.google.checkout.orderprocessing.ChargeOrderRequest.send()
-
com.google.checkout.orderprocessing.RefundOrderRequest.send()
-
com.google.checkout.orderprocessing.UnarchiveOrderRequest.send()
-
com.google.checkout.orderprocessing.lineitem.CancelItemsRequest.send()
-
com.google.checkout.orderprocessing.lineitem.ReturnItemsRequest.send()
-
com.google.checkout.orderprocessing.lineitem.ShipItemsRequest.send()
-
com.google.collide.client.communication.FrontendApi.RequestResponseApi.send()
-
com.google.gerrit.client.rpc.RestApi.send()
-
com.google.gerrit.server.mail.AddReviewerSender.send()
-
com.google.gerrit.server.mail.CommentSender.send()
-
com.google.gerrit.server.mail.CreateChangeSender.send()
-
com.google.gerrit.server.mail.MergeFailSender.send()
-
com.google.gerrit.server.mail.MergedSender.send()
-
com.google.gerrit.server.mail.RegisterNewEmailSender.send()
-
com.google.gerrit.server.mail.ReplacePatchSetSender.send()
-
com.google.gerrit.server.mail.ReplyToChangeSender.send()
-
com.google.gerrit.server.mail.RevertedSender.send()
-
com.google.greaze.rest.server.RestResponseSender.send()
-
com.google.greaze.webservice.server.ResponseSender.send()
-
com.google.gwt.gears.client.httprequest.HttpRequest.send()
Sends the request.
-
com.google.gwt.http.client.RequestBuilder.send()
Sends an HTTP request based on the current builder configuration. If no request headers have been set, the header "Content-Type" will be used with a value of "text/plain; charset=utf-8". You must call {@link #setRequestData(String)} and {@link #setCallback(RequestCallback)}before calling this method.
@return a {@link Request} object that can be used to track the request
@throws RequestException if the call fails to initiate
@throws NullPointerException if a request callback has not been set
-
com.google.gwt.user.client.rpc.impl.FailingRequestBuilder.send()
-
com.google.gwt.visualization.client.Query.send()
-
com.google.gwt.websockets.client.WebSocket.send()
-
com.google.gwt.xhr.client.XMLHttpRequest.send()
Initiates a request with no request data. This simply calls {@link #send(String)} with null
as an argument, because theno-argument send()
method is unavailable on Firefox.
-
com.google.sitebricks.acceptance.page.FormsPage.send()
-
com.google.wave.api.AbstractRobot.HttpFetcher.send()
-
com.google.web.bindery.requestfactory.shared.RequestTransport.send()
Called by the RequestFactory implementation.
@param payload the String payload
@param receiver the {@link TransportReceiver} instance that willreceive the payload
-
com.googlecode.gmail4j.GmailClient.send()
Sends the message
@param message Message to be sent
-
com.googlecode.gmail4j.javamail.ImapGmailClient.send()
-
com.hazelcast.client.SimpleClient.send()
-
com.hazelcast.client.spi.impl.ClientInvocationServiceImpl.send()
-
com.hazelcast.spi.OperationService.send()
Executes an operation remotely. It isn't allowed
@param op the operation to send and execute.
@param target the address of that target member.
@return
-
com.hp.hpl.jena.sparql.engine.binding.BindingOutputStream.send()
-
com.ib.client.Builder.send()
-
com.ibm.sbt.services.client.email.MimeEmail.send()
Sends the email.
@throws MimeEmailException Thrown when there is an error sending the email.
-
com.ikanow.infinit.e.data_model.utils.SendMail.send()
-
com.im.imjutil.email.EmailSender.send()
Metodo utilitario para envios rapidos de email.
Para o email ser enviado deve-se ter no minimo um endereco de destino.
@param subject O assunto do email. Pode ser nulo ou vazio.
@param message A mensagem do email. Pode ser nulo ou vazio.
@param to Um ou varios enderecos de destino do email.
@throws EmailException Caso ocorra algum erro no envio.
-
com.jeecms.common.email.EmailSendTool.send()
此段代码用来发送普通电子邮件
@throws MessagingException
@throws UnsupportedEncodingException
@throws UnsupportedEncodingException
-
com.lbslocal.cc.common.TCPClientDecarta.Send()
-
com.linkedin.d2.discovery.event.PropertyEventThread.send()
-
com.linkedin.helix.messaging.DefaultMessagingService.send()
-
com.mdraco.chat.BaseClient.Send()
-
com.mdraco.chat.ConsoleClient.Send()
-
com.mossle.api.msg.MsgConnector.send()
-
com.netflix.suro.client.SuroClient.send()
-
com.nokia.dempsy.messagetransport.Sender.send()
Sends the message. The implementor needs to take special handle exceptions from the underlying system correctly. The user of the Sender should not be required to release the sender and reaquire it. The Sender should do that work.
@param messageBytes The serialized message to send
@throws MessageTransportException indicates that the message wasn't sent.
-
com.opengamma.transport.FudgeMessageSender.send()
-
com.opengamma.transport.jms.JmsByteArrayMessageSender.send()
-
com.openmashupos.socket.client.Socket.send()
-
com.ourlinc.activity.Mail.send()
发送邮件,抛出异常表示发送失败
@param fromAddress
@param toEmailAddresses
@param ccEmailAddresses
@param subject
@param content
@return
@throws MessagingException
-
com.ourlinc.helloworld.model.Mail.send()
发送邮件,抛出异常表示发送失败
@param fromAddress
@param toEmailAddresses
@param ccEmailAddresses
@param subject
@param content
@return
@throws MessagingException
-
com.peterhi.obsolete.Endpoint.send()
-
com.peterhi.working.EndpointImpl.send()
-
com.postmark.PostmarkMailSender.send()
-
com.simoncat.net.SendFileSFTP.send()
-
com.sogou.qadev.service.cynthia.service.MailSender.send()
-
com.stuffwithstuff.magpie.interpreter.Channel.send()
-
com.sun.enterprise.jbi.serviceengine.comm.MessageSender.send()
Users of this class execute send() method to send the message to NMR. Note that execute() method will finally call doWork().
-
com.sun.jini.test.spec.jeri.mux.util.AbortMessage.send()
-
com.sun.jini.test.spec.jeri.mux.util.ClientConnectionHeader.send()
-
com.sun.jini.test.spec.jeri.mux.util.CloseMessage.send()
-
com.sun.jini.test.spec.jeri.mux.util.DataMessage.send()
-
com.sun.jini.test.spec.jeri.mux.util.IncrementRationMessage.send()
-
com.sun.jini.test.spec.jeri.mux.util.PingMessage.send()
-
com.sun.jini.test.spec.jeri.mux.util.ServerConnectionHeader.send()
-
com.sun.sgs.app.Channel.send()
Sends the message contained in the specified buffer to all client sessions joined to this channel. If no sessions are joined to this channel, then no action is taken. The message starts at the buffer's current position and ends at the buffer's limit. The buffer's position is not modified by this operation.
If the specified {@code sender} is non-{@code null} and thatsender is not a member of this channel when the message is processed to be sent, then the message will not be forwarded to the channel for delivery.
The {@code ByteBuffer} may be reused immediately after this methodreturns. Changes made to the buffer after this method returns will have no effect on the message sent to the channel by this invocation.
The maximum length of a message that can be sent over the channel is dependent on the maximum message length supported by all joined client sessions. (See: {@link ClientSession#getMaxMessageLength})
@param sender the sending client session, or {@code null}
@param message a message
@return this channel
@throws IllegalStateException if this channel is closed
@throws IllegalArgumentException if the channel would be unableto send the specified message because it exceeds a size limit
@throws MessageRejectedException if there are not enough resourcesto send the specified message
@throws TransactionException if the operation failed because ofa problem with the current transaction
-
com.sun.sgs.app.ClientSession.send()
Sends a message contained in the specified {@link ByteBuffer} tothis session's client with the delivery guarantee of {@link Delivery#RELIABLE}. The message starts at the buffer's current position and ends at the buffer's limit. The buffer's position is not modified by this operation.
The {@code ByteBuffer} may be reused immediately after this methodreturns. Changes made to the buffer after this method returns will have no effect on the message sent to the client by this invocation.
This method is equivalent to invoking {@link #send(ByteBuffer,Delivery) send} with the specified {@code message}and {@code Delivery.RELIABLE}.
@param message a message
@return this client session
@throws IllegalStateException if this session is disconnected
@throws IllegalArgumentException if the specified message lengthexceeds {@link #getMaxMessageLength}
@throws MessageRejectedException if there are not enough resourcesto send the specified message
@throws DeliveryNotSupportedException if this client session doesnot support {@link Delivery#RELIABLE reliable} delivery
@throws TransactionException if the operation failed because ofa problem with the current transaction
-
com.sun.sgs.client.ClientChannel.send()
Sends the message contained in the specified {@code ByteBuffer} tothis channel. The message starts at the buffer's current position and ends at the buffer's limit. The buffer's position is not modified by this operation.
If the server-side application does not filter messages on this channel, the message will be delivered unaltered to all channel members, including the sender. However, the server-side application may alter the message, discard the message, or modify the list of recipients for application-specific reasons. If the channel message is not delivered to the sender (because it is discarded by the application, for example), the sender's {@link ClientChannelListener} will not receive a {@link ClientChannelListener#receivedMessage receivedMessage} notificationfor that message.
The {@code ByteBuffer} may be reused immediately after this methodreturns. Changes made to the buffer after this method returns will have no effect on the message sent to the channel by this invocation.
@param message a message to send
@throws IllegalStateException if the sender is not a member ofthis channel
@throws IOException if a synchronous I/O problem occurs
-
com.sun.sgs.client.simple.SimpleClient.send()
{@inheritDoc}
Note: The server does not guarantee delivery of any session message (sent via this method) that is received by the server before the sending client is logged in. Therefore messages sent before this client is logged in, that is, before the {@link SimpleClientListener#loggedIn SimpleClientListener.loggedIn} methodis invoked, may be dropped by the server.
-
com.taobao.metamorphosis.client.extension.spring.MetaqTemplate.send()
Send message built by message builder.Returns the sent result.
@param builder
@return
@throws InterruptedException
@since 1.4.5
-
com.typesafe.plugin.MailerAPI.send()
-
com.uwyn.drone.core.Bot.send()
-
com.uwyn.drone.core.Channel.send()
-
com.volantis.mps.channels.MessageChannel.send()
Sends the message via the channel.
@param multiChannelMessage The message.
@param messageRecipients The list of recipients.
@param messageSender The sender of the message.
@return A list of failed recipients.
@throws RecipientException if a problem occurred during recipientprocessing.
@throws MessageException if a problem occurred during messageprocessing.
-
com.volantis.mps.session.Session.send()
Sends a
MultiChannelMessage
to a single recipient.
@param message The MultiChannelMessage
to send.
@param recipient The MessageRecipient
to send this message to.
@throws MessageException if an error occurs when sending the message.
@return A MessageRecipients
list of failedMessageRecipients
.
-
com.volantis.vdp.scs.connectors.client.connection.ClientBroker.send()
Sends the data to the client.
@param packet the data as object SCPPacket class
-
com.volantis.vdp.scs.connectors.sps.connection.SPSBroker.send()
Sends the data as byte array if connection between SecureConnectionServer and sps is active.
@param data the data sent to the sps worker
-
com.zeonfederated.mailclient.senders.Sender.send()
-
com.zeonfederated.mailclient.senders.SmtpSender.send()
-
connection.server.ServerConnection.send()
-
de.creepsmash.server.Client.send()
Sends an object of ServerMessage to the outgoing queue.
@param message Expects an ServerMessage object.
-
de.matrixweb.smaller.clients.common.Util.send()
@param host
@param port
@param bytes
@return the response as {@link InputStream}
@throws ExecutionException
-
de.sciss.jcollider.SynthDef.send()
-
de.sciss.net.OSCTransmitter.send()
-
dijjer.io.comm.UdpSocketManager.send()
-
dijjer.io.xfer.BlockTransmitter.send()
-
edu.drexel.cs544.mcmuc.channels.Controller.send()
Passes the action to the multicast channel for sending
@param a Action action to send
@see MulticastChannel
-
edu.emory.mathcs.backport.java.util.concurrent.Callable.send()
-
edu.vt.rt.hyflow.core.tm.control.vote.VoteResult.send()
-
edu.wpi.cs.wpisuitetng.network.Request.send()
Sends the Request by creating a new RequestActor and starting it as a new Thread. Note: If Request.isAsynchronous is false, RequestObservers for this Request will not be updated.
@throws IllegalStateException If the Request is being sent.
-
elemental.dom.XMLHttpRequest.send()
-
erjang.EPID.send()
-
eu.mosaic_cloud.components.core.ChannelController.send()
-
eu.planets_project.ifr.core.common.mail.PlanetsMailMessage.send()
Sends the message
-
example.proto.Mail.send()
-
fi.luomus.commons.kirjekyyhky.KirjekyyhkyAPIClient.send()
Send a new prefilled form to Kirjekyyhky
@param xml
@param pdf
@throws Exception
-
freenet.clients.fcp.FCPMessage.send()
-
freenet.io.xfer.BulkTransmitter.send()
Send the file.
@return True if the file was successfully sent. False otherwise.
@throws DisconnectedException
-
freenet.node.SendableRequestSender.send()
ONLY called by RequestStarter. Start the actual request using the NodeClientCore provided, and the key and key number earlier got from chooseKey(). Either use the callbacks on the ChosenBlock, which will remove the key from KeysFetchingLocally, or do it directly (in obscure cases such as OfferedKeysList).
@param sched The scheduler this request has just been grabbed from.
@param request The ChosenBlock containing the key, the SendableRequestItem,and the methods to call to indicate success/failure.
@return True if a request was sent, false otherwise (in which case the request willbe removed if it hasn't already been).
-
freenet.pluginmanager.PluginTalker.send()
-
groovyx.gpars.actor.Actor.send()
-
hermes.Hermes.send()
Send a message to a destination
-
io.socket.SocketIO.send()
Send JSON data to the Socket.io server.
@param json the JSON object
-
io.undertow.io.Sender.send()
Write the given buffer using async IO, and calls the given callback on completion or error.
@param buffer The buffer to send.
@param callback The callback
-
io.undertow.websockets.core.WebSocketChannel.send()
Returns a new {@link StreamSinkFrameChannel} for sending the given {@link WebSocketFrameType} with the given payload.If this method is called multiple times, subsequent {@link StreamSinkFrameChannel}'s will not be writable until all previous frames were completely written.
@param type The {@link WebSocketFrameType} for which a {@link StreamSinkChannel} should be created
@param payloadSize The size of the payload which will be included in the WebSocket Frame. This may be 0 if you wantto transmit no payload at all.
-
io.undertow.websockets.utils.WebSocketTestClient.send()
Send the WebSocketFrame and call the FrameListener once a frame was received as response or when an Exception was caught.
-
io.vertx.rxcore.java.eventbus.RxEventBus.send()
Send a message
-
it.freedomotic.bus.BusService.send()
Sends a command to the bus
@param command The command to send
@return the Command sent
-
it.freedomotic.serial.SerialConnectionProvider.send()
-
it.unito.di.artifact.CommunicationArtifact.CARole.send()
-
java.net.DatagramSocket.send()
Sends a datagram packet from this socket. The
DatagramPacket
includes information indicating the data to be sent, its length, the IP address of the remote host, and the port number on the remote host.
If there is a security manager, and the socket is not currently connected to a remote address, this method first performs some security checks. First, if p.getAddress().isMulticastAddress()
is true, this method calls the security manager's checkMulticast
method with p.getAddress()
as its argument. If the evaluation of that expression is false, this method instead calls the security manager's checkConnect
method with arguments p.getAddress().getHostAddress()
and p.getPort()
. Each call to a security manager method could result in a SecurityException if the operation is not allowed.
@param p the DatagramPacket
to be sent.
@exception IOException if an I/O error occurs.
@exception SecurityException if a security manager exists and its checkMulticast
or checkConnect
method doesn't allow the send.
@exception PortUnreachableException may be thrown if the socket is connectedto a currently unreachable destination. Note, there is no guarantee that the exception will be thrown.
@exception java.nio.channels.IllegalBlockingModeException if this socket has an associated channel, and the channel is in non-blocking mode.
@see java.net.DatagramPacket
@see SecurityManager#checkMulticast(InetAddress)
@see SecurityManager#checkConnect
@revised 1.4
@spec JSR-51
-
java.net.MulticastSocket.send()
Sends a datagram packet to the destination, with a TTL (time- to-live) other than the default for the socket. This method need only be used in instances where a particular TTL is desired; otherwise it is preferable to set a TTL once on the socket, and use that default TTL for all packets. This method does
not alter the default TTL for the socket. Its behavior may be affected by
setInterface
.
If there is a security manager, this method first performs some security checks. First, if p.getAddress().isMulticastAddress()
is true, this method calls the security manager's checkMulticast
method with p.getAddress()
and ttl
as its arguments. If the evaluation of that expression is false, this method instead calls the security manager's checkConnect
method with arguments p.getAddress().getHostAddress()
and p.getPort()
. Each call to a security manager method could result in a SecurityException if the operation is not allowed.
@param p is the packet to be sent. The packet should containthe destination multicast ip address and the data to be sent. One does not need to be the member of the group to send packets to a destination multicast address.
@param ttl optional time to live for multicast packet.default ttl is 1.
@exception IOException is raised if an error occurs i.eerror while setting ttl.
@exception SecurityException if a security manager exists and its checkMulticast
or checkConnect
method doesn't allow the send.
@deprecated Use the following code or its equivalent instead:...... int ttl = mcastSocket.getTimeToLive(); mcastSocket.setTimeToLive(newttl); mcastSocket.send(p); mcastSocket.setTimeToLive(ttl); ......
@see DatagramSocket#send
@see DatagramSocket#receive
@see SecurityManager#checkMulticast(java.net.InetAddress,byte)
@see SecurityManager#checkConnect
-
java.nio.channels.DatagramChannel.send()
Sends out a datagram by the channel.
The precondition of sending is that whether the channel is in blocking mode and enough byte buffer space will be available, or the channel is in non-blocking mode and byte buffer space is enough. The transfer action is just like a regular write operation.
This method can be called at any moment, and will block if there is another thread started a read operation on the channel.
This method just execute the same security checks as the send method of the DatagramSocket
class.
@param source The byte buffer with the datagram to be sent.
@param address The address to be sent.
@return The number of sent bytes. If this method is called, it returnsthe number of bytes that remaining in the byte buffer. If the channel is in non-blocking mode and no enough space for the datagram in the buffer, it may returns zero.
@throws ClosedChannelException If the channel is already closed.
@throws AsynchronousCloseException If the channel is closed by another thread while this method is in operation.
@throws ClosedByInterruptException If another thread interrupts the calling thread while the operation is in progress. The calling thread will have the interrupt state set, and the channel will be closed.
@throws SecurityException If there is a security manager, and the address is not permitted to access.
@throws IOException Some other IO error occurred.
-
java.util.concurrent.Callable.send()
-
javax.bluetooth.L2CAPConnection.send()
Requests that data be sent to the remote device. The TransmitMTU determines the amount of data that can be successfully sent in a single send operation. If the size of data
is greater than the TransmitMTU, then only the first TransmitMTU bytes of the packet are sent, and the rest will be discarded. If data
is of length 0, an empty L2CAP packet will be sent.
@param data data to be sent
@exception IOException if data
cannot be sent successfully or if the connection is closed
@exception NullPointerException if the data
is null
-
javax.isolate.Link.send()
Sends the given message on this Link. The current thread will block in this method until a receiver is available. When the sender and receiver rendezvous, the message will then be transferred. A normal return indicates that the message was transferred. If an exception occurs on the sender side, no rendezvous will occur and no object will be transferred. But if an exception occurs on the receive(), the sender will see a successful transfer. If the receiving isolate becomes terminated after this method is invoked but before it returns, the link will be closed, a ClosedLinkException will be thrown, any subsequent attempts to use send() will result in a ClosedLinkException, and any Isolate objects corresponding to the receive side of the link will reflect a terminated state. If invoked on a closed link, this method will throw a ClosedLinkException. If close() is invoked on this Link while a thread is blocked in send(), send() will throw a ClosedLinkException. No message will have been transferred in that case. If Thread.interrupt() is invoked on a thread that has not yet completed an invocation of this method, the results are undefined. An InterruptedIOException may or may not be thrown; however, even if not, control will return from the method. Rendezvous and data transfer to the receiving isolate may or may not have occurred. In particular, undetected message loss between sender and receiver may occur. If a failure occurs during the transfer an IOException may be thrown in the sender and the object will not be sent. A transfer may succeed from the sender's point of view, but cause an independent IOException in the receiver. For example, if a message containing a large buffer is sent and the receiver has insufficient heap memory for the buffer or if construction of a link in the receiver isolate fails, an IOException will be thrown in the receiver after the transfer completes. A ClosedLinkException will be thrown if the given LinkMessage contains a closed Link, Socket, or ServerSocket. No object will be transferred in this case. If the current isolate is not a sender on this Link, an UnsupportedOperationException will be thrown. No object will be sent in this case.
@param message
@throws ClosedLinkException
@throws InterruptedIOException
@throws IOException
-
javax.jbi.messaging.DeliveryChannel.send()
-
javax.jms.JMSProducer.send()
Sends a message to the specified destination, using any send options, message properties and message headers that have been defined on this {@code JMSProducer}.
@param destination the destination to send this message to
@param message the message to send
@return this {@code JMSProducer}
@throws MessageFormatRuntimeException if an invalid message is specified.
@throws InvalidDestinationRuntimeException if a client uses this method with an invalid destination.
@throws MessageNotWriteableRuntimeException if this {@code JMSProducer} has been configured to set amessage property, but the message's properties are read-only
@throws JMSRuntimeException if the JMS provider fails to send the message due to some internal error.
-
javax.jms.MessageProducer.send()
-
javax.jms.QueueSender.send()
-
javax.jms.TopicPublisher.send()
-
javax.mail.Transport.send()
Send a message to all recipient addresses it contains (as returned by {@link Message#getAllRecipients()}) using message transports appropriate for each address. Message addresses are checked during submission, but there is no guarantee that the ultimate address is valid or that the message will ever be delivered.
{@link Message#saveChanges()} will be called before the message is actually sent.
@param message the message to send
@throws MessagingException if there was a problem sending the message
-
javax.microedition.io.UDPDatagramConnection.send()
-
javax.servlet.sip.SipServletRequest.send()
-
javax.servlet.sip.SipServletResponse.send()
-
javax.sound.midi.Receiver.send()
Sends a MIDI message and time-stamp to this receiver. If time-stamping is not supported by this receiver, the time-stamp value should be -1.
@param message the MIDI message to send
@param timeStamp the time-stamp for the message, in microseconds.
@throws IllegalStateException if the receiver is closed
-
javax.wireless.messaging.MessageConnection.send()
-
jpvm.jpvmMessage.send()
-
juzu.impl.bridge.spi.portlet.PortletActionBridge.send()
-
juzu.impl.bridge.spi.portlet.PortletEventBridge.send()
-
juzu.impl.bridge.spi.portlet.PortletResourceBridge.send()
-
juzu.impl.bridge.spi.portlet.PortletViewBridge.send()
-
kafka.javaapi.consumer.SimpleConsumer.send()
-
kafka.javaapi.producer.Producer.send()
-
kafka.producer.SimpleProducer.send()
-
lazyj.mail.Sendmail.send()
Send the given mail. This method will return true if everything is ok, false on any error. You can later check {@link #sError} to see what went wrong.
@param mail mail to be sent
@return true if everything is ok, false on any error.
-
lotus.domino.Document.send()
-
marauroa.functional.SimpleClient.send()
-
me.taylorkelly.bigbrother.datablock.BBDataBlock.send()
-
me.taylorkelly.bigbrother.datablock.BrokenBlock.send()
-
me.taylorkelly.bigbrother.datablock.ButtonPress.send()
-
me.taylorkelly.bigbrother.datablock.Chat.send()
-
me.taylorkelly.bigbrother.datablock.ChestOpen.send()
-
me.taylorkelly.bigbrother.datablock.Command.send()
-
me.taylorkelly.bigbrother.datablock.CreateSignText.send()
-
me.taylorkelly.bigbrother.datablock.DeltaChest.send()
-
me.taylorkelly.bigbrother.datablock.Disconnect.send()
-
me.taylorkelly.bigbrother.datablock.DoorOpen.send()
-
me.taylorkelly.bigbrother.datablock.DropItem.send()
-
me.taylorkelly.bigbrother.datablock.FlintAndSteel.send()
-
me.taylorkelly.bigbrother.datablock.LavaFlow.send()
-
me.taylorkelly.bigbrother.datablock.LeverSwitch.send()
-
me.taylorkelly.bigbrother.datablock.Login.send()
-
me.taylorkelly.bigbrother.datablock.PickupItem.send()
-
me.taylorkelly.bigbrother.datablock.PlacedBlock.send()
-
me.taylorkelly.bigbrother.datablock.SignDestroyed.send()
-
me.taylorkelly.bigbrother.datablock.Teleport.send()
-
me.taylorkelly.bigbrother.rollback.RollbackInterpreter.send()
-
megamek.common.net.IConnection.send()
Adds a packet to the send queue to be send on a seperate thread.
-
mireka.transmission.immediate.ImmediateSender.send()
Transmits mail to a single domain.
@throws IllegalArgumentException if the domains of the recipients are not the same, or if the recipient is the special global postmaster address, which has no absolute domain.
@throws PostponeException if transmission to all of the hosts must be postponed, because all of them are assumed to be busy at this moment.
-
models.mailing.Mailing.send()
-
net.jxta.pipe.OutputPipe.send()
-
net.rim.blackberry.api.mail.Transport.send()
-
net.rim.device.api.io.DatagramConnectionBase.send()
-
net.rim.device.api.io.messaging.NonBlockingSenderDestination.send()
-
net.ser1.stomp.Client.send()
-
net.sf.cindy.Session.send()
Send object with normal priority. The object will be encoded to Packet
use associated PacketEncoder
. This method is a shorthand for send(obj, 0).
@param obj send object
@return send future
-
net.sf.cindy.session.nio.PipeSession.send()
-
net.sf.clairv.p2p.OverlayNetwork.send()
Sends a message with the specified key. The message is routed to the node who is associated with this key. Note that if the target node does not generate a response, the callback will never be invoked.
@param key the key string
@param message the message to be sent
@param callback asynchronously invoked when the response of this message is received; null value is acceptable
@throws OverlayNetworkException thrown when any error occurred during the sending process
-
net.sf.collabreview.core.mails.Mail.send()
Send this message. Sending the message will be rejected if the "dead" flag is set to true (a debug message is logged).
-
net.sf.jml.MsnMessenger.send()
Send a message to DS/NS server. If block, the method will return after the message successfully sent or failed. If not block, the method always return false.
@param message MsnOutgoingMessage
@param block is block
@return if block, return message send successful, else return false
-
net.sf.jml.impl.AbstractMessenger.send()
@see MsnMessenger#send(MsnOutgoingMessage)
-
net.sf.jportlet.service.mail.MailService.send()
Send an email
@throws NamingException if the JNDINAme of the javax.mail.Session
is invalid
@throws MessagingException if any error while sending the email
-
net.sf.saxon.dom.DOMSender.send()
Walk a document (traversing the nodes depth first)
@exception net.sf.saxon.trans.XPathException On any error in the document
-
net.sf.saxon.event.DocumentSender.send()
Send the entire document to the receiver
-
net.sf.saxon.event.Sender.send()
Send the contents of a Source to a Receiver.
@param source the source to be copied. Note that if the Source contains an InputStreamor Reader then it will be left open, unless it is an AugmentedSource with the pleaseCloseAfterUse flag set. On the other hand, if it contains a URI that needs to be dereferenced to obtain an InputStream, then the InputStream will be closed after use.
@param receiver the destination to which it is to be copied
@param options Parse options. If source is an AugmentedSource, any options set in theAugmentedSource are used in preference to those set in options. If neither specifies a particular option, the defaults from the Configuration are used. May be null if no options are explicitly supplied.
-
net.tomp2p.dht.PeerDHT.send()
The send method works as follows:
1. routing: find close peers to the content hash. You can control the routing behavior with setRoutingConfiguration() 2. sending: send the data to the n closest peers. N is set via setRequestP2PConfiguration(). If you want to send it to the closest one, use setRequestP2PConfiguration(1, 5, 0)
@param locationKey The target hash to search for during the routing process
@return The send builder that allows to set options
-
net.windwards.dnsfrontend.client.Client.send()
-
netP5.UdpClient.send()
-
nexj.core.integration.Sender.send()
Initiates processing of a single message by the implementor.
@param tobj The transfer object containing the message.
-
nginx.clojure.NginxHttpServerChannel.send()
-
ninja.postoffice.Postoffice.send()
-
no.kommune.bergen.soa.common.remote.RemoteFileTransferClient.send()
-
no.kommune.bergen.soa.svarut.altinn.correspondence.CorrespondenceClient.send()
-
no.uib.cipr.matrix.distributed.Communicator.send()
Sends data[offset:offset+length] to peer
-
open.dolphin.orcaapi.OrcaApi.send()
診療内容を ORCA に送る
@param documentModel
-
org.activemq.ActiveMQMessageProducer.send()
Sends a message using the MessageProducer
's default delivery mode, priority, and time to live.
@param message the message to send
@throws JMSException if the JMS provider fails to send the message due to someinternal error.
@throws MessageFormatException if an invalid message is specified.
@throws InvalidDestinationException if a client uses this method with a MessageProducer
with an invalid destination.
@throws java.lang.UnsupportedOperationException if a client uses this method with a MessageProducer
that did not specify a destination at creation time.
@see javax.jms.Session#createProducer
@see javax.jms.MessageProducer
@since 1.1
-
org.activemq.transport.TransportChannel.send()
synchronously send a Packet
@param packet
@return a Receipt
@throws JMSException
-
org.activiti.engine.impl.persistence.entity.JobEntityManager.send()
-
org.activiti.engine.impl.persistence.entity.JobManager.send()
-
org.agilewiki.jactor.JAFuture.send()
Sends a request and waits for a response.
@param actor The target actor.
@param request The unwrapped request.
@return The unwrapped response.
@throws Exception Any uncaught exceptions raised while processing the request.
-
org.agilewiki.jfile.transactions.db.Checkpoint.send()
-
org.agilewiki.jfile.transactions.db.OpenDbFile.send()
-
org.agilewiki.jfile.transactions.transactionAggregator.AggregateTransaction.send()
-
org.agilewiki.jid.collection.IGet.send()
-
org.agilewiki.jid.collection.vlenc.IAdd.send()
-
org.agilewiki.jid.scalar.vlens.actor.SetActor.send()
-
org.agorava.api.oauth.OAuthRequest.send()
-
org.agorava.rest.OAuthRequestImpl.send()
-
org.ajax4jsf.javascript.DnDScript.send()
-
org.ajax4jsf.resource.InternetResource.send()
Send incapsulated resource to client by {@link ResourceContext} .
@param context
-
org.ajax4jsf.webapp.CacheContent.send()
Send saved content to http responce
@param response
@throws IOException
-
org.apache.accumulo.server.tabletserver.mastermessage.MasterMessage.send()
-
org.apache.accumulo.tserver.mastermessage.MasterMessage.send()
-
org.apache.activemq.ActiveMQMessageProducer.send()
Sends a message to a destination for an unidentified message producer, specifying delivery mode, priority and time to live.
Typically, a message producer is assigned a destination at creation time; however, the JMS API also supports unidentified message producers, which require that the destination be supplied every time a message is sent.
@param destination the destination to send this message to
@param message the message to send
@param deliveryMode the delivery mode to use
@param priority the priority for this message
@param timeToLive the message's lifetime (in milliseconds)
@throws JMSException if the JMS provider fails to send the message due tosome internal error.
@throws UnsupportedOperationException if an invalid destination isspecified.
@throws InvalidDestinationException if a client uses this method with aninvalid destination.
@see javax.jms.Session#createProducer
@since 1.1
-
org.apache.activemq.broker.Broker.send()
-
org.apache.activemq.broker.StubConnection.send()
-
org.apache.activemq.broker.region.Destination.send()
-
org.apache.activemq.broker.region.Queue.send()
-
org.apache.activemq.transport.stomp.StompConnection.send()
-
org.apache.avro.test.Mail.send()
-
org.apache.axis2.client.MessageSender.send()
Sends a SOAP elvelope created from an OMElement.
@param opName
@param toSend
@throws AxisFault
-
org.apache.axis2.clientapi.MessageSender.send()
Send the SOAP Message, the actual worker
@param opName
@param toSend
@throws AxisFault
-
org.apache.axis2.clustering.management.GroupManagementAgent.send()
Send a GroupManagementCommand to the group
@param command The command
@throws ClusteringFault If an error occurs while sending the command
-
org.apache.axis2.engine.AxisEngine.send()
This methods represents the outflow of the Axis, this could be either at the server side or the client side. Here the ExecutionChain
is created using the Phases. The Handlers at the each Phases is ordered in deployment time by the deployment module
@param msgContext
@throws AxisFault
@see MessageContext
@see Phase
@see Handler
-
org.apache.camel.ProducerTemplate.send()
Sends the exchange to the default endpoint
@param exchange the exchange to send
-
org.apache.camel.component.jms.JmsConfiguration.CamelJmsTeemplate102.send()
-
org.apache.camel.component.jms.JmsConfiguration.CamelJmsTemplate.send()
-
org.apache.camel.component.jms.JmsConfiguration.CamelJmsTemplate102.send()
-
org.apache.catalina.cluster.CatalinaCluster.send()
Sends a message to all the members in the cluster
@param msg SessionMessage
-
org.apache.catalina.cluster.tcp.SimpleTcpCluster.send()
-
org.apache.catalina.ha.CatalinaCluster.send()
Sends a message to all the members in the cluster
@param msg ClusterMessage
-
org.apache.catalina.tribes.group.RpcChannel.send()
Send a message and wait for the response.
@param destination Member[] - the destination for the message, and the members you request a reply from
@param message Serializable - the message you are sending out
@param rpcOptions int - FIRST_REPLY, MAJORITY_REPLY or ALL_REPLY
@param channelOptions channel sender options
@param timeout long - timeout in milliseconds, if no reply is received within this time null is returned
@return Response[] - an array of response objects.
@throws ChannelException
-
org.apache.cocoon.mail.MailMessageSender.send()
Assemble the message from the defined fields and send it.
@throws AddressException when problems with email addresses are found
@throws MessagingException when message could not be send.
-
org.apache.cocoon.mail.MailSender.send()
Assemble the message from the defined fields and send it. The source resolver is obtained from the hosting component container.
@throws AddressException when problems with email addresses are found
@throws MessagingException when message could not be send.
-
org.apache.cocoon.portal.event.EventManager.send()
Publish an event. All registered receivers get notified.
@param event The event to broadcast.
-
org.apache.commons.httpclient.methods.multipart.FilePart.send()
-
org.apache.commons.httpclient.methods.multipart.StringPart.send()
-
org.apache.commons.mail.Email.send()
Sends the email. Internally we build a MimeMessage which is afterwards sent to the SMTP server.
@return the message id of the underlying MimeMessage
@throws EmailException the sending failed
-
org.apache.commons.mail.HtmlEmail.send()
-
org.apache.commons.mail.MultiPartEmail.send()
-
org.apache.commons.mail.SimpleEmail.send()
-
org.apache.commons.mail.mocks.MockMultiPartEmailConcrete.send()
-
org.apache.commons.net.CharGenUDPClient.send()
Sends the data initiation datagram. This data in the packet is ignored by the server, and merely serves to signal that the server should send its reply.
@param host The address of the server.
@param port The port of the service.
@exception IOException If an error occurs while sending the datagram.
-
org.apache.commons.net.EchoUDPClient.send()
Sends the specified data to the specified server at the default echo port.
@param data The echo data to send.
@param length The length of the data to send. Should be less thanor equal to the length of the data byte array.
@param host The address of the server.
@exception IOException If an error occurs during the datagram sendoperation.
-
org.apache.commons.net.chargen.CharGenUDPClient.send()
Sends the data initiation datagram. This data in the packet is ignored by the server, and merely serves to signal that the server should send its reply.
@param host The address of the server.
@param port The port of the service.
@exception IOException If an error occurs while sending the datagram.
-
org.apache.commons.net.echo.EchoUDPClient.send()
Sends the specified data to the specified server at the default echo port.
@param data The echo data to send.
@param length The length of the data to send. Should be less thanor equal to the length of the data byte array.
@param host The address of the server.
@exception IOException If an error occurs during the datagram sendoperation.
-
org.apache.cxf.transport.Conduit.send()
Send an outbound message.
@param message the message to be sent.
-
org.apache.drill.exec.rpc.ResponseSender.send()
-
org.apache.hadoop.hdfs.qjournal.client.HttpImageUploadChannel.send()
Send a chunk of data.
-
org.apache.hadoop.nfs.nfs3.response.NFS3Response.send()
-
org.apache.hadoop.nfs.nfs3.response.WRITE3Response.send()
-
org.apache.harmony.xnet.provider.jsse.Finished.send()
-
org.apache.harmony.xnet.provider.jsse.HelloRequest.send()
Sends message
@param out
-
org.apache.harmony.xnet.provider.jsse.ServerHelloDone.send()
Sends message
@param out
-
org.apache.helix.ipc.netty.NettyHelixIPCService.send()
Sends a message to all partitions with a given state in the cluster.
-
org.apache.kafka.clients.producer.KafkaProducer.send()
Asynchronously send a record to a topic. Equivalent to {@link #send(ProducerRecord,Callback) send(record, null)}
-
org.apache.kafka.clients.producer.MockProducer.send()
Adds the record to the list of sent records. The {@link RecordMetadata} returned will be immediately satisfied.
@see #history()
-
org.apache.lenya.net.SMTP.send()
DOCUMENT ME!
@param from DOCUMENT ME!
@param to DOCUMENT ME!
@param cc DOCUMENT ME!
@param bcc DOCUMENT ME!
@param subject DOCUMENT ME!
@param body DOCUMENT ME!
-
org.apache.qpid.jms.MessageProducer.send()
-
org.apache.qpid.proton.engine.Sender.send()
Sends message data for the current delivery.
@param bytes the message data
-
org.apache.qpid.proton.messenger.Messenger.send()
Blocks until the outgoing queue is empty and, in the event that an outgoing window has been set, until the messages in that window have been received by the target to which they were sent, or the operation times out. The timeout property controls how long a Messenger will block before timing out.
-
org.apache.qpid.proton.messenger.impl.MessengerImpl.send()
-
org.apache.qpid.server.exchange.ExchangeImpl.send()
-
org.apache.qpid.server.model.Exchange.send()
-
org.apache.qpid.test.framework.CircuitEnd.send()
Send the specified message over the producer at this end point.
@param message The message to send.
@throws JMSException Any JMS exception occuring during the send is allowed to fall through.
-
org.apache.roller.weblogger.util.Trackback.send()
ixapart.com/pronet/docs/trackback_spec
-
org.apache.s4.base.Emitter.send()
@param partitionId - destination partition
@param message - message payload that needs to be sent
@return - true - if message is sent across successfully - false - if send fails
-
org.apache.s4.client.Driver.send()
Send a message to the adapter.
@param m message to be sent
@return true if and only if the message was successfully sent.
@throws IOException if the underlying TCP/IP socket throws an exception.
-
org.apache.s4.client.util.ByteArrayIOChannel.send()
-
org.apache.s4.comm.tcp.TCPEmitter.send()
-
org.apache.servicemix.client.DefaultServiceMixClient.send()
-
org.apache.servicemix.client.ServiceMixClient.send()
Sends the message exchange to the endpoint.
@param exchange
@throws MessagingException
-
org.apache.servicemix.components.util.ComponentSupport.send()
-
org.apache.servicemix.jbi.nmr.flow.Flow.send()
Distribute an ExchangePacket
@param packet
@throws JBIException
-
org.apache.servicemix.nmr.api.Channel.send()
An asynchronous invocation of the service
@param exchange the exchange to send
-
org.apache.servicemix.osworkflow.OSWorkflowEndpoint.send()
sends a msg to the channel
@param ex
@param sync
@throws MessagingException
-
org.apache.servicemix.tck.SenderComponent.send()
-
org.apache.sling.api.servlets.HtmlResponse.send()
Writes the response to the given writer and replaces all ${var} patterns by the value of the respective property. if the property is not defined the pattern is not modified.
@param response to send to
@param setStatus whether to set the status code on the response
@throws IOException if an i/o exception occurs
-
org.apache.sling.servlets.post.AbstractPostResponse.send()
Writes the response to the given writer and replaces all ${var} patterns by the value of the respective property. if the property is not defined the pattern is not modified.
@param response to send to
@param setStatus whether to set the status code on the response
@throws IOException if an i/o exception occurs
-
org.apache.sling.servlets.post.PostResponse.send()
Writes the response back over the provided HTTP channel. The actual format of the response is implementation dependent.
@param response to send to
@param setStatus whether to set the status code on the response
@throws IOException if an i/o exception occurs
-
org.apache.soap.messaging.Message.send()
Send an envelope to the given URL via the SOAPTransport that has been configured for this instance (or SOAPHTTPConnection by default). The envelope is sent exactly as-is.
@param url the url to send to
@param actionURI the value of the SOAPAction header
@param env envelope to send
@exception SOAPException if something goes wrong.
-
org.apache.soap.transport.http.SOAPHTTPConnection.send()
This method is used to request that an envelope be posted to the given URL. The response (if any) must be gotten by calling the receive() function.
@param sendTo the URL to send the envelope to
@param action the SOAPAction header field value
@param headers any other header fields to go to as protocol headers
@param env the envelope to send
@param smr the XML<->Java type mapping registry (passed on)
@param ctx the request SOAPContext
@exception SOAPException with appropriate reason code if problem
-
org.apache.sshd.common.scp.ScpHelper.send()
-
org.apache.synapse.endpoints.Endpoint.send()
Sends the message context according to an endpoint specific behavior.
@param synMessageContext MessageContext to be sent.
-
org.apache.tomcat.lite.http.HttpChannel.send()
-
org.apache.tomcat.lite.http.HttpRequest.send()
-
org.apache.tools.ant.taskdefs.email.Mailer.send()
Send the email.
@throws BuildException if the email can't be sent.
-
org.apache.turbine.util.mail.SimpleEmail.send()
-
org.apache.turbine.util.velocity.VelocityHtmlEmail.send()
Actually send the mail.
@exception EmailException thrown if mail cannot be sent.
-
org.apache.wicket.Component.send()
{@inheritDoc}
-
org.apache.wicket.Page.send()
-
org.apache.ws.security.common.CustomHandler.send()
-
org.apache.wsif.util.jms.WSIFJMSDestination.send()
Send a message to the write queue
@param data is the message
@return the id of the message that was sent.
-
org.apache.wss4j.dom.common.CustomHandler.send()
-
org.ardverk.dht.io.transport.Transport.send()
-
org.asmatron.messengine.engines.DefaultActionDelegate.send()
-
org.asmatron.messengine.engines.DefaultMessagingDelegate.send()
-
org.asmatron.messengine.testing.support.TestActionDelegate.send()
-
org.auto.comet.Socket.send()
发送消息
-
org.camunda.bpm.engine.impl.persistence.entity.JobManager.send()
-
org.cipango.client.SipRequest.send()
-
org.cipango.diameter.api.DiameterServletAnswer.send()
-
org.cipango.diameter.api.DiameterServletRequest.send()
-
org.cipango.diameter.node.DiameterRequest.send()
-
org.cipango.server.SipResponse.send()
@see SipServletResponse#send()
-
org.cipango.server.transaction.ServerTransaction.send()
-
org.codehaus.activemq.transport.TransportChannel.send()
synchronously send a Packet
@param packet
@return a Receipt
@throws JMSException
-
org.codehaus.xfire.transport.Channel.send()
Sends a message.
@param context
@param message
@throws XFireException Occurs if there was an error an error sending the message.
-
org.cometd.server.Transport.send()
-
org.compiere.util.EMail.send()
-
org.crazyyak.dev.net.email.EmailMessage.send()
-
org.cspoker.external.pokersource.PokersourceConnection.send()
-
org.dmlite.util.config.EmailConfig.send()
Sends an email.
@param to email to address
@param subject email subject
@param content email content
@throws dmLite exception if there is a problem
-
org.drools.runtime.Channel.send()
Sends the given object to this channel.
@param object
-
org.dspace.core.Email.send()
Sends the email.
@throws MessagingException if there was a problem sending the mail.
-
org.eclipse.jetty.client.HttpChannel.send()
-
org.eclipse.jetty.client.HttpClient.send()
-
org.eclipse.jetty.client.HttpRequest.send()
-
org.eclipse.jetty.client.api.Connection.send()
Sends a request with an associated response listener.
{@link Request#send(Response.CompleteListener)} will eventually call this method to send the request.It is exposed to allow applications to send requests via unpooled connections.
@param request the request to send
@param listener the response listener
-
org.eclipse.jetty.client.api.Request.send()
Sends this request and returns the response.
This method should be used when a simple blocking semantic is needed, and when it is known that the response content can be buffered without exceeding memory constraints.
For example, this method is not appropriate to download big files from a server; consider using {@link #send(Response.CompleteListener)} instead, passing your own {@link Response.Listener} or a utilitylistener such as {@link InputStreamResponseListener}.
The method returns when the {@link Response.CompleteListener complete event} is fired.
@return a {@link ContentResponse} for this request
@see Response.CompleteListener#onComplete(Result)
-
org.eclipse.jetty.websocket.common.test.Fuzzer.send()
-
org.eclipse.jgit.transport.RefAdvertiser.send()
Format an advertisement for the supplied refs.
@param refs zero or more refs to format for the client. The collection is sorted before display if necessary, and therefore may appear in any order.
@return set of ObjectIds that were advertised to the client.
@throws IOException the underlying output stream failed to write out an advertisement record.
-
org.exoplatform.frameworks.ftpclient.data.FtpDataTransiver.send()
-
org.fao.geonet.util.JavaMailer.send()
Sends multipart email.
@param subject the email subject
@param text the content of the body for text mail
@param html the content of the body for html mail
@param sender the email sender
@param recipients the email recipients
@throws javax.mail.MessagingException
-
org.fao.geonet.util.MailSender.send()
Better use through MailUtil, as it takes the settings directly from the BBDD.
@param server
@param port
@param username TODO
@param password TODO
@param useSSL TODO
@param from
@param fromDescr
@param to
@param toDescr
@param subject
@param message
-
org.fcrepo.server.messaging.JMSManager.send()
Allows the caller to send a Message object to a named destination
-
org.fenixedu.academic.domain.util.email.EmailBean.send()
-
org.foo.hub.api.Hub.send()
-
org.fusesource.stomp.client.BlockingConnection.send()
-
org.hampelratte.svdrp.Connection.send()
-
org.hornetq.api.core.client.ClientProducer.send()
Sends a message to an address. specified in {@link ClientSession#createProducer(String)} orsimilar methods.
This will block until confirmation that the message has reached the server has been received if {@link ServerLocator#setBlockOnDurableSend(boolean)} or{@link ServerLocator#setBlockOnNonDurableSend(boolean)} are set to true
for thespecified message type.
@param message the message to send
@throws HornetQException if an exception occurs while sending the message
-
org.hornetq.core.client.impl.ClientProducerImpl.send()
-
org.hornetq.core.protocol.core.Channel.send()
Sends a packet on this channel.
@param packet the packet to send
@return false if the packet was rejected by an outgoing interceptor; true if the send wassuccessful
-
org.hornetq.javaee.example.server.XARecoveryExampleService.send()
-
org.infoset.xml.ItemDestination.send()
-
org.infoset.xml.util.WriterItemDestination.send()
-
org.iremake.client.network.ClientContext.send()
-
org.java_websocket.WebSocket.send()
Send Text data to the other end.
@throws IllegalArgumentException
@throws NotYetConnectedException
-
org.jboss.aerogear.io.netty.handler.codec.sockjs.SockJsSessionContext.send()
Send data to the current session. This data might be delivered immediately of queued up in the session depending on the type of session (polling, streaming etc)
@param message the message to be sent.
-
org.jboss.aerogear.unifiedpush.JavaSender.send()
Sends the given payload to installations of the referenced PushApplication. We also pass a {@link MessageResponseCallback} to handle the message
@param unifiedMessage the {@link UnifiedMessage} to send.
@param callback the {@link MessageResponseCallback}.
-
org.jboss.aerogear.unifiedpush.SenderClient.send()
-
org.jboss.example.jms.stateless.bean.StatelessSessionExample.send()
-
org.jboss.example.jms.statelessclustered.bean.StatelessClusteredSessionExample.send()
-
org.jboss.identity.federation.web.util.IDPWebRequestUtil.send()
Send a response
@param responseDoc
@param relayState
@param response
@throws IOException
@throws GeneralSecurityException
-
org.jboss.jms.client.JBossMessageProducer.send()
-
org.jboss.jms.server.endpoint.SessionEndpoint.send()
Send a message
@param message The message to send
@throws JMSException
-
org.jboss.jms.server.endpoint.advised.SessionAdvised.send()
-
org.jboss.narayana.blacktie.jatmibroker.core.transport.Sender.send()
-
org.jbpm.env.session.MessageSession.send()
-
org.jbpm.msg.MessageService.send()
-
org.jbpm.pvm.internal.session.MessageSession.send()
-
org.jdesktop.wonderland.client.cell.CellEditChannelConnection.send()
Send a cell message to a specific cell on the server
@see org.jdesktop.wonderland.client.comms.WonderlandSession#send(WonderlandClient,Message)
@param message the cell message to send
-
org.jdesktop.wonderland.server.comms.WonderlandClientSender.send()
Send a message to all session connected via this sender's client type. The message will be handled on each remote client by the WonderlandClient connected with the ConnectionType of this sender.
@param message the message to send
@throws IllegalStateException if the handler for this client typehas been unregistered
-
org.jeromq.ZMsg.send()
-
org.jgroups.Channel.send()
Sends a message to a (unicast) destination. The message contains
- a destination address (Address). A
null
address sends the message to all group members. - a source address. Can be left empty. Will be filled in by the protocol stack.
- a byte buffer. The message contents.
- several additional fields. They can be used by application programs (or patterns). E.g. a message ID, a
oneway
field which determines whether a response is expected etc.
@param msg The message to be sent. Destination and buffer should be set. A null destinationmeans to send to all group members.
@exception ChannelNotConnectedException The channel must be connected to send messages.
@exception ChannelClosedException The channel is closed and therefore cannot be used any longer.A new channel has to be created first.
-
org.jgroups.JChannel.send()
Sends a message through the protocol stack. Implements the Transport interface.
@param msg the message to be sent through the protocol stack,the destination of the message is specified inside the message itself
@exception ChannelNotConnectedException
@exception ChannelClosedException
-
org.jinstagram.auth.model.OAuthRequest.send()
-
org.jitterbit.integration.client.ui.interchange.entity.message.TestEmailSender.send()
Tries to send a test email according to the given EmailMessage
definition.
-
org.jivesoftware.openfire.muc.MUCRole.send()
Sends a packet to the user.
@param packet The packet to send
-
org.jivesoftware.openfire.muc.MUCRoom.send()
Sends a packet to the user.
@param packet The packet to send
-
org.jpos.iso.ISOChannel.send()
sends an ISOMsg over the TCP/IP session
@param m the Message to be sent
@exception IOException
@exception ISOException
-
org.jpos.iso.ISOSource.send()
sends (or hands back) an ISOMsg
@param m the Message to be sent
@exception IOException
@exception ISOException
@exception ISOFilter.VetoException ;
-
org.jpos.iso.channel.XMLChannel.send()
-
org.jruby.RubyModule.send()
-
org.jscep.transaction.EnrollmentTransaction.send()
Sends the request to the SCEP server and processes the response..
@return the transaction state as returned by the SCEP server.
@throws TransactionException if any transaction-related error occurs.
-
org.jscep.transaction.NonEnrollmentTransaction.send()
Sends the request and processes the server response.
If the server returns a pending response, this method will throw a TransactionException, since this is unexpected behaviour.
@return the state as returned by the SCEP server.
@throws TransactionException if an error was encountered when sending this transaction.
-
org.jscep.transaction.Transaction.send()
Sends the request and processes the server response.
@return the state as return by the SCEP server.
@throws TransactionException if an error was encountered when sending this transaction.
-
org.jxchange.client.cdo121.JXCdoMessage.Send()
The Send method sends the message to the recipients through the messaging system. All params are optional.
@return
@throws JXCdoException
-
org.mortbay.cometd.Transport.send()
-
org.mortbay.jetty.client.HttpClient.send()
-
org.mule.api.client.LocalMuleClient.send()
-
org.mule.api.client.MuleClient.send()
Sends an event synchronously to a endpointUri via a Mule server and a resulting message is returned.
@param url the Mule URL used to determine the destination and transport of themessage
@param payload the object that is the payload of the event
@param messageProperties any properties to be associated with the payload. Inthe case of Jms you could set the JMSReplyTo property in these properties.
@return A return message, this could be null
if the thecomponents invoked explicitly sets a return as null
.
@throws org.mule.api.MuleException
-
org.mule.client.DefaultLocalMuleClient.send()
-
org.mule.extras.client.MuleClient.send()
-
org.mule.module.client.MuleClient.send()
Sends an event synchronously to a endpointUri via a Mule server and a resulting message is returned.
@param url the Mule URL used to determine the destination and transport of themessage
@param payload the object that is the payload of the event
@param messageProperties any properties to be associated with the payload. Inthe case of Jms you could set the JMSReplyTo property in these properties.
@return A return message, this could be null
if the the components invokedexplicitly sets a return as null
.
@throws org.mule.api.MuleException
-
org.mule.transport.udp.util.UdpClient.send()
-
org.mule.umo.provider.UMOMessageDispatcher.send()
-
org.nasutekds.server.util.EMailMessage.send()
Attempts to send this message to the intended recipient(s). This will use the mail server(s) defined in the Directory Server mail handler configuration. If multiple servers are specified and the first is unavailable, then the other server(s) will be tried before returning a failure to the caller.
@throws MessagingException If a problem occurred while attempting to sendthe message.
-
org.nfctools.nfcip.NFCIPConnection.send()
-
org.nutz.http.sender.FilePostSender.send()
-
org.nxplanner.mail.EmailMessage.send()
-
org.objectweb.joram.client.connector.OutboundProducer.send()
Delegates the call to the wrapped producer.
-
org.openbravo.erpCommon.businessUtility.EMail.send()
-
org.openhab.core.items.GroupItem.send()
-
org.openntf.domino.Document.send()
-
org.openntf.domino.email.DominoEmail.send()
-
org.openrdf.http.client.connections.HTTPRequest.send()
-
org.opensocial.Client.send()
Submits the passed {@link Request} to the associated {@link Provider} andreturns the container's response data as a {@link Response} object.
@param request Request object (typically returned from static methods inservice classes) encapsulating all request data including endpoint, HTTP method, and any required parameters
@return Response object encapsulating the response data returnedby the container
@throws RequestException if the passed request cannot be serialized, thecontainer returns an error code, or the response cannot be parsed
@throws IOException if an I/O error prevents a connection from beingopened or otherwise causes request transmission to fail
-
org.ops4j.pax.exam.sample9.pde.Notifier.send()
-
org.pdf4j.saxon.event.Sender.send()
Send the contents of a Source to a Receiver.
@param source the source to be copied
@param receiver the destination to which it is to be copied
-
org.pentaho.platform.scheduler2.email.Emailer.send()
-
org.picketlink.identity.federation.api.soap.SOAPSAMLXACML.send()
Given an xacml request
@param endpoint
@param issuer
@param xacmlRequest
@return
@throws ProcessingException
@throws SOAPException
@throws ParsingException
-
org.picketlink.identity.federation.web.util.IDPWebRequestUtil.send()
Send a response
@param holder
@throws GeneralSecurityException
@throws IOException
-
org.pircbotx.Channel.send()
-
org.port.Port.send()
-
org.projectforge.mail.SendMail.send()
@param composedMessage
@param workdir
@param attachmentfiles
@return true for successful sending, otherwise an exception will be thrown.
@throws UserException if to address is not given.
@throws InternalErrorException due to technical failures.
-
org.projectodd.stilts.stomp.client.ClientTransaction.send()
-
org.projectodd.stilts.stomp.client.StompClient.send()
-
org.python.pydev.logging.ping.AsyncLogPing.send()
Adds operation and schedules job to treat it later.
-
org.rstudio.core.client.jsonrpc.RpcRequest.send()
-
org.runningman.mailutils.SMTPSender.send()
-
org.scribe.model.OAuthRequest.send()
-
org.scribe.model.ProxyOAuthRequest.send()
-
org.seattlegamer.spacegame.core.Bus.send()
-
org.seattlegamer.spacegame.core.BusImpl.send()
-
org.serviceconnector.api.cln.SCSessionService.send()
Send with default operation timeout. Send is an asynchronous operation with the SC. Any reply will be informed over the callback.
@param requestMsg the request message
@throws SCServiceException session not active (not created yet or dead)
pending request, no second request allowed
send on SC failed
@throws SCMPValidatorException send message is null
-
org.serviceconnector.net.connection.IConnection.send()
Send and receive asynchronous operation.
@param scmp the scmp
@param callback the callback
@throws Exception the exception
-
org.servicemix.client.DefaultServiceMixClient.send()
-
org.servicemix.client.ServiceMixClient.send()
Sends the message exchange to the endpoint.
@param exchange
@throws MessagingException
-
org.servicemix.components.util.ComponentSupport.send()
-
org.sgx.yuigwt.yui.io.IO.send()
-
org.snmp4j.Snmp.send()
-
org.sonatype.nexus.bootstrap.monitor.CommandMonitorTalker.send()
Sends a command to a {@link CommandMonitorThread} on configured host/port.
@param command to send. Cannot be null.
@throws Exception Re-thrown if sending command fails
-
org.springframework.amqp.rabbit.core.RabbitTemplate.send()
-
org.springframework.integration.MessageChannel.send()
-
org.springframework.integration.channel.DirectChannel.send()
-
org.springframework.integration.channel.MessageChannel.send()
-
org.springframework.integration.channel.PublishSubscribeChannel.send()
-
org.springframework.integration.channel.QueueChannel.send()
-
org.springframework.integration.core.MessageChannel.send()
-
org.springframework.integration.core.MessagingTemplate.send()
-
org.springframework.integration.core.PollableChannel.send()
-
org.springframework.integration.core.SubscribableChannel.send()
-
org.springframework.integration.smpp.core.SmesMessageSpecification.send()
send the message on its way.
todo can we do something smart here or through an adapter to handle the situation where we have asked for a message receipt? what about if we're using a message receipt
and we're only a receiver or a sender connection and not a transceiver? We need gateway semantics across two unidirectional SMPPSessions, then
@return the messageId(s) (required if you want to then track itor correlate it with message receipt confirmations)
@throws Exception the{@link SMPPSession#submitShortMessage(String,org.jsmpp.bean.TypeOfNumber,org.jsmpp.bean.NumberingPlanIndicator,String,org.jsmpp.bean.TypeOfNumber,org.jsmpp.bean.NumberingPlanIndicator,String,org.jsmpp.bean.ESMClass,byte,byte,String,String,org.jsmpp.bean.RegisteredDelivery,byte,org.jsmpp.bean.DataCoding,byte,byte[],org.jsmpp.bean.OptionalParameter)}method throws lots of Exceptions, including {@link java.io.IOException}
-
org.springframework.jms.core.JmsTemplate.send()
-
org.springframework.mail.MailSender.send()
Send the given simple mail message.
@param simpleMessage the message to send
@throws org.springframework.mail.MailParseException in case of failure when parsing the message
@throws org.springframework.mail.MailAuthenticationException in case of authentication failure
@throws org.springframework.mail.MailSendException in case of failure when sending the message
-
org.springframework.mail.javamail.JavaMailSender.send()
Send the given JavaMail MIME message. The message needs to have been created with {@link #createMimeMessage()}.
@param mimeMessage message to send
@throws org.springframework.mail.MailAuthenticationException in case of authentication failure
@throws org.springframework.mail.MailSendException in case of failure when sending the message
@see #createMimeMessage
-
org.springframework.mail.javamail.JavaMailSenderImpl.send()
-
org.springframework.messaging.MessageChannel.send()
Send a {@link Message} to this channel. If the message is sent successfully,the method returns {@code true}. If the message cannot be sent due to a non-fatal reason, the method returns {@code false}. The method may also throw a RuntimeException in case of non-recoverable errors.
This method may block indefinitely, depending on the implementation. To provide a maximum wait time, use {@link #send(Message,long)}.
@param message the message to send
@return whether or not the message was sent
-
org.springframework.messaging.SubscribableChannel.send()
-
org.springframework.ws.transport.FaultAwareWebServiceConnection.send()
-
org.springframework.ws.transport.WebServiceConnection.send()
Sends the given message using this connection.
@param message the message to be sent
@throws IOException in case of I/O errors
-
org.springframework.xd.dirt.test.source.NamedChannelSource.send()
-
org.structr.websocket.StructrWebSocket.send()
-
org.switchyard.Exchange.send()
Sends the specified message as part of this message exchange.
Implementations must throw an {@link IllegalStateException} if this method iscalled when the Exchange {@link #getState() state} is in {@link ExchangeState#FAULT}.
@param message message to send
-
org.talamonso.OMAPI.Objects.Host.send()
-
org.teavm.dom.ajax.XMLHttpRequest.send()
-
org.terasology.entitySystem.entity.EntityRef.send()
Transmits an event to this entity
@param event
-
org.terasology.network.Client.send()
-
org.timepedia.chronoscope.gviz.api.client.Query.send()
-
org.vaadin.console.client.util.ClientCommUtils.Transcation.send()
-
org.vertx.java.core.eventbus.EventBus.send()
Send a message
@param address The address to send it to
@param message The message
-
org.voltcore.messaging.Mailbox.send()
Send a serializable object to a specific site and mailbox. This just forwards to the Messenger's send method of the instance that generated this mailbox for now.
@param hsId The id of the destination site/host.
@param message A serializable object to be sent to another mailbox.
@throws MessagingException Throws an exception if the destinationmailbox cannot be reached (maybe) or if an exception is thrown during serialization.
-
org.waveprotocol.box.webclient.client.atmosphere.AtmosphereConnectionImpl.send()
-
org.xbib.elasticsearch.websocket.client.WebSocketClient.send()
Send data to server
@param frame Data for sending
@return Write future. Will fire when the data is sent.
-
org.xbib.elasticsearch.websocket.client.WebSocketClientRequest.send()
-
org.xbill.DNS.ExtendedResolver.send()
Sends a message and waits for a response. Multiple servers are queried, and queries are sent multiple times until either a successful response is received, or it is clear that there is no successful response.
@param query The query to send.
@return The response.
@throws IOException An error occurred while sending or receiving.
-
org.xbill.DNS.Resolver.send()
Sends a message and waits for a response.
@param query The query to send.
@return The response
@throws IOException An error occurred while sending or receiving.
-
org.xbill.DNS.SimpleResolver.send()
Sends a message to a single server and waits for a response. No checking is done to ensure that the response is associated with the query.
@param query The query to send.
@return The response.
@throws IOException An error occurred while sending or receiving.
-
org.xlightweb.IHttpExchange.send()
send the response. If the content-length header is not set, the message will send in chunked mode. This send method will be used if the body size is unknown by sending the header.
By calling the {@link IHttpMessage#getProtocolVersion()} method of the request, it can be verified, if the requestorsupports a chunked responses (HTTP/1.0 request)
@param header the header
@return the body handle to write
@throws IOException if an exception occurs
@throws IllegalStateException if a response has already been send
-
org.xlightweb.client.HttpClientConnection.send()
{@inheritDoc}
-
org.xlightweb.client.IHttpClientEndpoint.send()
send the request. If the content-length header is not set, the message will send in chunked mode
@param requestHeader the request header
@param responseHandler the response handler or null
(supported: {@link IHttpRequestHandler}, {@link IHttpSocketTimeoutHandler})
@return the body handle to write
@throws ConnectException if an error occurred while attempting to connect to a remote address and port.
@throws IOException if an exception occurs
-
org.xmlBlaster.jms.XBMessageProducer.send()
-
org.zeromq.ZFrame.send()
Method to call org.zeromq.Socket send() method.
@param socket 0MQ socket to send on
@param flags Valid send() method flags, defined in org.zeromq.ZMQ class
@return True if success, else False
-
org.zeromq.ZMQ.Socket.send()
-
org.zeromq.ZMsg.send()
Send message to 0MQ socket.
@param socket 0MQ socket to send ZMsg on.
-
placeholder.http.HttpRequest.send()
Send request.
-
pt.opensoft.mail.SimpleEmail.send()
-
pt.utl.ist.fenix.tools.util.EMail.send()
-
ptolemy.actor.IOPort.send()
Send the specified token to all receivers connected to the specified channel. Tokens are in general immutable, so each receiver is given a reference to the same token and no clones are made. If the port is not connected to anything, or receivers have not been created in the remote port, or the channel index is out of range, or the port is not an output port, then just silently return. This behavior makes it easy to leave output ports unconnected when you are not interested in the output. The transfer is accomplished by calling the put() method of the remote receivers. If the port is not connected to anything, or receivers have not been created in the remote port, then just return.
Some of this method is read-synchronized on the workspace. Since it is possible for a thread to block while executing a put, it is important that the thread does not hold read access on the workspace when it is blocked. Thus this method releases read access on the workspace before calling put.
@param channelIndex The index of the channel, from 0 to width-1
@param token The token to send
@exception NoRoomException If there is no room in the receiver.
@exception IllegalActionException Not thrown in this base class.
-
ptolemy.actor.TypedIOPort.send()
Send a token to the specified channel, checking the type and converting the token if necessary. If the port is not connected to anything, or receivers have not been created in the remote port, or the channel index is out of range, or the port is not an output port, then just silently return. This behavior makes it easy to leave output ports unconnected when you are not interested in the output. If the type of the specified token is the type of this port, or the token can be converted to that type losslessly, the token is sent to all receivers connected to the specified channel. Otherwise, IllegalActionException is thrown. Before putting the token into the destination receivers, this method also checks the type of the remote input port, and converts the token if necessary. The conversion is done by calling the convert() method of the type of the remote input port.
Some of this method is read-synchronized on the workspace. Since it is possible for a thread to block while executing a put, it is important that the thread does not hold read access on the workspace when it is blocked. Thus this method releases read access on the workspace before calling put.
@param channelIndex The index of the channel, from 0 to width-1.
@param token The token to send.
@exception IllegalActionException If the token to be sent cannotbe converted to the type of this port, or if the token is null.
@exception NoRoomException If there is no room in the receiver.
-
quickfix.Session.send()
-
rabbit.html.HtmlBlock.send()
Send this block (but not the rest part) on the given stream.
@param out the Stream to send the data on.
@throws IOException if writing the data fails.
-
ratpack.http.Response.send()
Sends the response back to the client, with no body.
-
rocks.xmpp.core.session.TestXmppSession.send()
-
rocks.xmpp.core.session.XmppSession.send()
Sends an XML element to the server, usually a stanza, i.e. a message, presence or IQ.
@param element The XML element.
-
service.BusinessService.send()
-
service.DefaultBusinessServiceImpl.send()
-
sos.net.SOSMail.send()
Nachricht versenden
@throws java.lang.Exception
-
sos.net.SOSMailOrder.send()
-
sos.spooler.Web_service_response.send()
-
sun.security.krb5.internal.TCPClient.send()
-
sun.security.krb5.internal.UDPClient.send()
-
tachyon.worker.nio.DataServerMessage.send()
Send this message to the specified socket channel. Make sure this is a send message.
@param socketChannel The socket channel to send to
@throws IOException
-
unibg.overencrypt.client.OverEncryptClient.send()
-
zephyropen.command.Command.send()
Send this command to the output channel
-
zmq.SocketBase.send()