A B C D E F G H I J K L M O P R S T W

A

add(Callback<T>) - Method in class org.jetlang.channels.SubscriberList
 
add(Disposable) - Method in interface org.jetlang.core.DisposingExecutor
Add a Disposable to be disposed when this component is disposed
add(Runnable) - Method in class org.jetlang.core.EventBuffer
 
add(Disposable) - Method in class org.jetlang.core.RunnableExecutorImpl
 
add(Disposable) - Method in class org.jetlang.core.SynchronousDisposingExecutor
 
add(Disposable) - Method in class org.jetlang.fibers.FiberStub
 
add(Disposable) - Method in class org.jetlang.fibers.ThreadFiber
 
AsyncRequest<R,V> - Class in org.jetlang.channels
User: mrettig Date: Jan 31, 2009 Time: 1:31:46 PM
AsyncRequest(Fiber) - Constructor for class org.jetlang.channels.AsyncRequest
 

B

BaseSubscription<T> - Class in org.jetlang.channels
Base implementation for all producer thread subscriptions.
BaseSubscription(DisposingExecutor) - Constructor for class org.jetlang.channels.BaseSubscription
 
BaseSubscription(DisposingExecutor, Filter<T>) - Constructor for class org.jetlang.channels.BaseSubscription
 
BatchExecutor - Interface in org.jetlang.core
Event executor.
BatchExecutorImpl - Class in org.jetlang.core
Default implementation that simply executes all events.
BatchExecutorImpl() - Constructor for class org.jetlang.core.BatchExecutorImpl
 
BatchSubscriber<T> - Class in org.jetlang.channels
Batches events for the consuming thread.
BatchSubscriber(Fiber, Callback<List<T>>, Filter<T>, int, TimeUnit) - Constructor for class org.jetlang.channels.BatchSubscriber
 
BatchSubscriber(Fiber, Callback<List<T>>, int, TimeUnit) - Constructor for class org.jetlang.channels.BatchSubscriber
 

C

Callback<T> - Interface in org.jetlang.core
Event callback.
Channel<T> - Interface in org.jetlang.channels
Combined suscriber and publisher interface.
ChannelSubscription<T> - Class in org.jetlang.channels
Subscription for events on a channel.
ChannelSubscription(DisposingExecutor, Callback<T>) - Constructor for class org.jetlang.channels.ChannelSubscription
 
ChannelSubscription(DisposingExecutor, Callback<T>, Filter<T>) - Constructor for class org.jetlang.channels.ChannelSubscription
 
clear() - Method in class org.jetlang.channels.SubscriberList
 
clear() - Method in class org.jetlang.core.EventBuffer
 
clearSubscribers() - Method in class org.jetlang.channels.MemoryChannel
 
convert(T) - Method in interface org.jetlang.channels.Converter
 
Converter<T,K> - Interface in org.jetlang.channels
Interface to convert from T to K.
create() - Method in class org.jetlang.fibers.PoolFiberFactory
Create a new Fiber from this pool.
create(BatchExecutor) - Method in class org.jetlang.fibers.PoolFiberFactory
Create a new Fiber from this pool that uses the supplied Executor to execute commands

D

Disposable - Interface in org.jetlang.core
Interface to represent an instance that requires explicit resource cleanup
Disposables - Variable in class org.jetlang.fibers.FiberStub
 
dispose() - Method in interface org.jetlang.core.Disposable
Dispose this instance.
dispose() - Method in class org.jetlang.core.RunnableExecutorImpl
 
dispose() - Method in class org.jetlang.core.SchedulerImpl
 
dispose() - Method in class org.jetlang.core.SynchronousDisposingExecutor
 
dispose() - Method in class org.jetlang.fibers.FiberStub
 
dispose() - Method in class org.jetlang.fibers.PoolFiberFactory
 
dispose() - Method in class org.jetlang.fibers.ThreadFiber
 
DisposingExecutor - Interface in org.jetlang.core
An Executor that can dispose other components in unison with itself.

E

equals(Object) - Method in class org.jetlang.fibers.FiberStub.ScheduledEvent
 
EventBuffer - Class in org.jetlang.core
User: mrettig Date: Aug 29, 2009
EventBuffer() - Constructor for class org.jetlang.core.EventBuffer
 
EventReader - Interface in org.jetlang.core
User: mrettig Date: Aug 30, 2009
execute(EventReader) - Method in interface org.jetlang.core.BatchExecutor
 
execute(EventReader) - Method in class org.jetlang.core.BatchExecutorImpl
 
execute(Runnable) - Method in class org.jetlang.core.RunnableExecutorImpl
 
execute(Runnable) - Method in class org.jetlang.core.SynchronousDisposingExecutor
 
execute(Runnable) - Method in class org.jetlang.core.SynchronousExecutor
 
execute(Runnable) - Method in class org.jetlang.fibers.FiberStub
 
execute(Runnable) - Method in class org.jetlang.fibers.ThreadFiber
Queue runnable for execution on this fiber.
executeAllPending() - Method in class org.jetlang.fibers.FiberStub
 
executeAllScheduled() - Method in class org.jetlang.fibers.FiberStub
 

F

Fiber - Interface in org.jetlang.fibers
Fibers provide event queueing, scheduling, and full pub/sub capabilities when combined with a Channel.
FiberStub - Class in org.jetlang.fibers
Provides a deterministic fiber implementation for testing.
FiberStub() - Constructor for class org.jetlang.fibers.FiberStub
 
FiberStub.ScheduledEvent - Class in org.jetlang.fibers
 
FiberStub.ScheduledEvent(Runnable, long, TimeUnit) - Constructor for class org.jetlang.fibers.FiberStub.ScheduledEvent
 
FiberStub.ScheduledEvent(Runnable, long, long, TimeUnit) - Constructor for class org.jetlang.fibers.FiberStub.ScheduledEvent
 
Filter<T> - Interface in org.jetlang.core
Interface to represent a boolean filter for messages

G

get(int) - Method in class org.jetlang.core.EventBuffer
 
get(int) - Method in interface org.jetlang.core.EventReader
 
getFirst() - Method in class org.jetlang.fibers.FiberStub.ScheduledEvent
 
getInterval() - Method in class org.jetlang.fibers.FiberStub.ScheduledEvent
 
getOriginalRequest() - Method in interface org.jetlang.channels.SessionClosed
 
getQueue() - Method in class org.jetlang.channels.BaseSubscription
 
getQueue() - Method in interface org.jetlang.channels.Subscribable
 
getRequest() - Method in interface org.jetlang.channels.Request
 
getRunnable() - Method in class org.jetlang.fibers.FiberStub.ScheduledEvent
 
getSession() - Method in interface org.jetlang.channels.Request
 
getSession() - Method in interface org.jetlang.channels.SessionClosed
 
getThread() - Method in class org.jetlang.fibers.ThreadFiber
 
getTimeUnit() - Method in class org.jetlang.fibers.FiberStub.ScheduledEvent
 

H

hashCode() - Method in class org.jetlang.fibers.FiberStub.ScheduledEvent
 

I

isEmpty() - Method in class org.jetlang.core.EventBuffer
 
isEmpty() - Method in class org.jetlang.core.RunnableBlockingQueue
 
isRecurring() - Method in class org.jetlang.fibers.FiberStub.ScheduledEvent
 
isRunning() - Method in class org.jetlang.core.RunnableBlockingQueue
 
isRunning() - Method in class org.jetlang.core.SynchronousExecutor
 

J

join() - Method in class org.jetlang.fibers.ThreadFiber
Wait for thread to complete

K

KeyedBatchSubscriber<K,T> - Class in org.jetlang.channels
Channel subscription that drops duplicates based upon a key.
KeyedBatchSubscriber(Fiber, Callback<Map<K, T>>, Filter<T>, int, TimeUnit, Converter<T, K>) - Constructor for class org.jetlang.channels.KeyedBatchSubscriber
 
KeyedBatchSubscriber(Fiber, Callback<Map<K, T>>, int, TimeUnit, Converter<T, K>) - Constructor for class org.jetlang.channels.KeyedBatchSubscriber
 

L

LastSubscriber<T> - Class in org.jetlang.channels
Subscribes to last event received on the channel.
LastSubscriber(Fiber, Callback<T>, Filter<T>, int, TimeUnit) - Constructor for class org.jetlang.channels.LastSubscriber
 
LastSubscriber(Fiber, Callback<T>, int, TimeUnit) - Constructor for class org.jetlang.channels.LastSubscriber
 

M

MemoryChannel<T> - Class in org.jetlang.channels
Conduit for exchanging messages between threads.
MemoryChannel() - Constructor for class org.jetlang.channels.MemoryChannel
 
MemoryRequestChannel<R,V> - Class in org.jetlang.channels
User: mrettig Date: Jan 31, 2009 Time: 10:42:42 AM
MemoryRequestChannel() - Constructor for class org.jetlang.channels.MemoryRequestChannel
 

O

onMessage(T) - Method in class org.jetlang.channels.BaseSubscription
Receives the event, filters, and passes to handler.
onMessage(T) - Method in interface org.jetlang.core.Callback
 
onMessageOnProducerThread(T) - Method in class org.jetlang.channels.BaseSubscription
 
onMessageOnProducerThread(T) - Method in class org.jetlang.channels.BatchSubscriber
Receives message and batches as needed.
onMessageOnProducerThread(T) - Method in class org.jetlang.channels.ChannelSubscription
Receives the event and queues the execution on the target execute.
onMessageOnProducerThread(T) - Method in class org.jetlang.channels.KeyedBatchSubscriber
Message received and batched on producer thread.
onMessageOnProducerThread(T) - Method in class org.jetlang.channels.LastSubscriber
 
org.jetlang.channels - package org.jetlang.channels
 
org.jetlang.core - package org.jetlang.core
 
org.jetlang.fibers - package org.jetlang.fibers
 

P

passes(T) - Method in interface org.jetlang.core.Filter
Check to see whether the supplied message passes the filter
Pending - Variable in class org.jetlang.fibers.FiberStub
 
PoolFiberFactory - Class in org.jetlang.fibers
Factory that creates Fiber instances that share threads.
PoolFiberFactory(Executor) - Constructor for class org.jetlang.fibers.PoolFiberFactory
Construct a new instance.
publish(RequestChannel<R, V>, R, Callback<List<V>>) - Method in class org.jetlang.channels.AsyncRequest
 
publish(T) - Method in class org.jetlang.channels.MemoryChannel
 
publish(DisposingExecutor, R, Callback<V>) - Method in class org.jetlang.channels.MemoryRequestChannel
 
publish(T) - Method in interface org.jetlang.channels.Publisher
Publish a message.
publish(DisposingExecutor, R, Callback<V>) - Method in interface org.jetlang.channels.RequestChannel
 
publish(T) - Method in class org.jetlang.channels.SubscriberList
 
Publisher<T> - Interface in org.jetlang.channels
Interface for components that allow messages to be published to them
put(Runnable) - Method in class org.jetlang.core.RunnableBlockingQueue
 

R

remove(Callback<T>) - Method in class org.jetlang.channels.SubscriberList
 
remove(Disposable) - Method in interface org.jetlang.core.DisposingExecutor
Remove a Disposable from being disposed when this component is disposed
remove(Disposable) - Method in class org.jetlang.core.RunnableExecutorImpl
 
remove(Disposable) - Method in class org.jetlang.core.SynchronousDisposingExecutor
 
remove(Disposable) - Method in class org.jetlang.fibers.FiberStub
 
remove(Disposable) - Method in class org.jetlang.fibers.ThreadFiber
 
reply(V) - Method in interface org.jetlang.channels.Request
 
Request<R,V> - Interface in org.jetlang.channels
User: mrettig Date: Jan 31, 2009 Time: 10:25:53 AM
RequestChannel<R,V> - Interface in org.jetlang.channels
User: mrettig Date: Jan 31, 2009 Time: 10:23:38 AM
run() - Method in class org.jetlang.core.RunnableExecutorImpl
 
run() - Method in class org.jetlang.core.SynchronousDisposingExecutor
 
run() - Method in class org.jetlang.fibers.FiberStub.ScheduledEvent
 
RunnableBlockingQueue - Class in org.jetlang.core
Blocking queue supporting efficient put and sweep operations.
RunnableBlockingQueue() - Constructor for class org.jetlang.core.RunnableBlockingQueue
 
RunnableExecutor - Interface in org.jetlang.core
Queues and executes events.
RunnableExecutorImpl - Class in org.jetlang.core
Default implementation that queues and executes events.
RunnableExecutorImpl() - Constructor for class org.jetlang.core.RunnableExecutorImpl
 
RunnableExecutorImpl(BatchExecutor) - Constructor for class org.jetlang.core.RunnableExecutorImpl
 

S

schedule(Runnable, long, TimeUnit) - Method in interface org.jetlang.core.Scheduler
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Runnable, long, TimeUnit) - Method in class org.jetlang.core.SchedulerImpl
 
schedule(Runnable, long, TimeUnit) - Method in class org.jetlang.fibers.FiberStub
 
schedule(Runnable, long, TimeUnit) - Method in class org.jetlang.fibers.ThreadFiber
Schedule a Runnable to execute in the future.
Scheduled - Variable in class org.jetlang.fibers.FiberStub
 
Scheduler - Interface in org.jetlang.core
Component that can schedule events to execute in the future.
SchedulerImpl - Class in org.jetlang.core
Default implementation for scheduling events for execution on fibers.
SchedulerImpl(Executor) - Constructor for class org.jetlang.core.SchedulerImpl
 
SchedulerImpl(DisposingExecutor, ScheduledExecutorService) - Constructor for class org.jetlang.core.SchedulerImpl
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.jetlang.core.Scheduler
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given delay between the termination of one execution and the commencement of the next.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jetlang.core.SchedulerImpl
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jetlang.fibers.FiberStub
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jetlang.fibers.ThreadFiber
Schedule recurring event.
Session - Interface in org.jetlang.channels
Uniquely identifies a request/reply session.
SessionClosed<R> - Interface in org.jetlang.channels
Message sent when a request session is closed.
setResponseCount(int) - Method in class org.jetlang.channels.AsyncRequest
 
setRunning(boolean) - Method in class org.jetlang.core.RunnableBlockingQueue
 
setRunning(boolean) - Method in class org.jetlang.core.SynchronousExecutor
 
setTimeout(Callback<List<V>>, long, TimeUnit) - Method in class org.jetlang.channels.AsyncRequest
 
size() - Method in class org.jetlang.channels.SubscriberList
 
size() - Method in interface org.jetlang.core.DisposingExecutor
Return the number of Disposable instances registered with this instance.
size() - Method in class org.jetlang.core.EventBuffer
 
size() - Method in interface org.jetlang.core.EventReader
 
size() - Method in class org.jetlang.core.RunnableExecutorImpl
 
size() - Method in class org.jetlang.core.SynchronousDisposingExecutor
 
size() - Method in class org.jetlang.fibers.FiberStub
 
size() - Method in class org.jetlang.fibers.ThreadFiber
 
start() - Method in interface org.jetlang.fibers.Fiber
Start consuming events
start() - Method in class org.jetlang.fibers.FiberStub
 
start() - Method in class org.jetlang.fibers.ThreadFiber
Start thread
Subscribable<T> - Interface in org.jetlang.channels
Interface to subscribe to events on producing thread(s).
subscribe(DisposingExecutor, Callback<T>) - Method in class org.jetlang.channels.MemoryChannel
 
subscribe(Subscribable<T>) - Method in class org.jetlang.channels.MemoryChannel
 
subscribe(DisposingExecutor, Callback<Request<R, V>>) - Method in class org.jetlang.channels.MemoryRequestChannel
 
subscribe(DisposingExecutor, Callback<Request<R, V>>, Callback<SessionClosed<R>>) - Method in class org.jetlang.channels.MemoryRequestChannel
 
subscribe(DisposingExecutor, Callback<Request<R, V>>) - Method in interface org.jetlang.channels.RequestChannel
 
subscribe(DisposingExecutor, Callback<Request<R, V>>, Callback<SessionClosed<R>>) - Method in interface org.jetlang.channels.RequestChannel
 
subscribe(DisposingExecutor, Callback<T>) - Method in interface org.jetlang.channels.Subscriber
Subscribe to receive messages produced by this subscriber
subscribe(Subscribable<T>) - Method in interface org.jetlang.channels.Subscriber
 
subscribeOnProducerThread(DisposingExecutor, Callback<T>) - Method in class org.jetlang.channels.MemoryChannel
 
Subscriber<T> - Interface in org.jetlang.channels
Interface for components that allow for message subscriptions
subscriberCount() - Method in class org.jetlang.channels.MemoryChannel
 
SubscriberList<T> - Class in org.jetlang.channels
User: mrettig Date: Aug 29, 2009
SubscriberList() - Constructor for class org.jetlang.channels.SubscriberList
 
swap(EventBuffer) - Method in class org.jetlang.core.RunnableBlockingQueue
 
SynchronousDisposingExecutor - Class in org.jetlang.core
A synchronous execute typically used for testing.
SynchronousDisposingExecutor() - Constructor for class org.jetlang.core.SynchronousDisposingExecutor
 
SynchronousExecutor - Class in org.jetlang.core
Executor that runs tasks on the current thread.
SynchronousExecutor() - Constructor for class org.jetlang.core.SynchronousExecutor
 

T

ThreadFiber - Class in org.jetlang.fibers
Fiber implementation backed by a dedicated thread for execution.
ThreadFiber(RunnableExecutor, String, boolean) - Constructor for class org.jetlang.fibers.ThreadFiber
Create thread backed fiber
ThreadFiber() - Constructor for class org.jetlang.fibers.ThreadFiber
 

W

withOneReply(Fiber, RequestChannel<R, V>, R, Callback<V>) - Static method in class org.jetlang.channels.AsyncRequest
 
withOneReply(Fiber, RequestChannel<R, V>, R, Callback<V>, long, TimeUnit, Runnable) - Static method in class org.jetlang.channels.AsyncRequest
 

A B C D E F G H I J K L M O P R S T W

Copyright © 2009. All Rights Reserved.