A B C D E F G H I J L N O P Q R S T U V W 
All Classes All Packages

A

AbstractNode - Class in com.noleme.flow.node
 
AbstractNode() - Constructor for class com.noleme.flow.node.AbstractNode
 
accumulate() - Method in interface com.noleme.flow.stream.StreamOut
 
accumulate(Accumulator<O, N>) - Method in class com.noleme.flow.stream.StreamGenerator
 
accumulate(Accumulator<O, N>) - Method in class com.noleme.flow.stream.StreamJoin
 
accumulate(Accumulator<O, N>) - Method in interface com.noleme.flow.stream.StreamOut
 
accumulate(Accumulator<O, N>) - Method in class com.noleme.flow.stream.StreamPipe
 
accumulate(Accumulator<O, N>) - Method in class com.noleme.flow.stream.StreamSource
 
accumulate(Collection<I>) - Method in interface com.noleme.flow.actor.accumulator.Accumulator
This method should transform a collection of inputs resulting from stream executions into a unified output.
AccumulationException - Exception in com.noleme.flow.actor.accumulator
 
AccumulationException(String) - Constructor for exception com.noleme.flow.actor.accumulator.AccumulationException
 
AccumulationException(String, Throwable) - Constructor for exception com.noleme.flow.actor.accumulator.AccumulationException
 
Accumulator<I,​O> - Interface in com.noleme.flow.actor.accumulator
 
after(Node) - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
after(Node) - Method in class com.noleme.flow.node.AbstractNode
 
after(Node) - Method in interface com.noleme.flow.node.Node
Requests for the current node to be executed after the provided node.
after(Node) - Method in class com.noleme.flow.node.NodeDecorator
 
after(Collection<Node>) - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
after(Collection<Node>) - Method in class com.noleme.flow.node.AbstractNode
 
after(Collection<Node>) - Method in interface com.noleme.flow.node.Node
Requests for the current node to be executed after the provided nodes.
after(Collection<Node>) - Method in class com.noleme.flow.node.NodeDecorator
 
afterExecute(Runnable, Throwable) - Method in class com.noleme.flow.impl.parallel.runtime.executor.ThrowingThreadPoolExecutor
 
aggregate(Loader<I>) - Static method in class com.noleme.flow.Flow
An adapter function for leveraging a given Loader over a collection of its inputs.
aggregate(BiTransformer<I1, I2, O>) - Static method in class com.noleme.flow.Flow
An adapter function for leveraging a given BiTransformer over a collection of its inputs.
aggregate(Transformer<I, O>) - Static method in class com.noleme.flow.Flow
An adapter function for leveraging a given Transformer over a collection of its inputs.
and(String, T) - Method in interface com.noleme.flow.io.input.Input
 
and(String, T) - Method in class com.noleme.flow.io.input.InputMap
 
asExtractor(I) - Method in interface com.noleme.flow.actor.transformer.Transformer
Allows the use of a Transformer contract as an Extractor provided a given input.

B

bind(SimpleNode) - Method in class com.noleme.flow.node.BiNode
 
bind(SimpleNode) - Method in class com.noleme.flow.node.SimpleNode
 
BiNode - Class in com.noleme.flow.node
 
BiNode(Node, Node) - Constructor for class com.noleme.flow.node.BiNode
 
BiTransformer<I1,​I2,​O> - Interface in com.noleme.flow.actor.transformer
 
BlackHole<T> - Class in com.noleme.flow.actor.loader
 
BlackHole() - Constructor for class com.noleme.flow.actor.loader.BlackHole
 
block(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
blockAll(Collection<Node>) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
blockBranch(Node, Set<Node>) - Static method in class com.noleme.flow.impl.pipeline.PipelineRuntime
 
BLOCKED - com.noleme.flow.impl.parallel.ParallelRuntime.NodeState
 

C

collect() - Method in interface com.noleme.flow.FlowOut
 
collect(String) - Method in interface com.noleme.flow.FlowOut
 
collect(String) - Method in class com.noleme.flow.Join
 
collect(String) - Method in class com.noleme.flow.Pipe
 
collect(String) - Method in class com.noleme.flow.Source
 
collect(String) - Method in class com.noleme.flow.stream.StreamAccumulator
 
com.noleme.flow - package com.noleme.flow
 
com.noleme.flow.actor.accumulator - package com.noleme.flow.actor.accumulator
 
com.noleme.flow.actor.extractor - package com.noleme.flow.actor.extractor
 
com.noleme.flow.actor.generator - package com.noleme.flow.actor.generator
 
com.noleme.flow.actor.loader - package com.noleme.flow.actor.loader
 
com.noleme.flow.actor.transformer - package com.noleme.flow.actor.transformer
 
com.noleme.flow.compiler - package com.noleme.flow.compiler
 
com.noleme.flow.impl.parallel - package com.noleme.flow.impl.parallel
 
com.noleme.flow.impl.parallel.compiler - package com.noleme.flow.impl.parallel.compiler
 
com.noleme.flow.impl.parallel.compiler.pass - package com.noleme.flow.impl.parallel.compiler.pass
 
com.noleme.flow.impl.parallel.runtime.executor - package com.noleme.flow.impl.parallel.runtime.executor
 
com.noleme.flow.impl.parallel.runtime.heap - package com.noleme.flow.impl.parallel.runtime.heap
 
com.noleme.flow.impl.parallel.runtime.state - package com.noleme.flow.impl.parallel.runtime.state
 
com.noleme.flow.impl.pipeline - package com.noleme.flow.impl.pipeline
 
com.noleme.flow.impl.pipeline.compiler.pass - package com.noleme.flow.impl.pipeline.compiler.pass
 
com.noleme.flow.impl.pipeline.compiler.stream - package com.noleme.flow.impl.pipeline.compiler.stream
 
com.noleme.flow.impl.pipeline.runtime.execution - package com.noleme.flow.impl.pipeline.runtime.execution
 
com.noleme.flow.impl.pipeline.runtime.heap - package com.noleme.flow.impl.pipeline.runtime.heap
 
com.noleme.flow.impl.pipeline.runtime.node - package com.noleme.flow.impl.pipeline.runtime.node
 
com.noleme.flow.interruption - package com.noleme.flow.interruption
 
com.noleme.flow.io.input - package com.noleme.flow.io.input
 
com.noleme.flow.io.output - package com.noleme.flow.io.output
 
com.noleme.flow.node - package com.noleme.flow.node
 
com.noleme.flow.stream - package com.noleme.flow.stream
 
compareTo(Node) - Method in interface com.noleme.flow.node.Node
 
CompilationException - Exception in com.noleme.flow.compiler
 
CompilationException(String) - Constructor for exception com.noleme.flow.compiler.CompilationException
 
CompilationException(String, Throwable) - Constructor for exception com.noleme.flow.compiler.CompilationException
 
compile(Node...) - Method in interface com.noleme.flow.compiler.FlowCompiler
 
compile(Collection<Node>) - Method in interface com.noleme.flow.compiler.FlowCompiler
 
compile(Collection<Node>) - Method in class com.noleme.flow.impl.parallel.ParallelCompiler
 
compile(Collection<Node>) - Method in class com.noleme.flow.impl.pipeline.PipelineCompiler
 
compile(Collection<Node>, List<PipelineCompilerPass>) - Static method in class com.noleme.flow.impl.pipeline.PipelineCompiler
 
complete(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
completeAll(Collection<Node>) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
completeStreamItem(OffsetNode) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
ConcurrentHashHeap - Class in com.noleme.flow.impl.parallel.runtime.heap
 
ConcurrentHashHeap(Input) - Constructor for class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
consume(String) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
consume(String) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
consume(String) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
consume(String, int) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
consume(String, int) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
consume(String, int) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
consumeAll(String) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
consumeAll(String) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
consumeAll(String) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
count() - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState.ParallelismCounter
 
Counter - Class in com.noleme.flow.impl.pipeline.runtime.heap
 
Counter(Object, int) - Constructor for class com.noleme.flow.impl.pipeline.runtime.heap.Counter
 
CounterContainer - Class in com.noleme.flow.impl.pipeline.runtime.heap
 
CounterContainer() - Constructor for class com.noleme.flow.impl.pipeline.runtime.heap.CounterContainer
 

D

decrement() - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState.ParallelismCounter
 
decrement() - Method in class com.noleme.flow.impl.pipeline.runtime.heap.Counter
 
driftSink(Loader<O>) - Method in class com.noleme.flow.Join
 
driftSink(Loader<O>) - Method in class com.noleme.flow.Pipe
 
driftSink(Loader<O>) - Method in class com.noleme.flow.Source
 
driftSink(Loader<O>) - Method in class com.noleme.flow.stream.StreamAccumulator
 
driftSink(Loader<O>) - Method in class com.noleme.flow.stream.StreamGenerator
 
driftSink(Loader<O>) - Method in class com.noleme.flow.stream.StreamJoin
 
driftSink(Loader<O>) - Method in class com.noleme.flow.stream.StreamPipe
 
driftSink(Loader<O>) - Method in class com.noleme.flow.stream.StreamSource
 

E

empty() - Static method in interface com.noleme.flow.io.input.Input
 
emptyInput - Static variable in interface com.noleme.flow.io.input.Input
 
equals(Object) - Method in class com.noleme.flow.node.AbstractNode
 
equals(Object) - Method in class com.noleme.flow.node.NodeDecorator
 
execution - Variable in class com.noleme.flow.impl.pipeline.PipelineRuntime
 
Execution - Class in com.noleme.flow.impl.pipeline.runtime.execution
 
Execution() - Constructor for class com.noleme.flow.impl.pipeline.runtime.execution.Execution
 
Executors - Class in com.noleme.flow.impl.parallel.runtime.executor
 
ExecutorServiceProvider - Interface in com.noleme.flow.impl.parallel.runtime.executor
 
extract() - Method in interface com.noleme.flow.actor.extractor.Extractor
 
extract() - Method in class com.noleme.flow.io.input.InputExtractor
 
ExtractionException - Exception in com.noleme.flow.actor.extractor
 
ExtractionException(String) - Constructor for exception com.noleme.flow.actor.extractor.ExtractionException
 
ExtractionException(String, Throwable) - Constructor for exception com.noleme.flow.actor.extractor.ExtractionException
 
Extractor<T> - Interface in com.noleme.flow.actor.extractor
 

F

Flow - Class in com.noleme.flow
A helper class for initiating flows, it also provides a handful of shorthand methods for building and launching flow DAGs.
FlowCompiler<R extends FlowRuntime> - Interface in com.noleme.flow.compiler
 
FlowIn<I> - Interface in com.noleme.flow
Concept representing a Node with a potential upstream.
FlowOut<O> - Interface in com.noleme.flow
Concept representing a Node with a potential downstream.
FlowRuntime - Interface in com.noleme.flow.compiler
 
from(Extractor<O>) - Static method in class com.noleme.flow.Flow
Returns a Source node from a given Extractor instance.
from(Transformer<I, O>, I) - Static method in class com.noleme.flow.Flow
 
from(String) - Static method in class com.noleme.flow.Flow
 

G

generate() - Method in interface com.noleme.flow.actor.generator.Generator
This method should return the next element of the stream each time it is called or null if it has reached the end.
GenerationException - Exception in com.noleme.flow.actor.generator
 
GenerationException(String) - Constructor for exception com.noleme.flow.actor.generator.GenerationException
 
GenerationException(String, Throwable) - Constructor for exception com.noleme.flow.actor.generator.GenerationException
 
Generator<O> - Interface in com.noleme.flow.actor.generator
 
generators - Variable in class com.noleme.flow.impl.parallel.compiler.ParallelIndexes
 
get(int) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.CounterContainer
 
get(Recipient<T>) - Method in interface com.noleme.flow.io.output.Output
 
get(Recipient<T>) - Method in class com.noleme.flow.io.output.OutputMap
 
get(String) - Method in interface com.noleme.flow.io.input.Input
 
get(String) - Method in class com.noleme.flow.io.input.InputMap
 
get(String) - Method in interface com.noleme.flow.io.output.Output
 
get(String) - Method in class com.noleme.flow.io.output.OutputMap
 
get(String, Class<T>) - Method in interface com.noleme.flow.io.output.Output
 
get(String, Class<T>) - Method in class com.noleme.flow.io.output.OutputMap
 
getActor() - Method in class com.noleme.flow.Join
 
getActor() - Method in class com.noleme.flow.node.SimpleNode
 
getActor() - Method in class com.noleme.flow.stream.StreamJoin
 
getCount() - Method in class com.noleme.flow.impl.pipeline.runtime.heap.Counter
 
getDownstream() - Method in class com.noleme.flow.impl.pipeline.runtime.node.OffsetNode
 
getDownstream() - Method in class com.noleme.flow.node.AbstractNode
 
getDownstream() - Method in interface com.noleme.flow.node.Node
Returns the list of downstream nodes, ie. nodes which require the current node's output in order to be executed.
getDownstream() - Method in class com.noleme.flow.node.NodeDecorator
 
getGeneratorNode() - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
getHeap() - Method in exception com.noleme.flow.impl.parallel.ParallelRunException
 
getHeap() - Method in exception com.noleme.flow.impl.pipeline.PipelineRunException
 
getIdentifier() - Method in class com.noleme.flow.io.input.InputExtractor
 
getIdentifier() - Method in class com.noleme.flow.io.output.Recipient
 
getInput(String) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
getInput(String) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
getInput(String) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
getMaxParallelism() - Method in class com.noleme.flow.stream.StreamGenerator
 
getNextStreamOffset(StreamGenerator) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
getNextStreamOffset(StreamGenerator) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
getNextStreamOffset(StreamGenerator) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
getNode() - Method in class com.noleme.flow.node.NodeDecorator
 
getNodes() - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
getOffset() - Method in class com.noleme.flow.impl.pipeline.runtime.node.OffsetNode
 
getOutput() - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
getOutput() - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
getOutput() - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
getParallelism(StreamGenerator) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
getPivot() - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
getPotentialPivots() - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
getRequiredBy() - Method in class com.noleme.flow.node.AbstractNode
 
getRequiredBy() - Method in interface com.noleme.flow.node.Node
Returns the list of downstream requirements over the current node, ie. nodes which cannot be executed until the current node is.
getRequiredBy() - Method in class com.noleme.flow.node.NodeDecorator
 
getRequirements() - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
getRequirements() - Method in class com.noleme.flow.impl.pipeline.runtime.node.OffsetNode
 
getRequirements() - Method in class com.noleme.flow.node.AbstractNode
 
getRequirements() - Method in interface com.noleme.flow.node.Node
Returns the list of upstream requirement nodes, ie. nodes which need to be executed before, but which outputs aren't required for execution.
getRequirements() - Method in class com.noleme.flow.node.NodeDecorator
 
getSimpleUpstream() - Method in class com.noleme.flow.node.SimpleNode
 
getStreamGenerator(StreamGenerator) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
getStreamGenerator(StreamGenerator) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
getStreamGenerator(StreamGenerator) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
getUid() - Method in class com.noleme.flow.impl.pipeline.runtime.node.OffsetNode
 
getUid() - Method in class com.noleme.flow.node.AbstractNode
 
getUid() - Method in interface com.noleme.flow.node.Node
Returns a unique identifier for the node within a flow DAG.
getUid() - Method in class com.noleme.flow.node.NodeDecorator
 
getUpstream() - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
getUpstream() - Method in class com.noleme.flow.node.BiNode
 
getUpstream() - Method in interface com.noleme.flow.node.Node
Returns the list of upstream nodes, ie. nodes which output is required in order to execute the current node.
getUpstream() - Method in class com.noleme.flow.node.NodeDecorator
 
getUpstream() - Method in class com.noleme.flow.node.SimpleNode
 
getUpstream() - Method in class com.noleme.flow.Source
 
getUpstream1() - Method in class com.noleme.flow.node.BiNode
 
getUpstream2() - Method in class com.noleme.flow.node.BiNode
 
getValue() - Method in class com.noleme.flow.impl.pipeline.runtime.heap.Counter
 

H

has(Recipient<T>) - Method in interface com.noleme.flow.io.output.Output
 
has(Recipient<T>) - Method in class com.noleme.flow.io.output.OutputMap
 
has(String) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
has(String) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
has(String) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
has(String) - Method in interface com.noleme.flow.io.input.Input
 
has(String) - Method in class com.noleme.flow.io.input.InputMap
 
has(String) - Method in interface com.noleme.flow.io.output.Output
 
has(String) - Method in class com.noleme.flow.io.output.OutputMap
 
has(String, int) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
has(String, int) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
has(String, int) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
hashCode() - Method in class com.noleme.flow.node.AbstractNode
 
hashCode() - Method in class com.noleme.flow.node.NodeDecorator
 
HashHeap - Class in com.noleme.flow.impl.pipeline.runtime.heap
 
HashHeap(Input) - Constructor for class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
hasInput(String) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
hasInput(String) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
hasInput(String) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
hasNext() - Method in interface com.noleme.flow.actor.generator.Generator
This method should return true if the generator is active, false otherwise.
hasReachedMaxParallelism(StreamGenerator) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
hasSubmitted() - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
hasWaiting() - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
Heap - Interface in com.noleme.flow.impl.pipeline.runtime.heap
 

I

increment() - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState.ParallelismCounter
 
initiateStream(OffsetNode) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
Input - Interface in com.noleme.flow.io.input
 
InputExtractor<T> - Class in com.noleme.flow.io.input
 
InputExtractor(String) - Constructor for class com.noleme.flow.io.input.InputExtractor
 
InputMap - Class in com.noleme.flow.io.input
 
interrupt() - Static method in exception com.noleme.flow.interruption.InterruptionException
 
interrupt() - Method in class com.noleme.flow.Join
 
interrupt() - Method in class com.noleme.flow.Pipe
 
interrupt() - Method in class com.noleme.flow.Source
 
interrupt() - Method in class com.noleme.flow.stream.StreamGenerator
 
interrupt() - Method in class com.noleme.flow.stream.StreamJoin
 
interrupt() - Method in class com.noleme.flow.stream.StreamPipe
 
interrupt() - Method in class com.noleme.flow.stream.StreamSource
 
interruptIf(Predicate<O>) - Method in class com.noleme.flow.Join
 
interruptIf(Predicate<O>) - Method in class com.noleme.flow.Pipe
 
interruptIf(Predicate<O>) - Method in class com.noleme.flow.Source
 
interruptIf(Predicate<O>) - Method in class com.noleme.flow.stream.StreamGenerator
 
interruptIf(Predicate<O>) - Method in class com.noleme.flow.stream.StreamJoin
 
interruptIf(Predicate<O>) - Method in class com.noleme.flow.stream.StreamPipe
 
interruptIf(Predicate<O>) - Method in class com.noleme.flow.stream.StreamSource
 
Interruption<I> - Class in com.noleme.flow.interruption
 
Interruption() - Constructor for class com.noleme.flow.interruption.Interruption
 
Interruption(Predicate<I>) - Constructor for class com.noleme.flow.interruption.Interruption
 
InterruptionException - Exception in com.noleme.flow.interruption
 
into(Loader<O>) - Method in interface com.noleme.flow.FlowOut
Binds the current node into a Loader, resulting in a new Sink node.
into(Loader<O>) - Method in class com.noleme.flow.Join
 
into(Loader<O>) - Method in class com.noleme.flow.Pipe
 
into(Loader<O>) - Method in class com.noleme.flow.Source
 
into(Loader<O>) - Method in class com.noleme.flow.stream.StreamAccumulator
 
into(Loader<O>) - Method in class com.noleme.flow.stream.StreamGenerator
 
into(Loader<O>) - Method in class com.noleme.flow.stream.StreamJoin
 
into(Loader<O>) - Method in interface com.noleme.flow.stream.StreamOut
Binds the current node into a Loader, resulting in a new StreamSink node.
into(Loader<O>) - Method in class com.noleme.flow.stream.StreamPipe
 
into(Loader<O>) - Method in class com.noleme.flow.stream.StreamSource
 
into(Transformer<O, N>) - Method in class com.noleme.flow.Join
 
into(Transformer<O, N>) - Method in class com.noleme.flow.Pipe
 
into(Transformer<O, N>) - Method in class com.noleme.flow.Source
 
into(Transformer<O, NO>) - Method in interface com.noleme.flow.FlowOut
Binds the current node into a Transformer, resulting in a new Pipe node.
into(Transformer<O, NO>) - Method in class com.noleme.flow.stream.StreamAccumulator
 
into(Transformer<O, NO>) - Method in class com.noleme.flow.stream.StreamGenerator
 
into(Transformer<O, NO>) - Method in class com.noleme.flow.stream.StreamJoin
 
into(Transformer<O, NO>) - Method in interface com.noleme.flow.stream.StreamOut
Binds the current node into a Transformer, resulting in a new StreamPipe node.
into(Transformer<O, NO>) - Method in class com.noleme.flow.stream.StreamPipe
 
into(Transformer<O, NO>) - Method in class com.noleme.flow.stream.StreamSource
 
into(FlowOut<I>, Loader<I>) - Static method in class com.noleme.flow.Flow
 
into(FlowOut<I>, Transformer<I, O>) - Static method in class com.noleme.flow.Flow
 
into(FlowOut<I>, Function<I, Generator<O>>) - Static method in class com.noleme.flow.Flow
 
into(StreamOut<I>, Loader<I>) - Static method in class com.noleme.flow.Flow
 
into(StreamOut<I>, Transformer<I, O>) - Static method in class com.noleme.flow.Flow
 
isBlocked(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
isCompleted(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
isGeneratorSubmitted(StreamGenerator) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
isStreamComplete(StreamAccumulator) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
isStreamComplete(StreamNode) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
isSubmitted(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
isWaiting(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 

J

join(FlowOut<I1>, FlowOut<I2>, BiTransformer<I1, I2, O>) - Static method in class com.noleme.flow.Flow
Returns a Join node resulting from the joining of two flows using a provided BiTransformer.
join(FlowOut<JI>, BiTransformer<O, JI, JO>) - Method in interface com.noleme.flow.FlowOut
Joins the current node with another flow using a bi-transformer join function.
join(FlowOut<JI>, BiTransformer<O, JI, JO>) - Method in class com.noleme.flow.Join
 
join(FlowOut<JI>, BiTransformer<O, JI, JO>) - Method in class com.noleme.flow.Pipe
 
join(FlowOut<JI>, BiTransformer<O, JI, JO>) - Method in class com.noleme.flow.Source
 
join(FlowOut<JI>, BiTransformer<O, JI, JO>) - Method in class com.noleme.flow.stream.StreamAccumulator
 
join(FlowOut<JI>, BiTransformer<O, JI, JO>) - Method in class com.noleme.flow.stream.StreamGenerator
 
join(FlowOut<JI>, BiTransformer<O, JI, JO>) - Method in class com.noleme.flow.stream.StreamJoin
 
join(FlowOut<JI>, BiTransformer<O, JI, JO>) - Method in interface com.noleme.flow.stream.StreamOut
Joins the current stream node with another non-stream flow using a bi-transformer join function.
join(FlowOut<JI>, BiTransformer<O, JI, JO>) - Method in class com.noleme.flow.stream.StreamPipe
 
join(FlowOut<JI>, BiTransformer<O, JI, JO>) - Method in class com.noleme.flow.stream.StreamSource
 
join(StreamOut<I1>, FlowOut<I2>, BiTransformer<I1, I2, O>) - Static method in class com.noleme.flow.Flow
Returns a StreamJoin node resulting from the joining of a stream flow and a non-stream flow using a provided BiTransformer.
Join<I1,​I2,​O> - Class in com.noleme.flow
Joins are a point of passage joining two upstream branchs of a DAG.
Join(FlowOut<I1>, FlowOut<I2>, BiTransformer<I1, I2, O>) - Constructor for class com.noleme.flow.Join
 

L

launch(Node, Heap) - Method in class com.noleme.flow.impl.pipeline.runtime.execution.Execution
Actually executes the Node passed as parameter.
load(T) - Method in class com.noleme.flow.actor.loader.BlackHole
 
load(T) - Method in interface com.noleme.flow.actor.loader.Loader
 
Loader<T> - Interface in com.noleme.flow.actor.loader
 
LoadingException - Exception in com.noleme.flow.actor.loader
 
LoadingException(String) - Constructor for exception com.noleme.flow.actor.loader.LoadingException
 
LoadingException(String, Throwable) - Constructor for exception com.noleme.flow.actor.loader.LoadingException
 

N

newFixedThreadPool(int) - Static method in class com.noleme.flow.impl.parallel.runtime.executor.Executors
 
Node - Interface in com.noleme.flow.node
 
NodeDecorator - Class in com.noleme.flow.node
 
NodeDecorator(Node) - Constructor for class com.noleme.flow.node.NodeDecorator
 
nonFatal(Extractor<O>) - Static method in class com.noleme.flow.Flow
An adapter function for absorbing ExtractionException and replace them with a log line and the control InterruptionException.
nonFatal(BiTransformer<I1, I2, O>) - Static method in class com.noleme.flow.Flow
An adapter function for absorbing TransformationException and replace them with a log line and the control InterruptionException.
nonFatal(Transformer<I, O>) - Static method in class com.noleme.flow.Flow
An adapter function for absorbing TransformationException and replace them with a log line and the control InterruptionException.
NOT_READY - com.noleme.flow.impl.parallel.ParallelRuntime.NodeState
 
NotImplementedException - Exception in com.noleme.flow.compiler
 
NotImplementedException() - Constructor for exception com.noleme.flow.compiler.NotImplementedException
 
NotImplementedException(String) - Constructor for exception com.noleme.flow.compiler.NotImplementedException
 

O

of(String, T) - Static method in interface com.noleme.flow.io.input.Input
 
OffsetNode - Class in com.noleme.flow.impl.pipeline.runtime.node
 
OffsetNode(Node, int) - Constructor for class com.noleme.flow.impl.pipeline.runtime.node.OffsetNode
 
Output - Interface in com.noleme.flow.io.output
 
OutputMap - Class in com.noleme.flow.io.output
 
OutputMap() - Constructor for class com.noleme.flow.io.output.OutputMap
 

P

ParallelCompiler - Class in com.noleme.flow.impl.parallel
 
ParallelCompiler() - Constructor for class com.noleme.flow.impl.parallel.ParallelCompiler
 
ParallelCompiler(int, boolean) - Constructor for class com.noleme.flow.impl.parallel.ParallelCompiler
 
ParallelCompiler(ExecutorServiceProvider, boolean) - Constructor for class com.noleme.flow.impl.parallel.ParallelCompiler
 
ParallelIndexes - Class in com.noleme.flow.impl.parallel.compiler
 
ParallelIndexes(Map<Node, StreamGenerator>, Map<StreamGenerator, Set<Node>>) - Constructor for class com.noleme.flow.impl.parallel.compiler.ParallelIndexes
 
ParallelismCounter() - Constructor for class com.noleme.flow.impl.parallel.runtime.state.RuntimeState.ParallelismCounter
 
ParallelRunException - Exception in com.noleme.flow.impl.parallel
 
ParallelRunException(String, Heap) - Constructor for exception com.noleme.flow.impl.parallel.ParallelRunException
 
ParallelRunException(String, Throwable, Heap) - Constructor for exception com.noleme.flow.impl.parallel.ParallelRunException
 
ParallelRuntime - Class in com.noleme.flow.impl.parallel
 
ParallelRuntime(List<Node>, ExecutorServiceProvider, boolean, ParallelIndexes) - Constructor for class com.noleme.flow.impl.parallel.ParallelRuntime
 
ParallelRuntime.NodeState - Enum in com.noleme.flow.impl.parallel
The NodeState enum represents the different states a Node can be in at runtime before its execution.
peek(String) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
peek(String) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
peek(String) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
peek(String, int) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
peek(String, int) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
peek(String, int) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
pipe(Transformer<O, NO>) - Method in interface com.noleme.flow.FlowOut
Synonymous with into(Transformer), has the advantage of not allowing ambiguous lambdas.
pipe(Transformer<O, NO>) - Method in interface com.noleme.flow.stream.StreamOut
Synonymous with into(Transformer), has the advantage of not allowing ambiguous lambdas.
pipe(FlowOut<I>, Transformer<I, O>) - Static method in class com.noleme.flow.Flow
Returns the Pipe node resulting from the binding of a provided flow to a Transformer.
pipe(StreamOut<I>, Transformer<I, O>) - Static method in class com.noleme.flow.Flow
Returns the StreamPipe node resulting from the binding of a provided stream flow to a Transformer.
Pipe<I,​O> - Class in com.noleme.flow
Pipes are a point of passage in a DAG.
Pipe(Transformer<I, O>) - Constructor for class com.noleme.flow.Pipe
 
PipelineCompiler - Class in com.noleme.flow.impl.pipeline
 
PipelineCompiler() - Constructor for class com.noleme.flow.impl.pipeline.PipelineCompiler
 
PipelineCompilerPass - Interface in com.noleme.flow.impl.pipeline.compiler.pass
 
PipelineRunException - Exception in com.noleme.flow.impl.pipeline
 
PipelineRunException(String, Heap) - Constructor for exception com.noleme.flow.impl.pipeline.PipelineRunException
 
PipelineRunException(String, Throwable, Heap) - Constructor for exception com.noleme.flow.impl.pipeline.PipelineRunException
 
PipelineRuntime - Class in com.noleme.flow.impl.pipeline
 
PipelineRuntime(List<Node>) - Constructor for class com.noleme.flow.impl.pipeline.PipelineRuntime
 
produceGenerator(I) - Method in class com.noleme.flow.stream.StreamGenerator
 
provide() - Method in interface com.noleme.flow.impl.parallel.runtime.executor.ExecutorServiceProvider
 
push(Node) - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
push(String, int, Object, int) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
push(String, int, Object, int) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
push(String, int, Object, int) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
push(String, Object, int) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
push(String, Object, int) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
push(String, Object, int) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 

Q

queue(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
queueAll(Collection<Node>) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 

R

READY - com.noleme.flow.impl.parallel.ParallelRuntime.NodeState
 
Recipient<I> - Class in com.noleme.flow.io.output
 
Recipient(String) - Constructor for class com.noleme.flow.io.output.Recipient
 
removeConsumed() - Method in class com.noleme.flow.impl.pipeline.runtime.heap.CounterContainer
 
RemoveNodesWithUpstreamPass - Class in com.noleme.flow.impl.parallel.compiler.pass
 
RemoveNodesWithUpstreamPass() - Constructor for class com.noleme.flow.impl.parallel.compiler.pass.RemoveNodesWithUpstreamPass
 
run() - Method in interface com.noleme.flow.compiler.FlowRuntime
 
run(Input) - Method in interface com.noleme.flow.compiler.FlowRuntime
 
run(Input) - Method in class com.noleme.flow.impl.parallel.ParallelRuntime
 
run(Input) - Method in class com.noleme.flow.impl.pipeline.PipelineRuntime
 
run(Collection<Node>) - Method in class com.noleme.flow.impl.parallel.compiler.pass.RemoveNodesWithUpstreamPass
 
run(Collection<Node>) - Method in interface com.noleme.flow.impl.pipeline.compiler.pass.PipelineCompilerPass
 
run(Collection<Node>) - Method in class com.noleme.flow.impl.pipeline.compiler.pass.StreamAggregationPass
 
run(Collection<Node>) - Method in class com.noleme.flow.impl.pipeline.compiler.pass.TopologicalSortPass
 
runAs(C, Input, Node...) - Static method in class com.noleme.flow.Flow
Compiles and runs the provided DAG using the provided FlowCompiler implementation.
runAs(C, Node...) - Static method in class com.noleme.flow.Flow
Compiles and runs the provided DAG using the provided FlowCompiler implementation.
runAsParallel(int, Node...) - Static method in class com.noleme.flow.Flow
Compiles and runs the provided DAG as a pipeline using the ParallelPipelineCompiler implementation.
runAsParallel(ExecutorServiceProvider, Input, Node...) - Static method in class com.noleme.flow.Flow
Compiles and runs the provided DAG as a pipeline using the ParallelPipelineCompiler implementation.
runAsParallel(Input, Node...) - Static method in class com.noleme.flow.Flow
Compiles and runs the provided DAG as a pipeline using the ParallelPipelineCompiler implementation.
runAsParallel(Node...) - Static method in class com.noleme.flow.Flow
Compiles and runs the provided DAG as a pipeline using the ParallelPipelineCompiler implementation.
runAsPipeline(Input, Node...) - Static method in class com.noleme.flow.Flow
Compiles and runs the provided DAG as a pipeline using the PipelineCompiler implementation.
runAsPipeline(Node...) - Static method in class com.noleme.flow.Flow
Compiles and runs the provided DAG as a pipeline using the PipelineCompiler implementation.
RunException - Exception in com.noleme.flow.compiler
 
RunException(String) - Constructor for exception com.noleme.flow.compiler.RunException
 
RunException(String, Throwable) - Constructor for exception com.noleme.flow.compiler.RunException
 
RuntimeState - Class in com.noleme.flow.impl.parallel.runtime.state
 
RuntimeState(ParallelIndexes) - Constructor for class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
RuntimeState.ParallelismCounter - Class in com.noleme.flow.impl.parallel.runtime.state
 

S

sample(String) - Method in class com.noleme.flow.Join
 
sample(String) - Method in class com.noleme.flow.Pipe
 
sample(String) - Method in class com.noleme.flow.Source
 
sample(String) - Method in class com.noleme.flow.stream.StreamAccumulator
 
searchGenerator(Node) - Static method in class com.noleme.flow.impl.pipeline.compiler.pass.StreamAggregationPass
 
set(int, Counter) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.CounterContainer
 
set(String, Object) - Method in class com.noleme.flow.io.output.OutputMap
 
set(String, Object) - Method in interface com.noleme.flow.io.output.WriteableOutput
 
setMaxParallelism(int) - Method in class com.noleme.flow.stream.StreamGenerator
 
setOutput(String, Object) - Method in class com.noleme.flow.impl.parallel.runtime.heap.ConcurrentHashHeap
 
setOutput(String, Object) - Method in class com.noleme.flow.impl.pipeline.runtime.heap.HashHeap
 
setOutput(String, Object) - Method in interface com.noleme.flow.impl.pipeline.runtime.heap.Heap
 
setPivot(String) - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
setPotentialPivots(Set<String>) - Method in class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
shutdownThreadPool() - Method in class com.noleme.flow.impl.parallel.ParallelRuntime
 
SimpleNode<T> - Class in com.noleme.flow.node
 
SimpleNode(T) - Constructor for class com.noleme.flow.node.SimpleNode
 
sink(Loader<O>) - Method in interface com.noleme.flow.FlowOut
Synonymous with into(Loader), has the advantage of not allowing ambiguous lambdas.
sink(Loader<O>) - Method in interface com.noleme.flow.stream.StreamOut
Synonymous with into(Loader), has the advantage of not allowing ambiguous lambdas.
sink(FlowOut<I>, Loader<I>) - Static method in class com.noleme.flow.Flow
Returns the Sink node resulting from the binding of a provided flow to a Loader.
sink(StreamOut<I>, Loader<I>) - Static method in class com.noleme.flow.Flow
Returns the StreamSink node resulting from the binding of a provided stream flow to a Loader.
Sink<I> - Class in com.noleme.flow
Sinks represent a final endpoint node in a DAG.
Sink(Loader<I>) - Constructor for class com.noleme.flow.Sink
 
Source<O> - Class in com.noleme.flow
Sources represent an entrypoint node in a DAG.
Source(Extractor<O>) - Constructor for class com.noleme.flow.Source
 
sources(Node) - Static method in class com.noleme.flow.Flow
Returns a set of Nodes that are considered to be "source nodes" or "root nodes" to the provided node.
stream() - Method in class com.noleme.flow.impl.pipeline.runtime.heap.CounterContainer
 
stream(FlowOut<I>, Function<I, Generator<O>>) - Static method in class com.noleme.flow.Flow
 
stream(Function<O, Generator<N>>) - Method in class com.noleme.flow.Join
 
stream(Function<O, Generator<N>>) - Method in class com.noleme.flow.Pipe
 
stream(Function<O, Generator<N>>) - Method in class com.noleme.flow.Source
 
stream(Function<O, Generator<N>>) - Method in class com.noleme.flow.stream.StreamAccumulator
 
stream(Function<O, Generator<NO>>) - Method in interface com.noleme.flow.FlowOut
Initiates a stream from the current node, results in a new StreamGenerator node.
stream(Supplier<Generator<O>>) - Static method in class com.noleme.flow.Flow
 
StreamAccumulator<I,​O> - Class in com.noleme.flow.stream
 
StreamAccumulator(Accumulator<I, O>) - Constructor for class com.noleme.flow.stream.StreamAccumulator
 
StreamAggregationPass - Class in com.noleme.flow.impl.pipeline.compiler.pass
 
StreamAggregationPass() - Constructor for class com.noleme.flow.impl.pipeline.compiler.pass.StreamAggregationPass
 
StreamGenerator<I,​O> - Class in com.noleme.flow.stream
 
StreamGenerator(Function<I, Generator<O>>) - Constructor for class com.noleme.flow.stream.StreamGenerator
 
StreamIn<I> - Interface in com.noleme.flow.stream
 
StreamJoin<I1,​I2,​O> - Class in com.noleme.flow.stream
 
StreamJoin(StreamOut<I1>, FlowOut<I2>, BiTransformer<I1, I2, O>) - Constructor for class com.noleme.flow.stream.StreamJoin
 
StreamNode - Interface in com.noleme.flow.stream
 
streamNodes - Variable in class com.noleme.flow.impl.parallel.compiler.ParallelIndexes
 
StreamOut<O> - Interface in com.noleme.flow.stream
 
StreamPipe<I,​O> - Class in com.noleme.flow.stream
 
StreamPipe(Transformer<I, O>) - Constructor for class com.noleme.flow.stream.StreamPipe
 
StreamPipeline - Class in com.noleme.flow.impl.pipeline.compiler.stream
 
StreamPipeline(StreamGenerator) - Constructor for class com.noleme.flow.impl.pipeline.compiler.stream.StreamPipeline
 
StreamSink<I> - Class in com.noleme.flow.stream
 
StreamSink(Loader<I>) - Constructor for class com.noleme.flow.stream.StreamSink
 
StreamSource<O> - Class in com.noleme.flow.stream
 
StreamSource(Supplier<Generator<O>>) - Constructor for class com.noleme.flow.stream.StreamSource
 
submit(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
submitAll(Collection<Node>) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 

T

terminateStream(OffsetNode) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
ThrowingThreadPoolExecutor - Class in com.noleme.flow.impl.parallel.runtime.executor
 
ThrowingThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>) - Constructor for class com.noleme.flow.impl.parallel.runtime.executor.ThrowingThreadPoolExecutor
 
ThrowingThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class com.noleme.flow.impl.parallel.runtime.executor.ThrowingThreadPoolExecutor
 
ThrowingThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class com.noleme.flow.impl.parallel.runtime.executor.ThrowingThreadPoolExecutor
 
ThrowingThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, RejectedExecutionHandler) - Constructor for class com.noleme.flow.impl.parallel.runtime.executor.ThrowingThreadPoolExecutor
 
TopologicalSortPass - Class in com.noleme.flow.impl.pipeline.compiler.pass
 
TopologicalSortPass() - Constructor for class com.noleme.flow.impl.pipeline.compiler.pass.TopologicalSortPass
 
transform(I) - Method in interface com.noleme.flow.actor.transformer.Transformer
 
transform(I) - Method in class com.noleme.flow.interruption.Interruption
 
transform(I1, I2) - Method in interface com.noleme.flow.actor.transformer.BiTransformer
 
TransformationException - Exception in com.noleme.flow.actor.transformer
 
TransformationException(String) - Constructor for exception com.noleme.flow.actor.transformer.TransformationException
 
TransformationException(String, Throwable) - Constructor for exception com.noleme.flow.actor.transformer.TransformationException
 
Transformer<I,​O> - Interface in com.noleme.flow.actor.transformer
 

U

unblock(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
uncomplete(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
unqueue(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
unsubmit(Node) - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 

V

valueOf(String) - Static method in enum com.noleme.flow.impl.parallel.ParallelRuntime.NodeState
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.noleme.flow.impl.parallel.ParallelRuntime.NodeState
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitingIterator() - Method in class com.noleme.flow.impl.parallel.runtime.state.RuntimeState
 
WriteableOutput - Interface in com.noleme.flow.io.output
 
A B C D E F G H I J L N O P Q R S T U V W 
All Classes All Packages