-
akka.actor.Inbox.receive()
-
akka.testkit.TestActorRef.receive()
-
br.com.visualmidia.core.server.Communicate.receive()
-
ch.usi.dslab.bezerra.netwrapper.tcp.TCPReceiver.receive()
-
com.barchart.udt.SocketUDT.receive()
receive into byte[] array upto array.length
bytes
@return -1
: nothing received (non-blocking only)
=0
: timeout expired (blocking only)
>0
: normal receive, byte count
@see #receive0(int,int,byte[])
-
com.bj58.spat.gaea.client.communication.socket.CSocket.receive()
-
com.cloudbees.groovy.cps.Continuation.receive()
-
com.consol.citrus.messaging.Consumer.receive()
Receive message with default timeout.
@return
@param context
-
com.dp.nebula.wormhole.common.BufferedLineExchanger.receive()
Get next line of data which dumped to data destination.
@return next {@link ILine}.
-
com.ericsson.otp.erlang.OtpConnection.receive()
Receive a message from a remote process. This method blocks until a valid message is received or an exception is raised.
If the remote node sends a message that cannot be decoded properly, the connection is closed and the method throws an exception.
@return an object containing a single Erlang term.
@exception java.io.IOException if the connection is not active or a communication error occurs.
@exception OtpErlangExit if an exit signal is received from a process on the peer node.
@exception OtpAuthException if the remote node sends a message containing an invalid cookie.
-
com.ericsson.otp.erlang.OtpMbox.receive()
Block until a message arrives for this mailbox.
@return an {@link OtpErlangObject OtpErlangObject} representing the bodyof the next message waiting in this mailbox.
@exception OtpErlangDecodeException if the message can not be decoded.
@exception OtpErlangExit if a linked {@link OtpErlangPid pid} has exited or hassent an exit signal to this mailbox.
-
com.fly.test.activemqTest.ConsumerService.receive()
-
com.github.kevinsawicki.http.HttpRequest.receive()
Stream response body to file
@param file
@return this request
@throws HttpRequestException
-
com.google.greaze.rest.server.RestRequestBaseReceiver.receive()
-
com.google.greaze.webservice.server.RequestReceiver.receive()
-
com.griddynamics.gridkit.coherence.patterns.message.benchmark.BenchmarkMessage.receive()
-
com.hazelcast.client.SimpleClient.receive()
-
com.izforge.soapdtc.transport.HttpSoapTransport.receive()
Receive pattern for the SOAP HTTP binding.
@param uri the endpoint uri.
@param soapAction the soapAction
parameter, or null
@return the response SOAP message.
@throws SoapTransportException if an error occurs, including a SOAP fault when appropriate.
-
com.peterhi.net.Local.receive()
-
com.stuffwithstuff.magpie.interpreter.Channel.receive()
-
com.sun.jini.test.spec.jeri.mux.util.AcknowledgementMessage.receive()
-
com.sun.jini.test.spec.jeri.mux.util.ClientConnectionHeader.receive()
-
com.sun.jini.test.spec.jeri.mux.util.DataMessage.receive()
-
com.sun.jini.test.spec.jeri.mux.util.PingAckMessage.receive()
-
com.sun.jini.test.spec.jeri.mux.util.ServerConnectionHeader.receive()
-
com.sun.nio.sctp.SctpChannel.receive()
-
com.svanloon.game.wizard.network.MessageReceiver.receive()
-
de.danet.an.workflow.api.EventSubscriber.receive()
Receives the next audit event. This method blocks until the next event is received.
@return the audit event
@throws IOException if an error occurs
-
dijjer.io.xfer.BlockReceiver.receive()
-
fi.luomus.commons.kirjekyyhky.KirjekyyhkyAPIClient.receive()
Mark a form received. Form is moved to "archive".
@param id
@throws Exception
-
freenet.io.xfer.BlockReceiver.receive()
-
freenet.io.xfer.BulkReceiver.receive()
Receive the file.
@return True if the whole file was received, false otherwise.
-
java.net.DatagramSocket.receive()
Receives a datagram packet from this socket. When this method returns, the
DatagramPacket
's buffer is filled with the data received. The datagram packet also contains the sender's IP address, and the port number on the sender's machine.
This method blocks until a datagram is received. The length
field of the datagram packet object contains the length of the received message. If the message is longer than the packet's length, the message is truncated.
If there is a security manager, a packet cannot be received if the security manager's checkAccept
method does not allow it.
@param p the DatagramPacket
into which to placethe incoming data.
@exception IOException if an I/O error occurs.
@exception SocketTimeoutException if setSoTimeout was previously calledand the timeout has expired.
@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 java.net.DatagramSocket
@revised 1.4
@spec JSR-51
-
java.net.MulticastSocket.receive()
-
java.nio.channels.DatagramChannel.receive()
Get a datagram from this channel.
This method transfers the datagram from the channel into the target byte buffer and return the address of the datagram, if the datagram is available or will be available as this channel is in blocking mode. This method returns null
if the datagram is not available now and the channel is in non-blocking mode. The transfer start at the current position of the buffer, and the residual part of the datagram will be ignored if there is no efficient remaining in the buffer to store the datagram.
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 receive method of the DatagramSocket
class.
@param target The byte buffer to store the received datagram.
@return Address of the datagram if the transfer is performed, or null ifthe channel is in non-blocking mode and the datagrama are unavailable.
@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.
-
javax.bluetooth.L2CAPConnection.receive()
Reads a packet of data. The amount of data received in this operation is related to the value of ReceiveMTU. If the size of inBuf
is greater than or equal to ReceiveMTU, then no data will be lost. Unlike read()
on an java.io.InputStream
, if the size of inBuf
is smaller than ReceiveMTU, then the portion of the L2CAP payload that will fit into inBuf
will be placed in inBuf
, the rest will be discarded. If the application is aware of the number of bytes (less than ReceiveMTU) it will receive in any transaction, then the size of inBuf
can be less than ReceiveMTU and no data will be lost. If inBuf
is of length 0, all data sent in one packet is lost unless the length of the packet is 0.
@param inBuf byte array to store the received data
@return the actual number of bytes read; 0 if a zero length packet is received; 0 if inBuf
length is zero
@exception IOException if an I/O error occurs or the connection has been closed
@exception InterruptedIOException if the request timed out
@exception NullPointerException if inBuf
is null
-
javax.isolate.Link.receive()
Receives a copy of a message sent on this Link. The current thread will block in this method until a sender is available. When the sender and receiver rendezvous, the message will then be transferred. If multiple threads invoke this method on the same object, only one thread will receive any message at rendezvous and the other threads will contend for subsequent access to the rendezvous point. A normal return indicates that the message was received successfully. If an exception occured on the sender side, no rendezvous will occur, and no object will be transferred; the receiver will wait for the next successful send. If an exception occurs on the receive, the sender will see a successful transfer. This method never returns null. If the sending 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 receive() 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 the link while a thread is blocked in receive(), receive() 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; if not, control will return from the method with a valid LinkMessage object. However, even if InterruptedIOException is thrown, rendezvous and data transfer from the sending isolate may have occurred. In particular, undetected message loss between sender and receiver may occur. If a failure occurs due to the object being transferred between isolates an IOException may be thrown 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. The sender will see a successful transfer in these cases. If the current isolate is not a receiver on this Link an IllegalStateException will be thrown. The receiver will not rendezvous with a sender in this case.
@return
-
javax.jms.JMSConsumer.receive()
Receives the next message produced for this {@code JMSConsumer}.
This call blocks indefinitely until a message is produced or until this {@code JMSConsumer} is closed.
If this {@code receive} is done within a transaction, the JMSConsumer retains the message until the transaction commits.
@return the next message produced for this {@code JMSConsumer}, or null if this {@code JMSConsumer} is concurrently closed
@exception JMSRuntimeException if the JMS provider fails to receive the nextmessage due to some internal error.
-
javax.jms.MessageConsumer.receive()
-
javax.jms.QueueReceiver.receive()
-
javax.jms.TopicSubscriber.receive()
-
javax.microedition.io.DatagramConnection.receive()
-
javax.microedition.io.UDPDatagramConnection.receive()
-
javax.wireless.messaging.MessageConnection.receive()
-
net.floodlightcontroller.core.IOFMessageListener.receive()
This is the method Floodlight uses to call listeners with OpenFlow messages
@param sw the OpenFlow switch that sent this message
@param msg the message
@param cntx a Floodlight message context object you can use to pass information between listeners
@return the command to continue or stop the execution
-
net.rim.device.api.io.messaging.BlockingReceiverDestination.receive()
-
net.sf.laja.parser.engine2.Output.receive()
-
org.apache.activemq.ActiveMQMessageConsumer.receive()
Receives the next message produced for this message consumer.
This call blocks indefinitely until a message is produced or until this message consumer is closed.
If this receive
is done within a transaction, the consumer retains the message until the transaction commits.
@return the next message produced for this message consumer, or null ifthis message consumer is concurrently closed
-
org.apache.activemq.MessageAvailableConsumer.receive()
-
org.apache.activemq.transport.stomp.StompConnection.receive()
-
org.apache.axis2.engine.AxisEngine.receive()
This methods represents the inflow 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
@throws AxisFault
@see MessageContext
@see Phase
@see Handler
-
org.apache.axis2.engine.MessageReceiver.receive()
-
org.apache.axis2.transport.EmailReceiver.receive()
-
org.apache.camel.ConsumerTemplate.receive()
Receives from the endpoint, waiting until there is a response
Important: See {@link #doneUoW(Exchange)}
@param endpointUri the endpoint to receive from
@return the returned exchange
-
org.apache.camel.PollingConsumer.receive()
Waits until a message is available and then returns it. Warning that this method could block indefinitely if no messages are available.
@return the message exchange received.
-
org.apache.commons.net.CharGenUDPClient.receive()
Receive the reply data from the server. This will always be 512 bytes or less. Chargen and quote of the day only return one packet. Netstat and systat require multiple calls to receive() with timeout detection.
@return The reply data from the server.
@exception IOException If an error occurs while receiving the datagram.
-
org.apache.commons.net.EchoUDPClient.receive()
Receives echoed data and returns its length. The data may be divided up among multiple datagrams, requiring multiple calls to receive. Also, the UDP packets will not necessarily arrive in the same order they were sent.
@return Length of actual data received.
@exception IOException If an error occurs while receiving the data.
-
org.apache.commons.net.chargen.CharGenUDPClient.receive()
Receive the reply data from the server. This will always be 512 bytes or less. Chargen and quote of the day only return one packet. Netstat and systat require multiple calls to receive() with timeout detection.
@return The reply data from the server.
@exception IOException If an error occurs while receiving the datagram.
-
org.apache.commons.net.echo.EchoUDPClient.receive()
Receives echoed data and returns its length. The data may be divided up among multiple datagrams, requiring multiple calls to receive. Also, the UDP packets will not necessarily arrive in the same order they were sent.
@return Length of actual data received.
@exception IOException If an error occurs while receiving the data.
-
org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher.receive()
-
org.apache.sandesha2.msgreceivers.RMMessageReceiver.receive()
-
org.apache.servicemix.client.DefaultServiceMixClient.receive()
-
org.apache.servicemix.client.ServiceMixClient.receive()
Receives an inbound message exchange, blocking forever until one is available.
@return the received message exchange
@throws MessagingException
-
org.apache.soap.transport.SOAPTransport.receive()
Return a buffered reader to receive back the response to whatever was sent to whatever.
@return a reader to read the results from or null if that's notpossible.
-
org.apache.soap.transport.http.SOAPHTTPConnection.receive()
Return a buffered reader to receive back the response to whatever was sent to whatever.
@return a reader to read the results from or null if that's notpossible.
-
org.apache.sshd.common.scp.ScpHelper.receive()
-
org.apache.ws.security.common.CustomHandler.receive()
-
org.apache.wsif.util.jms.WSIFJMSDestination.receive()
Blocking receive for the wsif.syncrequest.timeout
@return the received message
-
org.apache.wss4j.dom.common.CustomHandler.receive()
-
org.codehaus.xfire.transport.Channel.receive()
-
org.drools.grid.generic.MessageResponseHandler.receive()
-
org.drools.runtime.pipeline.Action.receive()
-
org.eclipse.ecf.filetransfer.events.IIncomingFileTransferReceiveResumedEvent.receive()
Get incoming file transfer object by specifying a local File instance to save the received contents to.
@param localFileToSave the file on the local file system to receive and save the remote file. Must not be null
.
@param append if true
, and data received is appended to the given localFileToSave. If false
, data are written to the beginning of the given localFileToSave, and any existing contents are overwritten.
@return IIncomingFileTransfer the incoming file transfer object. Will notbe null
.
@throws IOException if localFileToSave cannot be opened for writing.
@since 2.0
-
org.eclipse.ecf.filetransfer.events.IIncomingFileTransferReceiveStartEvent.receive()
Get incoming file transfer object by specifying a local File instance to save the received contents to.
@param localFileToSave the file on the local file system to receive and save the remote file. Must not be null
. If the file already exists, its content will be overwritten by any data received.
@return IIncomingFileTransfer the incoming file transfer object. Will notbe null
.
@throws IOException if localFileToSave cannot be opened for writing
-
org.eclipse.jgit.transport.ReceivePack.receive()
Execute the receive task on the socket.
@param input raw input to read client commands and pack data from. Caller must ensure the input is buffered, otherwise read performance may suffer.
@param output response back to the Git network client. Caller must ensure the output is buffered, otherwise write performance may suffer.
@param messages secondary "notice" channel to send additional messages out through. When run over SSH this should be tied back to the standard error channel of the command execution. For most other network connections this should be null.
@throws IOException
-
org.exolab.jms.messagemgr.ConsumerEndpoint.receive()
Return the next available message to the client.
@param cancel if set, indictates to cancel the receive
@return the next message, or null
if none is available
@throws JMSException for any error
-
org.exoplatform.frameworks.ftpclient.data.FtpDataTransiver.receive()
-
org.fusesource.mqtt.client.BlockingConnection.receive()
-
org.fusesource.stomp.client.BlockingConnection.receive()
-
org.hornetq.api.core.client.ClientConsumer.receive()
Receives a message from a queue.
This call will block indefinitely until a message is received.
Calling this method on a closed consumer will throw a HornetQException.
@return a ClientMessage
@throws HornetQException if an exception occurs while waiting to receive a message
-
org.hornetq.core.client.impl.ClientConsumerInternal.receive()
-
org.javagroups.Channel.receive()
-
org.jboss.blacktie.jatmibroker.core.transport.Receiver.receive()
-
org.jboss.example.jms.stateless.bean.StatelessSessionExample.receive()
-
org.jboss.narayana.blacktie.jatmibroker.core.transport.Receiver.receive()
-
org.jboss.test.ws.jaxws.samples.dar.generated.reply.DarReplyEndpoint.receive()
@param arg0
-
org.jclouds.sqs.features.MessageApi.receive()
The ReceiveMessage action retrieves one or more messages from the specified queue. The ReceiveMessage action does not delete the message after it is retrieved. To delete a message, you must use the DeleteMessage action. For more information about message deletion in the message life cycle, see Message Lifecycle.
Note
Due to the distributed nature of the queue, a weighted random set of machines is sampled on a ReceiveMessage call. That means only the messages on the sampled machines are returned. If the number of messages in the queue is small (less than 1000), it is likely you will get fewer messages than you requested per ReceiveMessage call. If the number of messages in the queue is extremely small, you might not receive any messages in a particular ReceiveMessage response; in which case you should repeat the request.
@param queue from where you are receiving messages
@return message including the receipt handle you can use to delete it
-
org.jgroups.Channel.receive()
Receives a message, a view change or a block event. By using
setOpt
, the type of objects to be received can be determined (e.g., not views and blocks, just messages). The possible types returned can be:
Message
. Normal message Event
. All other events (used by JChannel) View
. A view change. BlockEvent
. A block event indicating that a flush protocol has been started, and we should not send any more messages. This event should be ack'ed by calling {@link org.jgroups.Channel#blockOk()} .Any messages sent after blockOk() returns might get blocked until the flush protocol has completed. UnblockEvent
. An unblock event indicating that the flush protocol has completed and we can resume sending messages SuspectEvent
. A notification of a suspected member. GetStateEvent
. The current state of the application should be returned using ReturnState
. SetStateEvent
. The state of a single/all members as requested previously by having called Channel.getState(s). ExitEvent
. Signals that this member was forced to leave the group (e.g., caused by the member being suspected.) The member can rejoin the group by calling open(). If the AUTO_RECONNECT is set (see setOpt()), the reconnect will be done automatically.
The
instanceof
operator can be used to discriminate between different types returned.
@param timeout Value in milliseconds. Value <= 0 means wait forever
@return A Message, View, BlockEvent, SuspectEvent, GetStateEvent, SetStateEvent orExitEvent, depending on what is on top of the internal queue.
@exception ChannelNotConnectedException The channel must be connected to receive messages.
@exception ChannelClosedException The channel is closed and therefore cannot be used any longer.A new channel has to be created first.
@exception TimeoutException Thrown when a timeout has occurred.
@deprecated Use a {@link Receiver} instead
-
org.jgroups.JChannel.receive()
Blocking receive method. This method returns the object that was first received by this JChannel and that has not been received before. After the object is received, it is removed from the receive queue.
If you only want to inspect the object received without removing it from the queue call JChannel.peek
If no messages are in the receive queue, this method blocks until a message is added or the operation times out
By specifying a timeout of 0, the operation blocks forever, or until a message has been received.
@param timeout the number of milliseconds to wait if the receive queue is empty. 0 means wait forever
@exception TimeoutException if a timeout occured prior to a new message was received
@exception ChannelNotConnectedException
@exception ChannelClosedException
@see JChannel#peek
-
org.jgroups.Receiver.receive()
-
org.jnode.net.NetworkLayer.receive()
Process a packet that has been received and matches getType()
@param skbuf
@param deviceAPI
@throws SocketException
-
org.jnode.net.NetworkLayerManager.receive()
Process a packet that has been received. The receive method of all those packettypes that have a matching type and allow the device(of the packet) is called. The packet is cloned if more then 1 packettypes want to receive the packet.
@param skbuf
-
org.jnode.net.ipv4.IPv4Protocol.receive()
Handle a received segment for this connection
@param hdr
@param skbuf
-
org.jpos.iso.ISOChannel.receive()
Receives an ISOMsg
@return the Message received
@exception IOException
@exception ISOException
-
org.jpos.iso.channel.X25Channel.receive()
-
org.jpos.iso.channel.XMLChannel.receive()
-
org.mobicents.mscontrol.MsSignalDetector.receive()
-
org.mule.extras.client.MuleClient.receive()
-
org.nasutekds.server.replication.protocol.ProtocolSession.receive()
Attempt to receive a ReplicationMsg. This method should block the calling thread until a ReplicationMsg is available or until an error condition. This method can only be called by a single thread and therefore does not need to implement any replication.
@return The ReplicationMsg that was received.
@throws IOException When error happened during IO process.
@throws ClassNotFoundException When the data received does extend theReplicationMsg class.
@throws DataFormatException When the data received is not formatted as aReplicationMsg.
@throws NotSupportedOldVersionPDUException If the received PDU is part ofan old protocol version and we do not support it.
-
org.nasutekds.server.replication.service.ReplicationBroker.receive()
Receive a message. This method is not multithread safe and should either always be called in a single thread or protected by a locking mechanism before being called. This is a wrapper to the method with a boolean version so that we do not have to modify existing tests.
@return the received message
@throws SocketTimeoutException if the timeout set by setSoTimeouthas expired
-
org.nfctools.nfcip.NFCIPConnection.receive()
-
org.springframework.amqp.core.AmqpTemplate.receive()
Receive a message if there is one from a default queue. Returns immediately, possibly with a null value.
@return a message or null if there is none waiting
@throws AmqpException if there is a problem
-
org.springframework.amqp.rabbit.core.RabbitTemplate.receive()
-
org.springframework.integration.channel.AbstractPollableChannel.receive()
-
org.springframework.integration.channel.MessageChannel.receive()
-
org.springframework.integration.channel.PollableChannel.receive()
-
org.springframework.integration.channel.QueueChannel.receive()
-
org.springframework.integration.core.MessagingOperations.receive()
-
org.springframework.integration.core.MessagingTemplate.receive()
-
org.springframework.integration.core.PollableChannel.receive()
-
org.springframework.jms.core.JmsOperations.receive()
Receive a message synchronously from the default destination, but only wait up to a specified time for delivery.
This method should be used carefully, since it will block the thread until the message becomes available or until the timeout value is exceeded.
This will only work with a default destination specified!
@return the message received by the consumer, or null
if the timeout expires
@throws JmsException checked JMSException converted to unchecked
-
org.springframework.jms.core.JmsTemplate.receive()
-
org.springframework.messaging.PollableChannel.receive()
Receive a message from this channel, blocking indefinitely if necessary.
@return the next available {@link Message} or {@code null} if interrupted
-
org.springframework.ws.server.MessageDispatcher.receive()
-
org.springframework.ws.soap.server.SoapMessageDispatcher.receive()
-
org.springframework.ws.transport.FaultAwareWebServiceConnection.receive()
-
org.springframework.ws.transport.WebServiceConnection.receive()
Receives a message using the given {@link WebServiceMessageFactory}. This method blocks until it receives, or returns {@code null} when no message is received.
@param messageFactory the message factory used for reading messages
@return the read message, or {@code null} if no message received
@throws IOException in case of I/O errors
-
org.springframework.ws.transport.WebServiceMessageReceiver.receive()
Receives the given message context. The given message context can be used to create a response.
@param messageContext the message context to be received
-
org.springframework.xd.dirt.test.sink.NamedChannelSink.receive()
-
org.xmlBlaster.client.I_XmlBlasterAccess.receive()
mlBlaster/doc/requirements/engine.qos.queryspec.QueueQuery.html">engine.qos.queryspec.QueueQuery requirement
@see javax.jms.MessageConsumer#receive
-
redis.netty.RedisDecoder.receive()
-
redis.netty4.RedisReplyDecoder.receive()
-
service.BusinessService.receive()
-
service.DefaultBusinessServiceImpl.receive()
-
sun.security.krb5.internal.TCPClient.receive()
-
sun.security.krb5.internal.UDPClient.receive()
-
y1.wms.Stock.receive()
Meetod, mis võtab lattu kaupa vastu. Kasutatakse iteraatoreid, et võtta parameetrina sisestatud tellimuse kauba ja selle koguse paarid ning sisestada need koos lattu.
@param order