- p1 - Variable in class net.dempsy.ringbuffer.RingBufferConsumerControl
-
Making this public avoids it being optimized away
- p2 - Variable in class net.dempsy.ringbuffer.RingBufferConsumerControl
-
Making this public avoids it being optimized away
- p3 - Variable in class net.dempsy.ringbuffer.RingBufferConsumerControl
-
Making this public avoids it being optimized away
- p4 - Variable in class net.dempsy.ringbuffer.RingBufferConsumerControl
-
Making this public avoids it being optimized away
- p5 - Variable in class net.dempsy.ringbuffer.RingBufferConsumerControl
-
Making this public avoids it being optimized away
- p6 - Variable in class net.dempsy.ringbuffer.RingBufferConsumerControl
-
Making this public avoids it being optimized away
- poll(long, T, ConditionPoll.Condition<T>) - Static method in class net.dempsy.utils.test.ConditionPoll
-
Poll for a given condition for timeoutMillis milliseconds.
- poll(T, ConditionPoll.Condition<T>) - Static method in class net.dempsy.utils.test.ConditionPoll
-
- poll(ConditionPoll.Condition) - Static method in class net.dempsy.utils.test.ConditionPoll
-
- pos - Variable in class net.dempsy.util.io.MessageBufferInput
-
The index of the next character to read from the input stream buffer.
- position - Variable in class net.dempsy.util.io.MessageBufferOutput
-
The number of valid bytes in the buffer.
- postRegister(Kryo) - Method in interface net.dempsy.serialization.kryo.KryoOptimizer
-
The implementor should provide whatever additional class specific optimizations they
would like to make.
- preemptWorkerAndWait() - Method in class net.dempsy.util.executor.RunningEventSwitch
-
The main thread uses this method when it needs to preempt the worker and
wait for the worker to finish before continuing.
- preRegister(Kryo) - Method in interface net.dempsy.serialization.kryo.KryoOptimizer
-
The implementor should provide whatever class specific optimizations they
would like to make.
- process() - Method in interface net.dempsy.cluster.ClusterInfoWatcher
-
- process(WatchedEvent) - Method in class net.dempsy.cluster.zookeeper.ZookeeperSession.WatcherProxy
-
- process(WatchedEvent) - Method in class net.dempsy.cluster.zookeeper.ZookeeperSession.ZkWatcher
-
- propertiesChanged() - Method in interface net.dempsy.distconfig.PropertiesWatcher
-
- PropertiesReader - Interface in net.dempsy.distconfig
-
Implementations of this interface can be used to retrieve a set of properties while optionally registering for updates when properties change.
- PropertiesReader.VersionedProperties - Class in net.dempsy.distconfig
-
- PropertiesStore - Class in net.dempsy.distconfig
-
This is a abstraction for storing/sharing distributed properties.
- PropertiesStore() - Constructor for class net.dempsy.distconfig.PropertiesStore
-
- PropertiesWatcher - Interface in net.dempsy.distconfig
-
Callback interface used to register for changes to the current distributed properties.
- proxied - Variable in class net.dempsy.serialization.util.ClassTracker
-
- publish(long) - Method in class net.dempsy.ringbuffer.RingBufferControl
-
Once the publisher has readied the buffer entries that were claimed, this method
allows the consumer to be notified that they are ready.
- publish(long) - Method in class net.dempsy.ringbuffer.RingBufferControlMulticaster
-
Once the publisher has readied the buffer entries that were claimed, this method
allows the subscribers to be notified that they are ready.
- publish(long) - Method in class net.dempsy.ringbuffer.RingBufferControlWorkerPool
-
Once the publisher has readied the buffer entries that were claimed, this method
allows the subscribers to be notified that they are ready.
- publishCursor - Variable in class net.dempsy.ringbuffer.RingBufferConsumerControl
-
- publishStop() - Method in class net.dempsy.ringbuffer.RingBufferControl
-
- publishStop() - Method in class net.dempsy.ringbuffer.RingBufferControlMulticaster
-
- publishStop() - Method in class net.dempsy.ringbuffer.RingBufferControlWorkerPool
-
- push(Properties) - Method in class net.dempsy.distconfig.apahcevfs.ApacheVfsPropertiesStore
-
- push(Properties) - Method in class net.dempsy.distconfig.clusterinfo.ClusterInfoPropertiesStore
-
- push(Properties) - Method in class net.dempsy.distconfig.PropertiesStore
-
This will basically clear the existing properties and replace them with the new set.
- put(K, V) - Method in class net.dempsy.util.StupidHashMap
-
- putAll(Map<? extends K, ? extends V>) - Method in class net.dempsy.util.StupidHashMap
-
- putIfAbsent(K, V) - Method in class net.dempsy.util.StupidHashMap
-
- read(PropertiesWatcher) - Method in class net.dempsy.distconfig.apahcevfs.ApacheVfsPropertiesReader
-
- read(PropertiesWatcher) - Method in class net.dempsy.distconfig.classpath.ClasspathPropertiesReader
-
- read(PropertiesWatcher) - Method in class net.dempsy.distconfig.clusterinfo.ClusterInfoPropertiesReader
-
- read(PropertiesWatcher) - Method in interface net.dempsy.distconfig.PropertiesReader
-
Retrieves the latest
Properties
file that's been registered.
- read() - Method in class net.dempsy.util.io.MessageBufferInput
-
Reads the next byte of data from this input stream.
- read(byte[], int, int) - Method in class net.dempsy.util.io.MessageBufferInput
-
Reads up to len
bytes of data into an array of bytes from this input stream.
- readByteArray() - Method in class net.dempsy.util.io.MessageBufferInput
-
- readShort() - Method in class net.dempsy.util.io.MessageBufferInput
-
- recheck(Supplier<T>) - Static method in class net.dempsy.util.Functional
-
- recheck(Runnable) - Static method in class net.dempsy.util.Functional
-
- recheck(Supplier<T>, Class<E>) - Static method in class net.dempsy.util.Functional
-
- recheck(Runnable, Class<E>) - Static method in class net.dempsy.util.Functional
-
- recursiveMkdir(String, Object, DirMode, DirMode) - Method in interface net.dempsy.cluster.ClusterInfoSession
-
- Registration - Class in net.dempsy.serialization.kryo
-
This class holds Kryo class registration information.
- Registration(String, int) - Constructor for class net.dempsy.serialization.kryo.Registration
-
Use this constructor to assign a class an id in a Kryo registration.
- Registration(String) - Constructor for class net.dempsy.serialization.kryo.Registration
-
Use this constructor to register a class but let Kryo assign the id.
- release() - Method in class net.dempsy.util.SpinLock
-
- remove(Object) - Method in class net.dempsy.util.StupidHashMap
-
- removeWorker(RingBufferConsumerControl) - Method in class net.dempsy.ringbuffer.RingBufferControlWorkerPool
-
- replace(byte[]) - Method in class net.dempsy.util.io.MessageBufferOutput
-
Completely replace the underlying buffer.
- reset() - Static method in class net.dempsy.cluster.local.LocalClusterSessionFactory
-
- reset() - Method in class net.dempsy.util.io.MessageBufferInput
-
Resets the buffer to the marked position.
- reset() - Method in class net.dempsy.util.io.MessageBufferOutput
-
Resets the count
field of this byte array output stream to zero, so that all currently accumulated output in the output stream is discarded.
- resetDelay - Variable in class net.dempsy.cluster.zookeeper.ZookeeperSession
-
- reverseRange(int, int) - Static method in class net.dempsy.util.Functional
-
Create's an IntStream that runs in reverse.
- RingBufferConsumerControl - Class in net.dempsy.ringbuffer
-
This code is substantially based on the ingenious work done by Martin Thompson
on what he calls "Mechanical Sympathy." It leans heavily on the source code
from version 3.0.0.beta2 of the LMAX-exchange Disruptor but has been completely
refactored in order to invert separate the control mechanism from what is being
controlled and to simplify the API.
- RingBufferConsumerControl(int, RingBufferConsumerControl.ConsumerWaitStrategy, Sequence) - Constructor for class net.dempsy.ringbuffer.RingBufferConsumerControl
-
- RingBufferConsumerControl(int, RingBufferConsumerControl.ConsumerWaitStrategy, Sequence, PaddedLong) - Constructor for class net.dempsy.ringbuffer.RingBufferConsumerControl
-
- RingBufferConsumerControl.ConsumerWaitStrategy - Interface in net.dempsy.ringbuffer
-
This interface can be implemented to provide various custom wait strategies for the consumer side of the control.
- RingBufferConsumerIterator<T> - Class in net.dempsy.ringbuffer
-
- RingBufferConsumerIterator(Iterator<T>, int, int) - Constructor for class net.dempsy.ringbuffer.RingBufferConsumerIterator
-
- RingBufferConsumerIterator(Iterator<T>, RingBufferConsumerIterator.Consumer<T>[], int, boolean) - Constructor for class net.dempsy.ringbuffer.RingBufferConsumerIterator
-
- RingBufferConsumerIterator.Consumer<R> - Interface in net.dempsy.ringbuffer
-
- RingBufferControl - Class in net.dempsy.ringbuffer
-
This code is substantially based on the ingenious work done by Martin Thompson on what he calls "Mechanical Sympathy." It leans heavily on the
source code from version 3.0.0.beta2 of the LMAX-exchange Disruptor but has been completely refactored in order to invert separate the control
mechanism from what is being controlled and to simplify the API.
- RingBufferControl(int) - Constructor for class net.dempsy.ringbuffer.RingBufferControl
-
- RingBufferControl(int, RingBufferConsumerControl.ConsumerWaitStrategy) - Constructor for class net.dempsy.ringbuffer.RingBufferControl
-
- RingBufferControlMulticaster - Class in net.dempsy.ringbuffer
-
This is a helper class for managing a set of
RingBufferControl
s for use in a "single-publisher to multi-consumer" thread configuration
where everything published is "multicast" to all consumers.
- RingBufferControlMulticaster(int, int) - Constructor for class net.dempsy.ringbuffer.RingBufferControlMulticaster
-
- RingBufferControlMultiplexor - Class in net.dempsy.ringbuffer
-
This is a helper class for managing a set of
RingBufferControl
s for use in a "multiple-publisher to single-consumer" thread configuration.
- RingBufferControlMultiplexor(int, int) - Constructor for class net.dempsy.ringbuffer.RingBufferControlMultiplexor
-
- RingBufferControlMultiplexor(int, Object...) - Constructor for class net.dempsy.ringbuffer.RingBufferControlMultiplexor
-
- RingBufferControlWorkerPool - Class in net.dempsy.ringbuffer
-
This is a helper class for managing a set of
RingBufferControl
s for use in a "single-publisher to multi-consumer" thread configuration
where the consumers are workers reading from the queued data.
- RingBufferControlWorkerPool(int) - Constructor for class net.dempsy.ringbuffer.RingBufferControlWorkerPool
-
- RingBufferControlWorkerPool(int, RingBufferConsumerControl.ConsumerWaitStrategy) - Constructor for class net.dempsy.ringbuffer.RingBufferControlWorkerPool
-
- rmdir(String) - Method in interface net.dempsy.cluster.ClusterInfoSession
-
This will remove the directory stored at the path.
- rmdir(String) - Method in class net.dempsy.cluster.local.LocalClusterSessionFactory.LocalSession
-
- rmdir(String) - Method in class net.dempsy.cluster.zookeeper.ZookeeperSession
-
- run(Iterator<R>) - Method in interface net.dempsy.ringbuffer.RingBufferConsumerIterator.Consumer
-
- run() - Method in class net.dempsy.util.executor.AutoDisposeSingleThreadScheduler.Cancelable
-
- run() - Method in interface net.dempsy.util.Functional.RunnableThrows
-
- run() - Method in class net.dempsy.utils.test.SocketTimeout
-
- RunningEventSwitch - Class in net.dempsy.util.executor
-
This is a helper class for coordinating a "restartable" job.
- RunningEventSwitch(AtomicBoolean) - Constructor for class net.dempsy.util.executor.RunningEventSwitch
-
- RunningEventSwitch() - Constructor for class net.dempsy.util.executor.RunningEventSwitch
-