Package org.apache.storm.utils
Class JCQueue
- java.lang.Object
- 
- org.apache.storm.utils.JCQueue
 
- 
- All Implemented Interfaces:
- Closeable,- AutoCloseable
 
 public class JCQueue extends Object implements Closeable 
- 
- 
Nested Class SummaryNested Classes Modifier and Type Class Description static interfaceJCQueue.Consumerstatic interfaceJCQueue.ExitCondition
 - 
Constructor SummaryConstructors Constructor Description JCQueue(String queueName, String metricNamePrefix, int size, int overflowLimit, int producerBatchSz, IWaitStrategy backPressureWaitStrategy, String topologyId, String componentId, List<Integer> taskIds, int port, StormMetricRegistry metricRegistry)
 - 
Method SummaryAll Methods Instance Methods Concrete Methods Modifier and Type Method Description voidclose()intconsume(JCQueue.Consumer consumer)Non blocking.intconsume(JCQueue.Consumer consumer, JCQueue.ExitCondition exitCond)Non blocking.voidflush()if(batchSz>1) : Blocking call.intgetOverflowCount()intgetQueuedCount()doublegetQueueLoad()StringgetQueueName()booleanisEmptyOverflow()voidpublish(Object obj)Blocking call.voidrecordMsgDrop()intsize()booleantryFlush()if(batchSz>1) : Non-Blocking call.booleantryPublish(Object obj)Non-blocking call, returns false if full.booleantryPublishDirect(Object obj)Non-blocking call.booleantryPublishToOverflow(Object obj)Un-batched write to overflowQ.
 
- 
- 
- 
Constructor Detail- 
JCQueuepublic JCQueue(String queueName, String metricNamePrefix, int size, int overflowLimit, int producerBatchSz, IWaitStrategy backPressureWaitStrategy, String topologyId, String componentId, List<Integer> taskIds, int port, StormMetricRegistry metricRegistry) 
 
- 
 - 
Method Detail- 
getQueueNamepublic String getQueueName() 
 - 
closepublic void close() - Specified by:
- closein interface- AutoCloseable
- Specified by:
- closein interface- Closeable
 
 - 
consumepublic int consume(JCQueue.Consumer consumer) Non blocking. Returns immediately if Q is empty. Returns number of elements consumed from Q.
 - 
consumepublic int consume(JCQueue.Consumer consumer, JCQueue.ExitCondition exitCond) Non blocking. Returns immediately if Q is empty. Runs till Q is empty OR exitCond.keepRunning() return false. Returns number of elements consumed from Q.
 - 
sizepublic int size() 
 - 
getQueueLoadpublic double getQueueLoad() 
 - 
publishpublic void publish(Object obj) throws InterruptedException Blocking call. Retries till it can successfully publish the obj. Can be interrupted via Thread.interrupt().- Throws:
- InterruptedException
 
 - 
tryPublishpublic boolean tryPublish(Object obj) Non-blocking call, returns false if full.
 - 
tryPublishDirectpublic boolean tryPublishDirect(Object obj) Non-blocking call. Bypasses any batching that may be enabled on the recvQueue. Intended for sending flush/metrics tuples
 - 
tryPublishToOverflowpublic boolean tryPublishToOverflow(Object obj) Un-batched write to overflowQ. Should only be called by WorkerTransfer returns false if overflowLimit has reached
 - 
recordMsgDroppublic void recordMsgDrop() 
 - 
isEmptyOverflowpublic boolean isEmptyOverflow() 
 - 
getOverflowCountpublic int getOverflowCount() 
 - 
getQueuedCountpublic int getQueuedCount() 
 - 
flushpublic void flush() throws InterruptedExceptionif(batchSz>1) : Blocking call. Does not return until at least 1 element is drained or Thread.interrupt() is received if(batchSz==1) : NO-OP. Returns immediately. doesnt throw.- Throws:
- InterruptedException
 
 - 
tryFlushpublic boolean tryFlush() if(batchSz>1) : Non-Blocking call. Tries to flush as many as it can. Returns true if flushed at least 1. if(batchSz==1) : This is a NO-OP. Returns true immediately.
 
- 
 
-