-
EDU.oswego.cs.dl.util.concurrent.LinkedQueue.poll()
-
EDU.oswego.cs.dl.util.concurrent.Slot.poll()
-
co.cask.cdap.data2.transaction.stream.StreamConsumer.poll()
Retrieves up to {@code maxEvents} of {@link StreamEvent} from the stream.
@param maxEvents Maximum number of events to retrieve
@param timeout Maximum of time to spend on trying to read up to maxEvents
@param timeoutUnit Unit for the timeout
@return An instance of {@link DequeueResult} which carries {@link StreamEvent}s inside.
@throws IOException If there is error while reading events
@throws InterruptedException If interrupted while waiting
-
com.googlecode.flaxcrawler.concurrent.BerkleyQueue.poll()
-
com.hazelcast.core.IQueue.poll()
{@inheritDoc}
-
com.hazelcast.core.TransactionalQueue.poll()
{@inheritDoc}
-
com.netflix.servo.publish.JmxMetricPoller.poll()
{@inheritDoc}
-
com.netflix.servo.publish.MetricPoller.poll()
Fetch the current values for a set of metrics that match the provided filter. This method should be cheap, thread-safe, and interruptible so that it can be called frequently to collect metrics at a regular interval.
@param filter retricts the set of metrics
@return list of current metric values
-
com.netflix.suro.input.thrift.MessageSetProcessor.poll()
-
com.opengamma.engine.view.execution.ViewCycleExecutionSequence.poll()
Gets the next execution options in the sequence. This is a destructive operation; it should be used only when intending to begin a view cycle with the options returned.
@param defaultExecutionOptions the default execution options, may be null
@return the execution options for the next cycle, null if there are no further cycles to execute
-
com.vividsolutions.jts.util.PriorityQueue.poll()
Remove the smallest item from the priority queue.
@return the smallest item.
@return null if empty
-
de.scoopgmbh.copper.test.backchannel.BackChannelQueue.poll()
-
edu.emory.mathcs.backport.java.util.Queue.poll()
Retrieves and removes the head of this queue, or returns null if this queue is empty.
@return the head of this queue, or null if this queue is empty
-
hudson.scm.SCM.poll()
Convenience method for the caller to handle the backward compatibility between pre 1.345 SCMs.
-
io.thp.psmove.PSMove.poll()
-
java.lang.ref.ReferenceQueue.poll()
Polls this queue to see if a reference object is available. If one is available without further delay then it is removed from the queue and returned. Otherwise this method immediately returns null.
@return A reference object, if one was immediately available,otherwise null
-
java.nio.file.WatchService.poll()
Retrieves and removes the next watch key, or {@code null} if none arepresent.
@return the next watch key, or {@code null}
@throws ClosedWatchServiceException if this watch service is closed
-
java.util.ArrayDeque.poll()
Retrieves and removes the head of the queue represented by this deque (in other words, the first element of this deque), or returns
null if this deque is empty.
This method is equivalent to {@link #pollFirst}.
@return the head of the queue represented by this deque, ornull if this deque is empty
-
java.util.LinkedList.poll()
Retrieves and removes the head (first element) of this list
@return the head of this list, or null if this list is empty
@since 1.5
-
java.util.PriorityQueue.poll()
-
java.util.Queue.poll()
Retrieves and removes the head of this queue, or returns null if this queue is empty.
@return the head of this queue, or null if this queue is empty
-
java.util.concurrent.ArrayBlockingQueue.poll()
-
java.util.concurrent.BlockingQueue.poll()
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
@param timeout how long to wait before giving up, in units of{@code unit}
@param unit a {@code TimeUnit} determining how to interpret the{@code timeout} parameter
@return the head of this queue, or {@code null} if thespecified waiting time elapses before an element is available
@throws InterruptedException if interrupted while waiting
-
java.util.concurrent.ConcurrentLinkedQueue.poll()
-
java.util.concurrent.ExecutorCompletionService.poll()
-
java.util.concurrent.LinkedBlockingDeque.poll()
-
java.util.concurrent.LinkedBlockingQueue.poll()
-
net.java.games.input.Controller.poll()
Polls axes for data. Returns false if the controller is no longer valid. Polling reflects the current state of the device when polled.
-
net.java.games.input.Keyboard.poll()
-
net.kuujo.copycat.spi.protocol.ProtocolClient.poll()
-
net.openhft.chronicle.sandbox.queue.LocalConcurrentBlockingObjectQueue.poll()
-
org.apache.geronimo.remoting.transport.async.Correlator.FutureResult.poll()
-
org.apache.mina.common.WriteRequestQueue.poll()
-
org.apache.mina.core.write.WriteRequestQueue.poll()
-
org.apache.oozie.event.EventQueue.poll()
Fetch single event from queue
@return event
-
org.apache.synapse.message.store.MessageStore.poll()
Retrieves and removes the first Message in this store. Message ordering will depend on the underlying implementation
@return first message context in the store
-
org.exoplatform.services.scheduler.QueueTasks.poll()
-
org.jboss.errai.bus.server.MessageQueue.poll()
-
org.jboss.errai.bus.server.api.MessageQueue.poll()
-
org.mule.util.queue.Queue.poll()
-
org.uberfire.java.nio.file.WatchService.poll()
-
org.zeromq.ZMQ.Poller.poll()
-
us.codecraft.webmagic.scheduler.Scheduler.poll()
get an url to crawl
@param task the task of spider
@return the url to crawl
-
utils.Keyboard.poll()
-
xbird.engine.XQEngine.poll()
-
xbird.engine.XQEngineClient.poll()