A B C D E F G H I K L M N O P Q R S T U V

A

AbstractStageDriver - Class in org.apache.commons.pipeline.driver
This interface is used to define how processing for a stage is started, stopped, and run.
AbstractStageDriver(Stage, StageContext) - Constructor for class org.apache.commons.pipeline.driver.AbstractStageDriver
Creates a StageDriver for the specified stage.
AbstractStageDriver(Stage, StageContext, FaultTolerance) - Constructor for class org.apache.commons.pipeline.driver.AbstractStageDriver
Creates a StageDriver for the specified stage.
addBranch(String, Pipeline) - Method in class org.apache.commons.pipeline.Pipeline
Adds a branch to the pipeline.
addCriterion(FtpFileDownloadStage.Criterion) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Add a criterion to the set of criteria that must be matched for files to be downloaded
addLifecycleJob(PipelineLifecycleJob) - Method in class org.apache.commons.pipeline.Pipeline
Adds a job to be onStart on startup to the pipeline.
addRuleInstances(Digester) - Method in class org.apache.commons.pipeline.config.PipelineRuleSet
Adds the rule instances for pipeline, stage, and enqueue tasks to the Digester instance supplied.
addRuleSet(RuleSet) - Method in class org.apache.commons.pipeline.config.DigesterPipelineFactory
Adds a RuleSet to the list of rules available to Digester for parsing the configuration file.
addStage(Stage, StageDriverFactory) - Method in class org.apache.commons.pipeline.Pipeline
Adds a Stage object to the end of this Pipeline.
AddToCollectionStage<T> - Class in org.apache.commons.pipeline.stage
This is a simple stage in the pipeline which will add each processed object to the specified collection.
AddToCollectionStage(Collection<T>) - Constructor for class org.apache.commons.pipeline.stage.AddToCollectionStage
Creates a new instance of AddToCollectionStage.
AddToCollectionStage(Collection<T>, boolean) - Constructor for class org.apache.commons.pipeline.stage.AddToCollectionStage
Creates a new instance of AddToCollectionStage.

B

BaseStage - Class in org.apache.commons.pipeline.stage
This is a simple base class for Stages with no-op implementations of the BaseStage.preprocess(), #process(), BaseStage.postprocess(), and BaseStage.release() methods.
BaseStage() - Constructor for class org.apache.commons.pipeline.stage.BaseStage
 
BlockingQueueFactory<T> - Interface in org.apache.commons.pipeline.util
Many StageDriver implementations require for one or more queues to be created.
BlockingQueueFactory.ArrayBlockingQueueFactory<T> - Class in org.apache.commons.pipeline.util
 
BlockingQueueFactory.ArrayBlockingQueueFactory() - Constructor for class org.apache.commons.pipeline.util.BlockingQueueFactory.ArrayBlockingQueueFactory
 
BlockingQueueFactory.DelayQueueFactoryL<T extends Delayed> - Class in org.apache.commons.pipeline.util
 
BlockingQueueFactory.DelayQueueFactoryL() - Constructor for class org.apache.commons.pipeline.util.BlockingQueueFactory.DelayQueueFactoryL
 
BlockingQueueFactory.LinkedBlockingQueueFactory<T> - Class in org.apache.commons.pipeline.util
 
BlockingQueueFactory.LinkedBlockingQueueFactory() - Constructor for class org.apache.commons.pipeline.util.BlockingQueueFactory.LinkedBlockingQueueFactory
 
BlockingQueueFactory.PriorityBlockingQueueFactory<T> - Class in org.apache.commons.pipeline.util
 
BlockingQueueFactory.PriorityBlockingQueueFactory() - Constructor for class org.apache.commons.pipeline.util.BlockingQueueFactory.PriorityBlockingQueueFactory
 
BlockingQueueFactory.SynchronousQueueFactory<T> - Class in org.apache.commons.pipeline.util
 
BlockingQueueFactory.SynchronousQueueFactory() - Constructor for class org.apache.commons.pipeline.util.BlockingQueueFactory.SynchronousQueueFactory
 
Branches - Annotation Type in org.apache.commons.pipeline.validation
This annotation is used to aggregate information about the branches served by a give Stage.
branchFeeders - Variable in class org.apache.commons.pipeline.testFramework.TestStageContext
 

C

canSucceed(Stage, Stage) - Static method in class org.apache.commons.pipeline.validation.ValidationUtils
Tests whether the specified downstream stage can succeed the specified upstream stage.
canSucceedOnBranch(Stage, String, Stage) - Static method in class org.apache.commons.pipeline.validation.ValidationUtils
Tests whether the specified downstream stage can succeed the specified upstream stage on a branch pipeline identified by the given branch key.
ConsumedTypes - Annotation Type in org.apache.commons.pipeline.validation
This annotation is used to describe what types of objects are consumed by the annotated Stage
context - Variable in class org.apache.commons.pipeline.driver.AbstractStageDriver
The context for the stage being run
context - Variable in class org.apache.commons.pipeline.stage.BaseStage
The context in which the stage runs.
createPipeline() - Method in class org.apache.commons.pipeline.config.DigesterPipelineFactory
Creates a new pipeline based upon the configuration of this factory instance.
createPipeline() - Method in interface org.apache.commons.pipeline.PipelineFactory
Returns a Pipeline created by the factory.
createQueue() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.ArrayBlockingQueueFactory
 
createQueue() - Method in interface org.apache.commons.pipeline.util.BlockingQueueFactory
 
createQueue() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.DelayQueueFactoryL
 
createQueue() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.LinkedBlockingQueueFactory
 
createQueue() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.PriorityBlockingQueueFactory
 
createQueue() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.SynchronousQueueFactory
 
createQueue() - Method in class org.apache.commons.pipeline.util.QueueFactory.ConcurrentLinkedQueueFactory
 
createQueue() - Method in interface org.apache.commons.pipeline.util.QueueFactory
Create a new queue.
createQueue() - Method in class org.apache.commons.pipeline.util.QueueFactory.LinkedListFactory
 
createQueue() - Method in class org.apache.commons.pipeline.util.QueueFactory.PriorityQueueFactory
 
createStageDriver(Stage, StageContext) - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriverFactory
Creates the new DedicatedThreadStageDriver based upon the configuration of this factory instance
createStageDriver(Stage, StageContext) - Method in class org.apache.commons.pipeline.driver.SynchronousStageDriverFactory
Creates a new SynchronousStageDriver based upon this factory's configuration.
createStageDriver(Stage, StageContext) - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Creates the new ThreadPoolStageDriver based upon the configuration of this factory instance
createStageDriver(Stage, StageContext) - Method in interface org.apache.commons.pipeline.StageDriverFactory
This method is used to create a driver that will run the specified stage in the specified context.
currentState - Variable in class org.apache.commons.pipeline.driver.AbstractStageDriver
The current state of processing.

D

DedicatedThreadStageDriver - Class in org.apache.commons.pipeline.driver
This is a very simple implementation of a AbstractStageDriver which spawns a single thread to process a stage.
DedicatedThreadStageDriver(Stage, StageContext, BlockingQueue, long, FaultTolerance) - Constructor for class org.apache.commons.pipeline.driver.DedicatedThreadStageDriver
Creates a new DedicatedThreadStageDriver with the specified thread wait timeout and fault tolerance values.
DedicatedThreadStageDriverFactory - Class in org.apache.commons.pipeline.driver
This factory is used to create DedicatedThreadStageDriver instances configured to run specific stages.
DedicatedThreadStageDriverFactory() - Constructor for class org.apache.commons.pipeline.driver.DedicatedThreadStageDriverFactory
Creates a new instance of DedicatedThreadStageDriverFactory
DigesterPipelineFactory - Class in org.apache.commons.pipeline.config
This factory is designed to simplify creating a pipeline using Digester.
DigesterPipelineFactory(URL) - Constructor for class org.apache.commons.pipeline.config.DigesterPipelineFactory
A factory created by this constructor will create a pipeline from the specified XML configuration file.
downstreamFeeders - Variable in class org.apache.commons.pipeline.testFramework.TestStageContext
 
DynamicLookupStaticMethodStage - Class in org.apache.commons.pipeline.stage
Provide this Stage with a class and a static method name and it will dynamically look up the appropriate method to call based on the object type.
DynamicLookupStaticMethodStage(Class, String) - Constructor for class org.apache.commons.pipeline.stage.DynamicLookupStaticMethodStage
Creates a new instance of DynamicLookupStaticMethodStage
DynamicLookupStaticMethodStage(String, String) - Constructor for class org.apache.commons.pipeline.stage.DynamicLookupStaticMethodStage
Creates a new DynamicLookupStaticMethodStage for the specified class and static method.

E

emit(Object) - Method in class org.apache.commons.pipeline.stage.BaseStage
Convenience method to feed the specified object to the next stage downstream.
emit(String, Object) - Method in class org.apache.commons.pipeline.stage.BaseStage
Convenience method to feed the specified object to the first stage of the specified branch.
emit(Object) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
Convenience method to feed the specified object to the next stage downstream.
emit(String, Object) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
Convenience method to feed the specified object to the first stage of the specified branch.
emitCount - Static variable in class org.apache.commons.pipeline.stage.ExtendedBaseStage
ThreadLocal count of emit calls during the current process call.
emitTotal - Static variable in class org.apache.commons.pipeline.stage.ExtendedBaseStage
ThreadLocal sum of time spent waiting on blocked queues during the current process call.
env - Variable in class org.apache.commons.pipeline.testFramework.TestStageContext
 
errors - Variable in class org.apache.commons.pipeline.driver.AbstractStageDriver
List of errors that have occurred.
ExtendedBaseStage - Class in org.apache.commons.pipeline.stage
Base class for pipeline stages.
ExtendedBaseStage() - Constructor for class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
ExtendedBaseStageMBean - Interface in org.apache.commons.pipeline.stage
Interface to JMX enable the ExtendedBaseStage.

F

FaultingTestStage - Class in org.apache.commons.pipeline.testFramework
This stage will generate StageExceptions for every other object this stage processes.
FaultingTestStage(int) - Constructor for class org.apache.commons.pipeline.testFramework.FaultingTestStage
 
faultTolerance - Variable in class org.apache.commons.pipeline.driver.AbstractStageDriver
Enumerated value indicating the fault tolerance level of the StageDriver.
FaultTolerance - Enum in org.apache.commons.pipeline.driver
Stores the failure tolerance flag for a worker thread.
feed(Object) - Method in interface org.apache.commons.pipeline.Feeder
Feeds the specified object to an underlying receiver.
feed(Object) - Method in class org.apache.commons.pipeline.testFramework.TestFeeder
 
Feeder - Interface in org.apache.commons.pipeline
This interface represents a data channel into which objects can be fed.
FileFinderStage - Class in org.apache.commons.pipeline.stage
This Stage is used to recursively find (non-directory) files that match the specified regex.
FileFinderStage() - Constructor for class org.apache.commons.pipeline.stage.FileFinderStage
Creates a new instance of FileFinder
finish() - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
This method waits for the stage(s) queue(s) to empty and any processor thread(s) to exit cleanly and then calls release() to release any resources acquired during processing, if possible.
finish() - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriver
Causes processing to shut down gracefully.
finish() - Method in class org.apache.commons.pipeline.driver.SynchronousStageDriver
Performs postprocessing and releases stage resources, and updates the driver state accordingly.
finish() - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriver
Causes processing to shut down gracefully.
finish() - Method in class org.apache.commons.pipeline.Pipeline
This method iterates over the stages in the pipeline, looking up a StageDriver for each stage and using that driver to request that the stage finish execution.
finish() - Method in interface org.apache.commons.pipeline.StageDriver
This method waits for the stage(s) queue(s) to empty and any processor thread(s) to exit cleanly and then calls release() to release any resources acquired during processing, if possible.
floatFormatter - Static variable in class org.apache.commons.pipeline.stage.ExtendedBaseStage
ThreadLocal formatter since they are not thread safe.
formatCounterStat(String, AtomicInteger) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
formatCounterStat(String, AtomicLong) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
formatCounterStat(String, long) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
formatTotalTimeStat(String, AtomicLong) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
formatTotalTimeStat(String, long) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
FtpFileDownloadStage - Class in org.apache.commons.pipeline.stage
This Stage provides the functionality needed to retrieve data from an FTP URL.
FtpFileDownloadStage() - Constructor for class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Default constructor - creates work directory in /tmp
FtpFileDownloadStage(String) - Constructor for class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Constructor specifying work directory.
FtpFileDownloadStage.Criterion - Interface in org.apache.commons.pipeline.stage
This class is used to specify a criterion that the downloaded file must satisfy.
FtpFileDownloadStage.FileDateMatchCriterion - Class in org.apache.commons.pipeline.stage
Matches files by matching their filesystem timestamp to a date range.
FtpFileDownloadStage.FileDateMatchCriterion(Date, Date) - Constructor for class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileDateMatchCriterion
Construct a new criterion to match file timestamp to a range of dates.
FtpFileDownloadStage.FileNameMatchCriterion - Class in org.apache.commons.pipeline.stage
Matches file names based upon the Java regex supplied in the constructor.
FtpFileDownloadStage.FileNameMatchCriterion(String) - Constructor for class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileNameMatchCriterion
Construct a new criterion to match on file names.
FtpFileDownloadStage.FileSpec - Class in org.apache.commons.pipeline.stage
This class is used to specify a path and pattern of file for the FtpFileDownload to retrieve.
FtpFileDownloadStage.FileSpec() - Constructor for class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
 
FtpFileDownloadStage.FileSpec.FileType - Enum in org.apache.commons.pipeline.stage
Enumeration of legal FTP file tranfer types

G

generateKey(T) - Method in interface org.apache.commons.pipeline.util.KeyFactory
Generates a unique identifier of type K for an object of type T.
generateKey(Object) - Method in class org.apache.commons.pipeline.util.KeyFactory.HashKeyFactory
 
getArguments() - Method in class org.apache.commons.pipeline.stage.InvokeMethodStage
Returns the objects being used to invoke this method
getBranches() - Method in class org.apache.commons.pipeline.Pipeline
Returns an unmodifiable map of branch pipelines, keyed by branch identifier.
getBranchFeeder(String) - Method in class org.apache.commons.pipeline.Pipeline
Return the source feeder for the specified pipeline branch.
getBranchFeeder(String) - Method in interface org.apache.commons.pipeline.StageContext
Return the source feeder for the specified pipeline branch.
getBranchFeeder(String) - Method in class org.apache.commons.pipeline.testFramework.TestStageContext
Dynamically adds branch feeders as needed to provide a feeder for the requested branch key.
getCapacity() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.ArrayBlockingQueueFactory
Setter for property capacity.
getCapacity() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.LinkedBlockingQueueFactory
Setter for property capacity.
getCollectBranchStats() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
getCollectBranchStats() - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
 
getCollection() - Method in class org.apache.commons.pipeline.stage.AddToCollectionStage
Returns the collection to which elements have been added during processing.
getComparator() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.PriorityBlockingQueueFactory
Getter for property comparator.
getComparator() - Method in class org.apache.commons.pipeline.util.QueueFactory.PriorityQueueFactory
Getter for property comparator.
getCounts() - Method in class org.apache.commons.pipeline.listener.ObjectProcessedEventCounter
 
getCurrentServiceTimeAverage() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
Returns a moving average of the service time.
getCurrentServiceTimeAverage() - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
Get the current average service time.
getCurrentStatWindowSize() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
getCurrentStatWindowSize() - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
Get the size of the service time collection window
getData() - Method in class org.apache.commons.pipeline.event.ObjectProcessedEvent
 
getData() - Method in exception org.apache.commons.pipeline.ProcessingException
Returns the object that was being processed at the time of failure.
getDownstreamFeeder(Stage) - Method in class org.apache.commons.pipeline.Pipeline
This method is used by a stage driver to pass data from one stage to the next.
getDownstreamFeeder(Stage) - Method in interface org.apache.commons.pipeline.StageContext
This method is used by a stage driver to pass data from one stage to the next.
getDownstreamFeeder(Stage) - Method in class org.apache.commons.pipeline.testFramework.TestStageContext
Dynamically adds downstream feeders as needed to provide a downstream feeder for the specified stage.
getDownstreamStage() - Method in class org.apache.commons.pipeline.validation.ValidationFailure
The stage downstream of the connection that could not be validated
getDriverState() - Method in exception org.apache.commons.pipeline.ProcessingException
Returns the saved driver state at the time of processing failure.
getEnv(String) - Method in class org.apache.commons.pipeline.Pipeline
A StageContext implementation provides a global environment for the stages being run.
getEnv(String) - Method in interface org.apache.commons.pipeline.StageContext
A StageContext implementation provides a global environment for the stages being run.
getEnv(String) - Method in class org.apache.commons.pipeline.testFramework.TestStageContext
This method allows objects in the global environment to be accessed by the stages running in this context.
getFatalErrors() - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
Returns a list of unrecoverable errors that occurred during stage processing.
getFatalErrors() - Method in interface org.apache.commons.pipeline.StageDriver
Returns a list of unrecoverable errors that occurred during stage processing.
getFaultTolerance() - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
Getter for property faultTolerant.
getFaultTolerance() - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriverFactory
Getter for property faultTolerance.
getFaultTolerance() - Method in class org.apache.commons.pipeline.driver.SynchronousStageDriverFactory
Getter for property faultTolerance.
getFaultTolerance() - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Getter for property faultTolerance.
getFeeder() - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
This method is used to provide a communication channel between the context in which the driver is being run and the managed stage.
getFeeder() - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriver
Return the Feeder used to feed data to the queue of objects to be processed.
getFeeder() - Method in class org.apache.commons.pipeline.driver.SynchronousStageDriver
Get the feeder for the encapsulated stage.
getFeeder() - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriver
Return the Feeder used to feed data to the queue of objects to be processed.
getFeeder() - Method in interface org.apache.commons.pipeline.StageDriver
This method is used to provide a communication channel between the context in which the driver is being run and the managed stage.
getFilePattern() - Method in class org.apache.commons.pipeline.stage.FileFinderStage
Getter for property filePattern.
getFileType() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Returns the file type for the transfer.
getHost() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Getter for property host.
getIndex() - Method in class org.apache.commons.pipeline.testFramework.TestStage
 
getInitialCapacity() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.PriorityBlockingQueueFactory
Getter for property initialCapacity.
getInitialCapacity() - Method in class org.apache.commons.pipeline.util.QueueFactory.PriorityQueueFactory
Getter for property initialCapacity.
getInitialContents() - Method in class org.apache.commons.pipeline.util.QueueFactory.AbstractQueueFactory
Getter for property initialContents.
getKey() - Method in class org.apache.commons.pipeline.event.KeyAvailableEvent
Returns the key.
getKeyFactory() - Method in class org.apache.commons.pipeline.stage.KeyWaitBufferStage
Getter for property keyFactory.
getKeyFactory() - Method in class org.apache.commons.pipeline.stage.RaiseKeyAvailableEventStage
Returns the KeyFactory used to create keys for the objects processed by this stage.
getMessage() - Method in class org.apache.commons.pipeline.event.PipelineShutdownRequest
 
getMessage() - Method in class org.apache.commons.pipeline.validation.ValidationFailure
Returns the descriptive message about the error
getMethod() - Method in class org.apache.commons.pipeline.stage.InvokeMethodStage
Returns the method to be accessed by processing
getMethod() - Method in class org.apache.commons.pipeline.stage.InvokeStaticMethodStage
Returns the Method object for the method that will be used to process objects in the queue.
getMethodClass() - Method in class org.apache.commons.pipeline.stage.DynamicLookupStaticMethodStage
Returns the class containing the method to be executed
getMethodName() - Method in class org.apache.commons.pipeline.stage.DynamicLookupStaticMethodStage
Returns the name of the method to be executed.
getNullResultBranchKey() - Method in class org.apache.commons.pipeline.stage.DynamicLookupStaticMethodStage
Getter for property nullResultBranchKey.
getNullResultBranchKey() - Method in class org.apache.commons.pipeline.stage.InvokeStaticMethodStage
Getter for property nullResultBranchKey.
getNumThreads() - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriver
Returns the number of threads allocated to the thread pool.
getNumThreads() - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Returns the number of threads that will be allocated to the thread pool of a driver created by this factory.
getObjectsReceived() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
getObjectsReceived() - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
 
getParent() - Method in class org.apache.commons.pipeline.Pipeline
Returns the parent of this pipeline, if it is a branch
getPath() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Getter for property path.
getPattern() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Deprecated. - not retrievable from criterion
getPort() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Getter for property port.
getProcessingExceptions() - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
Returns a list of errors that occurred while processing data objects, along with the objects that were being processed when the errors were generated.
getProcessingExceptions() - Method in interface org.apache.commons.pipeline.StageDriver
Returns a list of errors that occurred while processing data objects, along with the objects that were being processed when the errors were generated.
getQueueFactory() - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriverFactory
Getter for property queueFactory.
getQueueFactory() - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Getter for property queueFactory.
getQueueFactory() - Method in class org.apache.commons.pipeline.stage.KeyWaitBufferStage
Getter for property queueFactory.
getQueueSize() - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriver
Get the size of the queue used by this StageDriver.
getQueueSize() - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriver
Get the size of the queue used by this StageDriver.
getRegisteredListeners() - Method in class org.apache.commons.pipeline.Pipeline
Returns the collection of StageEventListeners registered with the context.
getRegisteredListeners() - Method in interface org.apache.commons.pipeline.StageContext
Returns the collection of StageEventListeners registered with the context.
getRegisteredListeners() - Method in class org.apache.commons.pipeline.testFramework.TestStageContext
 
getServiceInterval() - Method in class org.apache.commons.pipeline.server.PipelineService
Getter for property serviceInterval.
getSource() - Method in class org.apache.commons.pipeline.event.ObjectProcessedEvent
 
getSource() - Method in class org.apache.commons.pipeline.event.PipelineShutdownRequest
 
getSource() - Method in exception org.apache.commons.pipeline.StageException
Returns a reference to the Stage object where the exception occurred.
getSourceFeeder() - Method in class org.apache.commons.pipeline.Pipeline
Returns a feeder for the first stage if the pipeline is not empty
getStage() - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
Returns the Stage being run by this StageDriver.
getStage() - Method in interface org.apache.commons.pipeline.StageDriver
Returns the Stage being run by this StageDriver.
getStageDriver(Stage) - Method in class org.apache.commons.pipeline.Pipeline
Return the StageDriver for the specified Stage.
getStageDrivers() - Method in class org.apache.commons.pipeline.Pipeline
Returns an unmodifiable list of stage drivers that have been added to the pipeline.
getStageName() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
getStages() - Method in class org.apache.commons.pipeline.Pipeline
Returns an unmodifiable list of stages that have been added to this pipeline.
getState() - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
Return the current state of stage processing.
getState() - Method in interface org.apache.commons.pipeline.StageDriver
Returns the current state of stage processing.
getStatusBatchSize() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
getStatusBatchSize() - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
 
getStatusInterval() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
getStatusInterval() - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
 
getStatusMessage() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
getStatusMessage() - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
 
getTerminalFeeder() - Method in class org.apache.commons.pipeline.Pipeline
Gets the feeder that receives output from the final stage.
getTimeout() - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriver
Get the timeout value (in milliseconds) used by this StageDriver on thread termination.
getTimeout() - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriverFactory
Timeout (in milliseconds) for queue polling to ensure deadlock cannot occur on thread termination.
getTimeout() - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriver
Get the timeout value (in milliseconds) used by this StageDriver on thread termination.
getTimeout() - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Timeout for wait to ensure deadlock cannot occur on thread termination.
getTotalEmits() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
getTotalEmits() - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
 
getTotalEmitTime() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
getTotalEmitTime() - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
 
getTotalServiceTime() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
getTotalServiceTime() - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
 
getType() - Method in class org.apache.commons.pipeline.validation.ValidationFailure
Type identifying what sort of problem was encountered
getUpstreamStage() - Method in class org.apache.commons.pipeline.validation.ValidationFailure
The stage upstream of the connection that could not be validated
getUser() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Getter for property user.
getValidationErrors() - Method in exception org.apache.commons.pipeline.validation.ValidationException
Returns the list of errors that precipitated this validation exception.
getValidator() - Method in class org.apache.commons.pipeline.Pipeline
Returns the validator being used to validate the pipeline structure, or null if no validation is being performed..
getWorkDir() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Returns the name of the file download directory.
getWorkDir() - Method in class org.apache.commons.pipeline.stage.HttpFileDownloadStage
Returns the name of the file download directory.

H

handleRedirects(URL) - Method in class org.apache.commons.pipeline.stage.HttpFileDownloadStage
Follows redirects from the specified URL and recursively returns the destination URL.
HttpFileDownloadStage - Class in org.apache.commons.pipeline.stage
This Stage provides the functionality needed to retrieve data from an HTTP URL.
HttpFileDownloadStage() - Constructor for class org.apache.commons.pipeline.stage.HttpFileDownloadStage
 
HttpFileDownloadStage(String) - Constructor for class org.apache.commons.pipeline.stage.HttpFileDownloadStage
Creates a new HttpFileDownloadStage which will download files to the specified work directory.

I

init(StageContext) - Method in class org.apache.commons.pipeline.stage.BaseStage
This implementation of init() simply stores a reference to the stage context.
init(StageContext) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
init(StageContext) - Method in interface org.apache.commons.pipeline.Stage
Initialization takes place when the stage is added to a pipeline.
init(StageContext) - Method in class org.apache.commons.pipeline.stage.KeyWaitBufferStage
 
init(StageContext) - Method in class org.apache.commons.pipeline.testFramework.TestStage
 
initDigester(Digester) - Method in class org.apache.commons.pipeline.config.DigesterPipelineFactory
Initialize a Digester instance with the rule sets provided to this factory.
initialContents - Variable in class org.apache.commons.pipeline.util.QueueFactory.AbstractQueueFactory
Holds value of property initialContents.
initialized - Variable in class org.apache.commons.pipeline.testFramework.TestStage
 
innerPostprocess() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
innerPreprocess() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
innerProcess(Object) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
InputStreamLineBreakStage - Class in org.apache.commons.pipeline.stage
Breaks up an InputStream by line and exqueues each resulting line.
InputStreamLineBreakStage() - Constructor for class org.apache.commons.pipeline.stage.InputStreamLineBreakStage
Creates a new instance of InputStreamLineBreakStage
InputStreamLineBreakStage(boolean) - Constructor for class org.apache.commons.pipeline.stage.InputStreamLineBreakStage
Creates a new instance of InputStreamLineBreakStage
intValue() - Method in enum org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec.FileType
Get the integer value of the FTP transfer mode enumeration.
InvokeMethodStage - Class in org.apache.commons.pipeline.stage
Calls a method on the processed object giving it the arguments specified at the time of object construction.
InvokeMethodStage(Method) - Constructor for class org.apache.commons.pipeline.stage.InvokeMethodStage
Creates a new instance of InvokeMethodStage
InvokeMethodStage(Method, Object...) - Constructor for class org.apache.commons.pipeline.stage.InvokeMethodStage
Creates a new instance of InvokeMethodStage
InvokeMethodStage(String, String, Object...) - Constructor for class org.apache.commons.pipeline.stage.InvokeMethodStage
Creates a new instance of InvokeMethodStage from the class and method names.
InvokeStaticMethodStage - Class in org.apache.commons.pipeline.stage
Runs a static method with the object (or array) being processed.
InvokeStaticMethodStage(Method) - Constructor for class org.apache.commons.pipeline.stage.InvokeStaticMethodStage
Creates a new instance of InvokeStaticMethodStage
InvokeStaticMethodStage(String, String, String...) - Constructor for class org.apache.commons.pipeline.stage.InvokeStaticMethodStage
Convenience method to create the new stage with String description of className, methodName and argumentType
isFair() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.ArrayBlockingQueueFactory
Getter for property fair.
isFair() - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.SynchronousQueueFactory
Getter for property fair.
isIgnoreExisting() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Getter for property ignoreExisting.
isIgnoringBlankLines() - Method in class org.apache.commons.pipeline.stage.InputStreamLineBreakStage
Getter for property ignoreBlankLines.
isInState(StageDriver.State...) - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
Atomically tests to determine whether or not the driver is in the one of the specified states.
isJmxEnabled() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
isOverwrite() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Getter for property overwrite.
isRecursive() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Returns whether or not the stage will recursively traverse the directory tree to find files.

K

KeyAvailableEvent<T> - Class in org.apache.commons.pipeline.event
This event is used to signal the availability of the specified key.
KeyAvailableEvent(Object, T) - Constructor for class org.apache.commons.pipeline.event.KeyAvailableEvent
Creates a new instance of KeyAvailableEvent
KeyFactory<T,K> - Interface in org.apache.commons.pipeline.util
An implementation of this interface should define a strategy that will allow a unique identifier to be generated for an object.
KeyFactory.HashKeyFactory - Class in org.apache.commons.pipeline.util
Trivial key factory that produces the object's hash code as a key.
KeyFactory.HashKeyFactory() - Constructor for class org.apache.commons.pipeline.util.KeyFactory.HashKeyFactory
 
KeyWaitBufferStage - Class in org.apache.commons.pipeline.stage
 
KeyWaitBufferStage() - Constructor for class org.apache.commons.pipeline.stage.KeyWaitBufferStage
Creates a new instance of KeyWaitBufferStage

L

listeners - Variable in class org.apache.commons.pipeline.testFramework.TestStageContext
 
log - Variable in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
LogStage - Class in org.apache.commons.pipeline.stage
A do-nothing implementation of Stage that simply logs the state of processing.
LogStage() - Constructor for class org.apache.commons.pipeline.stage.LogStage
Creates a new LogStage.
logStatus() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 

M

main(String[]) - Static method in class org.apache.commons.pipeline.config.DigesterPipelineFactory
The simplest possible main method that creates a pipeline from a configuration file, then runs the pipeline processing from start to finish.
MAIN_BRANCH - Static variable in class org.apache.commons.pipeline.Pipeline
The branch key for the main line of production.
matches(FTPFile) - Method in interface org.apache.commons.pipeline.stage.FtpFileDownloadStage.Criterion
Interface defining matches for FTP file downloading.
matches(FTPFile) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileDateMatchCriterion
Test the given file's date against this criterion.
matches(FTPFile) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileNameMatchCriterion
Test the given file's name against this criterion.

N

notify(EventObject) - Method in class org.apache.commons.pipeline.listener.ObjectProcessedEventCounter
 
notify(EventObject) - Method in class org.apache.commons.pipeline.stage.KeyWaitBufferStage
 
notify(EventObject) - Method in interface org.apache.commons.pipeline.StageEventListener
Notify this listener of a StageEvent

O

ObjectProcessedEvent - Class in org.apache.commons.pipeline.event
 
ObjectProcessedEvent(Stage, Object) - Constructor for class org.apache.commons.pipeline.event.ObjectProcessedEvent
Creates a new instance of ObjectProcessedEvent
ObjectProcessedEventCounter - Class in org.apache.commons.pipeline.listener
This listener keeps track of the number of ObjectProcessedEvents received from each Stage
ObjectProcessedEventCounter() - Constructor for class org.apache.commons.pipeline.listener.ObjectProcessedEventCounter
 
onFinish(Pipeline) - Method in interface org.apache.commons.pipeline.PipelineLifecycleJob
This is called by the pipeline engine after all data processing has completed.
onStart(Pipeline) - Method in interface org.apache.commons.pipeline.PipelineLifecycleJob
This is called by the pipeline engine once the pipeline is fully configured, just prior to stage driver start.
org.apache.commons.pipeline - package org.apache.commons.pipeline
This package provides a set of pipeline utilities designed around work queues that run in parallel to sequentially process data objects.
org.apache.commons.pipeline.config - package org.apache.commons.pipeline.config
This package provides utilities for creating executing a pipeline using Digester.
org.apache.commons.pipeline.driver - package org.apache.commons.pipeline.driver
This package contains implementations of the StageDriver and StageDriverFactory interfaces.
org.apache.commons.pipeline.event - package org.apache.commons.pipeline.event
Simple event implementations that are useful for pipeline monitoring and control.
org.apache.commons.pipeline.listener - package org.apache.commons.pipeline.listener
Sample implementations of the StageEventListener interface used for testing.
org.apache.commons.pipeline.server - package org.apache.commons.pipeline.server
Code required to set up a pipeline to run as a server.
org.apache.commons.pipeline.stage - package org.apache.commons.pipeline.stage
A few simple Stage implementations for common use cases.
org.apache.commons.pipeline.testFramework - package org.apache.commons.pipeline.testFramework
Framework classes used to simplify unit test development for pipeline stages.
org.apache.commons.pipeline.util - package org.apache.commons.pipeline.util
 
org.apache.commons.pipeline.validation - package org.apache.commons.pipeline.validation
Utilities for validating stage connectivity within a pipeline.

P

Pipeline - Class in org.apache.commons.pipeline
This class represents a processing system consisting of a number of stages and branches.
Pipeline() - Constructor for class org.apache.commons.pipeline.Pipeline
Creates and initializes a new Pipeline.
PipelineContext - Class in org.apache.commons.pipeline.server
 
PipelineContext() - Constructor for class org.apache.commons.pipeline.server.PipelineContext
Creates a new instance of PipelineContext
PipelineCreationException - Exception in org.apache.commons.pipeline
This is a wrapper exception for use by PipelineFactorys.
PipelineCreationException() - Constructor for exception org.apache.commons.pipeline.PipelineCreationException
Creates a new instance of PipelineCreationException without detail message.
PipelineCreationException(String) - Constructor for exception org.apache.commons.pipeline.PipelineCreationException
Constructs an instance of PipelineCreationException with the specified detail message.
PipelineCreationException(String, Throwable) - Constructor for exception org.apache.commons.pipeline.PipelineCreationException
Constructs an instance of PipelineCreationException with the specified detail message.
PipelineCreationException(Throwable) - Constructor for exception org.apache.commons.pipeline.PipelineCreationException
Constructs an instance of PipelineCreationException with the specified detail message.
PipelineFactory - Interface in org.apache.commons.pipeline
Simple factory interface for creating pipelines.
PipelineLifecycleJob - Interface in org.apache.commons.pipeline
This interface specifies a job or set of tasks that are to be run at a well-specified points in the pipeline lifecycle.
PipelineRuleSet - Class in org.apache.commons.pipeline.config
This is a Digester RuleSet that provides rules for parsing a pipeline XML file.
PipelineRuleSet() - Constructor for class org.apache.commons.pipeline.config.PipelineRuleSet
Creates a new instance of the rule set used by Digester to configure a pipeline.
PipelineRuleSet(List<RuleSet>) - Constructor for class org.apache.commons.pipeline.config.PipelineRuleSet
Creates a new pipeline rule set with the specified collection of additional rule sets that may be used for recursive creation of branch pipelines.
PipelineService - Class in org.apache.commons.pipeline.server
 
PipelineService() - Constructor for class org.apache.commons.pipeline.server.PipelineService
Creates a new instance of PipelineService
PipelineShutdownRequest - Class in org.apache.commons.pipeline.event
 
PipelineShutdownRequest(Stage, String) - Constructor for class org.apache.commons.pipeline.event.PipelineShutdownRequest
Creates a new instance of ObjectProcessedEvent
PipelineShutdownStage - Class in org.apache.commons.pipeline.stage
 
PipelineShutdownStage() - Constructor for class org.apache.commons.pipeline.stage.PipelineShutdownStage
Creates a new instance of PipelineShutdownStage
PipelineShutdownStage(int) - Constructor for class org.apache.commons.pipeline.stage.PipelineShutdownStage
Creates a new instance of PipelineShutdownStage
PipelineValidator - Interface in org.apache.commons.pipeline.validation
This interface is used as the basis for validation strategies that may be used to check the validity of a pipeline under construction.
postprocess() - Method in class org.apache.commons.pipeline.stage.BaseStage
No-op implementation.
postprocess() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
Called when a stage has completed all processing.
postprocess() - Method in class org.apache.commons.pipeline.stage.LogStage
Logs tht point at which postprocessing runs
postprocess() - Method in interface org.apache.commons.pipeline.Stage
Implementations of this method should do any additional processing or finalization necessary after all data objects have been processed by the stage.
postprocess() - Method in class org.apache.commons.pipeline.testFramework.TestStage
 
postprocessed - Variable in class org.apache.commons.pipeline.testFramework.TestStage
 
preprocess() - Method in class org.apache.commons.pipeline.stage.BaseStage
No-op implementation.
preprocess() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
Called when a stage has been created but before the first object is sent to the stage for processing.
preprocess() - Method in class org.apache.commons.pipeline.stage.FileFinderStage
Precompiles the regex pattern for matching against filenames
preprocess() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Creates the download directory workDir uf it does not exist and makes a connection to the remote FTP server.
preprocess() - Method in class org.apache.commons.pipeline.stage.LogStage
Logs the point at which preprocessing runs.
preprocess() - Method in interface org.apache.commons.pipeline.Stage
Implementations of this method should perform any necessary setup that needs to be done before any data is processed.
preprocess() - Method in class org.apache.commons.pipeline.testFramework.TestStage
 
preprocessed - Variable in class org.apache.commons.pipeline.testFramework.TestStage
 
process(Object) - Method in class org.apache.commons.pipeline.stage.AddToCollectionStage
Adds the object to the underlying collection.
process(Object) - Method in class org.apache.commons.pipeline.stage.BaseStage
The only operation performed by this implementation of process() is to feed the specified object to the downstream feeder.
process(Object) - Method in class org.apache.commons.pipeline.stage.DynamicLookupStaticMethodStage
Finds the appropriate method overloading for the method specified by methodName, calls it to process the object, and exqueues any returned object.
process(Object) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
process(Object) - Method in class org.apache.commons.pipeline.stage.FileFinderStage
This method inspects a File object to determine if it matches this FileFinder's filePattern property.
process(Object) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Retrieves files that match the specified FileSpec from the FTP server and stores them in the work directory.
process(Object) - Method in class org.apache.commons.pipeline.stage.HttpFileDownloadStage
Removes a java.net.URL (an HTTP URL) or string representing a URL from the input queue, and then retrieves the data at that URL and stores it in a temporary file.
process(Object) - Method in class org.apache.commons.pipeline.stage.InputStreamLineBreakStage
 
process(Object) - Method in class org.apache.commons.pipeline.stage.InvokeMethodStage
Calls the specified method on the object being processed and exqueues the result
process(Object) - Method in class org.apache.commons.pipeline.stage.InvokeStaticMethodStage
Calls the defined static method and exqueues the returned object if it is not null, otherwise placing the original object on the branch specified by the nullResultBranchKey property if nullResultBranchKey is not null.
process(Object) - Method in class org.apache.commons.pipeline.stage.KeyWaitBufferStage
 
process(Object) - Method in class org.apache.commons.pipeline.stage.LogStage
Logs the current state of an object on the queue and passes the object unchanged to the next stage in the pipeline.
process(Object) - Method in class org.apache.commons.pipeline.stage.PipelineShutdownStage
Maintains a count of objects.
process(Object) - Method in interface org.apache.commons.pipeline.Stage
Implementations of this method should atomically process a single data object and transfer any feed objects resulting from this processing to the downstream Feeder.
process(Object) - Method in class org.apache.commons.pipeline.stage.RaiseEventStage
 
process(Object) - Method in class org.apache.commons.pipeline.stage.RaiseKeyAvailableEventStage
This implementation of process() simply generates a key for the processed object and raises a KeyAvailableEvent with the generated key, then emits the processed object unchanged.
process(Object) - Method in class org.apache.commons.pipeline.stage.URLToInputStreamStage
Takes a String or a URL object representing a URL and exqueues the input stream returned by opening that URL.
process(Object) - Method in class org.apache.commons.pipeline.testFramework.FaultingTestStage
 
process(Object) - Method in class org.apache.commons.pipeline.testFramework.TestStage
 
processedObjects - Variable in class org.apache.commons.pipeline.testFramework.TestStage
 
ProcessingException - Exception in org.apache.commons.pipeline
This exception class is used to store detailed information about a failure in the processing step of a stage including the failing data, the driver state at the time of failure, and any exceptions encountered.
ProcessingException(Stage, Throwable, Object, StageDriver.State) - Constructor for exception org.apache.commons.pipeline.ProcessingException
Creates a new instance of ProcessingException
processingExceptions - Variable in class org.apache.commons.pipeline.driver.AbstractStageDriver
List of processing failures that have occurred.
ProducedTypes - Annotation Type in org.apache.commons.pipeline.validation
This annotation is used to describe the objects produced by a Stage.
ProducesConsumed - Annotation Type in org.apache.commons.pipeline.validation
This marker annotation indicates that the Stage produces the same type of object that is consumed (or any subtype thereof).
ProductionOnBranch - Annotation Type in org.apache.commons.pipeline.validation
This annotation is used to describe the production of a Stage for a specific branch pipeline.

Q

QueueFactory<T> - Interface in org.apache.commons.pipeline.util
Many StageDriver implementations require for one or more queues to be created.
QueueFactory.AbstractQueueFactory<T> - Class in org.apache.commons.pipeline.util
 
QueueFactory.AbstractQueueFactory() - Constructor for class org.apache.commons.pipeline.util.QueueFactory.AbstractQueueFactory
 
QueueFactory.ConcurrentLinkedQueueFactory<T> - Class in org.apache.commons.pipeline.util
 
QueueFactory.ConcurrentLinkedQueueFactory() - Constructor for class org.apache.commons.pipeline.util.QueueFactory.ConcurrentLinkedQueueFactory
 
QueueFactory.LinkedListFactory<T> - Class in org.apache.commons.pipeline.util
 
QueueFactory.LinkedListFactory() - Constructor for class org.apache.commons.pipeline.util.QueueFactory.LinkedListFactory
 
QueueFactory.PriorityQueueFactory<T> - Class in org.apache.commons.pipeline.util
 
QueueFactory.PriorityQueueFactory() - Constructor for class org.apache.commons.pipeline.util.QueueFactory.PriorityQueueFactory
 

R

raise(EventObject) - Method in class org.apache.commons.pipeline.Pipeline
Asynchronously notifies each registered listener of an event and propagates the event to any attached branches and the parent pipeline.
raise(EventObject) - Method in interface org.apache.commons.pipeline.StageContext
Notifies each registered listener of an event and propagates the event to any attached branches
raise(EventObject) - Method in class org.apache.commons.pipeline.testFramework.TestStageContext
 
raisedEvents - Variable in class org.apache.commons.pipeline.testFramework.TestStageContext
 
RaiseEventStage - Class in org.apache.commons.pipeline.stage
 
RaiseEventStage() - Constructor for class org.apache.commons.pipeline.stage.RaiseEventStage
Creates a new instance of RaiseEventStage
RaiseKeyAvailableEventStage - Class in org.apache.commons.pipeline.stage
 
RaiseKeyAvailableEventStage() - Constructor for class org.apache.commons.pipeline.stage.RaiseKeyAvailableEventStage
Creates a new instance of RaiseKeyAvailableEventStage
receivedValues - Variable in class org.apache.commons.pipeline.testFramework.TestFeeder
 
recordFatalError(Throwable) - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
Store a fatal error.
recordProcessingException(Object, Throwable) - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
Store processing failure information for the specified data object.
registerDownstreamFeeder(Stage, Feeder) - Method in class org.apache.commons.pipeline.testFramework.TestStageContext
This method is used by the test implementation to set up the feeders for a stage as though they were provided by drivers in a pipeline.
registerListener(StageEventListener) - Method in class org.apache.commons.pipeline.Pipeline
Adds a StageEventListener to the context that will be notified by calls to StageContext.raise(EventObject).
registerListener(StageEventListener) - Method in interface org.apache.commons.pipeline.StageContext
Adds a StageEventListener to the context that will be notified by calls to StageContext.raise(EventObject).
registerListener(StageEventListener) - Method in class org.apache.commons.pipeline.testFramework.TestStageContext
 
release() - Method in class org.apache.commons.pipeline.stage.BaseStage
No-op implementation.
release() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
release() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Disconnects from FTP server.
release() - Method in class org.apache.commons.pipeline.stage.LogStage
Logs the point at which stage resources are released.
release() - Method in interface org.apache.commons.pipeline.Stage
Implementations of this method should clean up any lingering resources that might otherwise be left allocated if an exception is thrown during processing (or pre/postprocessing).
release() - Method in class org.apache.commons.pipeline.stage.URLToInputStreamStage
Ensure that all opened input streams are closed.
release() - Method in class org.apache.commons.pipeline.testFramework.TestStage
 
released - Variable in class org.apache.commons.pipeline.testFramework.TestStage
 
run() - Method in class org.apache.commons.pipeline.Pipeline
Runs the pipeline from start to finish.
run() - Method in class org.apache.commons.pipeline.server.PipelineService
 

S

setCapacity(int) - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.ArrayBlockingQueueFactory
Getter for property capacity.
setCapacity(int) - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.LinkedBlockingQueueFactory
Getter for property capacity.
setCollectBranchStats(Boolean) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
setCollectBranchStats(Boolean) - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
Branch stats are disabled by default because they are slow.
setComparator(Comparator<? super T>) - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.PriorityBlockingQueueFactory
Setter for property comparator.
setComparator(Comparator<? super T>) - Method in class org.apache.commons.pipeline.util.QueueFactory.PriorityQueueFactory
Setter for property comparator.
setCurrentStatWindowSize(Integer) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
setCurrentStatWindowSize(Integer) - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
Set the size of the service time collection window
setEnv(String, Object) - Method in class org.apache.commons.pipeline.Pipeline
Sets the value corresponding to the specified environment variable key.
setFair(boolean) - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.ArrayBlockingQueueFactory
Setter for property fair.
setFair(boolean) - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.SynchronousQueueFactory
Setter for property fair.
setFaultTolerance(FaultTolerance) - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
Sets the failure tolerance flag for the worker thread.
setFaultTolerance(FaultTolerance) - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriverFactory
Setter for property faultTolerance.
setFaultTolerance(FaultTolerance) - Method in class org.apache.commons.pipeline.driver.SynchronousStageDriverFactory
Setter for property faultTolerance.
setFaultTolerance(FaultTolerance) - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Setter for property faultTolerance.
setFaultToleranceLevel(String) - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriverFactory
Convenience setter for property faultTolerance for use by Digester.
setFaultToleranceLevel(String) - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Convenience setter for property faultTolerance for use by Digester.
setFilePattern(String) - Method in class org.apache.commons.pipeline.stage.FileFinderStage
Setter for property filePattern.
setFileType(String) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Sets the file type for the transfer.
setHost(String) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Setter for property host.
setIgnoreExisting(boolean) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Setter for property ignoreExisting.
setIgnoringBlankLines(boolean) - Method in class org.apache.commons.pipeline.stage.InputStreamLineBreakStage
Specifies that this stage will not exqueue blank lines.
setInitialCapacity(int) - Method in class org.apache.commons.pipeline.util.BlockingQueueFactory.PriorityBlockingQueueFactory
Setter for property initialCapacity.
setInitialCapacity(int) - Method in class org.apache.commons.pipeline.util.QueueFactory.PriorityQueueFactory
Setter for property initialCapacity.
setInitialContents(Collection<? extends T>) - Method in class org.apache.commons.pipeline.util.QueueFactory.AbstractQueueFactory
Setter for property initialContents.
setJmxEnabled(boolean) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
setKeyFactory(KeyFactory<Object, ? extends Object>) - Method in class org.apache.commons.pipeline.stage.KeyWaitBufferStage
Setter for property keyFactory.
setKeyFactory(KeyFactory<Object, Object>) - Method in class org.apache.commons.pipeline.stage.RaiseKeyAvailableEventStage
Sets the KeyFactory used to create keys for the objects processed by this stage.
setLog(Log) - Method in class org.apache.commons.pipeline.stage.LogStage
Sets the logger.
setLog(String) - Method in class org.apache.commons.pipeline.stage.LogStage
Sets the logger based upon the log name.
setLog(Class) - Method in class org.apache.commons.pipeline.stage.LogStage
Sets the logger based upon the specified class.
setNullResultBranchKey(String) - Method in class org.apache.commons.pipeline.stage.DynamicLookupStaticMethodStage
Setter for property nullResultBranchKey.
setNullResultBranchKey(String) - Method in class org.apache.commons.pipeline.stage.InvokeStaticMethodStage
Setter for property nullResultBranchKey.
setNumThreads(int) - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Sets the number of threads that will be allocated to the thread pool of a driver created by this factory.
setOverwrite(boolean) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Setter for property overwrite.
setPassword(String) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Setter for property password.
setPath(String) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Setter for property path.
setPattern(String) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Setter for property pattern.
setPort(int) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Setter for property port.
setQueueFactory(BlockingQueueFactory<?>) - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriverFactory
Setter for property queueFactory.
setQueueFactory(BlockingQueueFactory<?>) - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Setter for property queueFactory.
setQueueFactory(QueueFactory<Object>) - Method in class org.apache.commons.pipeline.stage.KeyWaitBufferStage
Setter for property queueFactory.
setRecursive(boolean) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec
Sets the flag determining whether or not the stage will recursively traverse the directory tree to find files.
setServiceInterval(long) - Method in class org.apache.commons.pipeline.server.PipelineService
Setter for property serviceInterval.
setStageName(String) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
setState(StageDriver.State) - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
Set the current state of stage processing and notify any listeners that may be waiting on a state change.
setStatusBatchSize(Integer) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
setStatusBatchSize(Integer) - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
 
setStatusInterval(Long) - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
setStatusInterval(Long) - Method in interface org.apache.commons.pipeline.stage.ExtendedBaseStageMBean
 
setTerminalFeeder(Feeder) - Method in class org.apache.commons.pipeline.Pipeline
Sets the terminal feeder used to handle any output from the final stage.
setTimeout(long) - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriverFactory
Setter for property timeout.
setTimeout(long) - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Setter for property timeout.
setUser(String) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Setter for property user.
setValidator(PipelineValidator) - Method in class org.apache.commons.pipeline.Pipeline
Sets the validator used to validate the pipeline as it is contstructed.
setWorkDir(String) - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage
Sets the working directory for the file download.
setWorkDir(String) - Method in class org.apache.commons.pipeline.stage.HttpFileDownloadStage
Sets the working directory for the file download.
SimplePipelineValidator - Class in org.apache.commons.pipeline.validation
This is a simple default implementation of the PipelineValidator interface that checks stage and branch connectivity.
SimplePipelineValidator() - Constructor for class org.apache.commons.pipeline.validation.SimplePipelineValidator
Creates a new instance of PipelineValidator
stage - Variable in class org.apache.commons.pipeline.driver.AbstractStageDriver
The stage to run.
Stage - Interface in org.apache.commons.pipeline
A Stage represents a set of tasks that can be performed on objects in a queue, and methods used to communicate with other stages in a Pipeline.
stageContext - Variable in class org.apache.commons.pipeline.stage.ExtendedBaseStage
 
StageContext - Interface in org.apache.commons.pipeline
This interface represents the context in which a stage is run.
StageDriver - Interface in org.apache.commons.pipeline
This interface is used to define how processing for a stage is started, stopped, and run.
StageDriver.State - Enum in org.apache.commons.pipeline
This enumeration represents possible states of the a stage driver during processing.
StageDriverFactory<T extends StageDriver> - Interface in org.apache.commons.pipeline
This interface represents a factory that is used by a Pipeline to create a driver for a Stage when that stage is added to the pipeline.
StageEventListener - Interface in org.apache.commons.pipeline
Listener interface for EventObjects.
StageException - Exception in org.apache.commons.pipeline
Exception wrapper class for exceptions that occur while processing a stage.
StageException(Stage) - Constructor for exception org.apache.commons.pipeline.StageException
Creates a new instance of StageException without detail message.
StageException(Stage, String) - Constructor for exception org.apache.commons.pipeline.StageException
Constructs an instance of StageException with the specified detail message.
StageException(Stage, Throwable) - Constructor for exception org.apache.commons.pipeline.StageException
Constructs an instance of StageException with the specified detail message and cause
StageException(Stage, String, Throwable) - Constructor for exception org.apache.commons.pipeline.StageException
Constructs an instance of StageException with the specified detail message and cause
start() - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
This method is used to start the driver, run the preprocess() method of the attached stage and to then begin processing any objects fed to this driver's Feeder.
start() - Method in class org.apache.commons.pipeline.driver.DedicatedThreadStageDriver
Start the processing of the stage.
start() - Method in class org.apache.commons.pipeline.driver.SynchronousStageDriver
Performs preprocessing and updates the driver state.
start() - Method in class org.apache.commons.pipeline.driver.ThreadPoolStageDriver
Start the processing of the stage.
start() - Method in class org.apache.commons.pipeline.Pipeline
This method iterates over the stages in the pipeline, looking up a StageDriver for each stage and using that driver to start the stage.
start() - Method in interface org.apache.commons.pipeline.StageDriver
This method is used to start the driver, run the preprocess() method of the attached stage and to then begin processing any objects fed to this driver's Feeder.
status() - Method in class org.apache.commons.pipeline.stage.ExtendedBaseStage
Class-specific status message.
SynchronousStageDriver - Class in org.apache.commons.pipeline.driver
This is a non-threaded version of the AbstractStageDriver.
SynchronousStageDriver(Stage, StageContext, FaultTolerance) - Constructor for class org.apache.commons.pipeline.driver.SynchronousStageDriver
Creates a new instance of SimpleStageDriver
SynchronousStageDriverFactory - Class in org.apache.commons.pipeline.driver
Factory for SynchronousStageDriver objects.
SynchronousStageDriverFactory() - Constructor for class org.apache.commons.pipeline.driver.SynchronousStageDriverFactory
Creates a new instance of SynchronousStageDriverFactory

T

testAndSetState(StageDriver.State, StageDriver.State) - Method in class org.apache.commons.pipeline.driver.AbstractStageDriver
This method performs an atomic conditional state transition change to the value specified by the nextState parameter if and only if the current state is equal to the test state.
TestFeeder - Class in org.apache.commons.pipeline.testFramework
This feeder simply adds the received objects to a list.
TestFeeder() - Constructor for class org.apache.commons.pipeline.testFramework.TestFeeder
 
TestStage - Class in org.apache.commons.pipeline.testFramework
 
TestStage(int) - Constructor for class org.apache.commons.pipeline.testFramework.TestStage
Construct a TestStage with a numeric index used to easily identify this stage.
TestStageContext - Class in org.apache.commons.pipeline.testFramework
Stage Context for test harness.
TestStageContext() - Constructor for class org.apache.commons.pipeline.testFramework.TestStageContext
 
threadLocalEmitBranchTime - Static variable in class org.apache.commons.pipeline.stage.ExtendedBaseStage
ThreadLocal sum of time spent waiting on blocked queues during the current process call by queue name.
ThreadPoolStageDriver - Class in org.apache.commons.pipeline.driver
This StageDriver implementation uses a pool of threads to process objects from an input queue.
ThreadPoolStageDriver(Stage, StageContext, BlockingQueue, long, FaultTolerance, int) - Constructor for class org.apache.commons.pipeline.driver.ThreadPoolStageDriver
Creates a new ThreadPoolStageDriver.
ThreadPoolStageDriverFactory - Class in org.apache.commons.pipeline.driver
This factory is used to create ThreadPoolStageDriver instances configured to run specific stages.
ThreadPoolStageDriverFactory() - Constructor for class org.apache.commons.pipeline.driver.ThreadPoolStageDriverFactory
Creates a new instance of ThreadPoolStageDriverFactory
toString() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileDateMatchCriterion
Printable version of this Criterion indicating the inclusive date range used for file date matching.
toString() - Method in class org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileNameMatchCriterion
Printable version of this Criterion indicating the Java regex used for filename matching.
toString() - Method in class org.apache.commons.pipeline.testFramework.TestStage
 

U

URLToInputStreamStage - Class in org.apache.commons.pipeline.stage
Converts a URL into an InputStream.
URLToInputStreamStage() - Constructor for class org.apache.commons.pipeline.stage.URLToInputStreamStage
Creates a new instance of URLToInputStreamStage

V

validate(Pipeline) - Method in interface org.apache.commons.pipeline.validation.PipelineValidator
Implementations of this method should validate the overall structure of the pipeline.
validate(Pipeline) - Method in class org.apache.commons.pipeline.validation.SimplePipelineValidator
This method validates the entire structure of the pipeline, ensuring that the data produced by each stage can be consumed by the subsequent stage and/or relevant branch pipelines.
validateAddBranch(Pipeline, String, Pipeline) - Method in interface org.apache.commons.pipeline.validation.PipelineValidator
Implementations of this method should validate whether or not the specified branch can be added to the specified pipeline with the given key.
validateAddBranch(Pipeline, String, Pipeline) - Method in class org.apache.commons.pipeline.validation.SimplePipelineValidator
Validate whether or not the specified branch pipeline can be added with the specified key.
validateAddStage(Pipeline, Stage, StageDriverFactory) - Method in interface org.apache.commons.pipeline.validation.PipelineValidator
Implementations of this method should validate whether or not the specified stage can be added to the pipeline in its current state.
validateAddStage(Pipeline, Stage, StageDriverFactory) - Method in class org.apache.commons.pipeline.validation.SimplePipelineValidator
Validate whether or not a stage can be added to the pipeline.
ValidationException - Exception in org.apache.commons.pipeline.validation
This exception is used to indicate that one or more validation errors have occurred during an operation.
ValidationException(List<ValidationFailure>) - Constructor for exception org.apache.commons.pipeline.validation.ValidationException
Creates a new instance of ValidationException without detail message.
ValidationException(String, List<ValidationFailure>) - Constructor for exception org.apache.commons.pipeline.validation.ValidationException
Constructs an instance of ValidationException with the specified detail message.
ValidationFailure - Class in org.apache.commons.pipeline.validation
This class is used to store a collection of information about a particular validation failure.
ValidationFailure(ValidationFailure.Type, String, Stage, Stage) - Constructor for class org.apache.commons.pipeline.validation.ValidationFailure
Creates a new instance of ValidationError
ValidationFailure.Type - Enum in org.apache.commons.pipeline.validation
Enumeration of possible causes of validation failure
ValidationUtils - Class in org.apache.commons.pipeline.validation
A collection of utility methods used by the validation system.
valueOf(String) - Static method in enum org.apache.commons.pipeline.driver.FaultTolerance
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec.FileType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.commons.pipeline.StageDriver.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.commons.pipeline.validation.ValidationFailure.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.commons.pipeline.driver.FaultTolerance
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.commons.pipeline.stage.FtpFileDownloadStage.FileSpec.FileType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.commons.pipeline.StageDriver.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.commons.pipeline.validation.ValidationFailure.Type
Returns an array containing the constants of this enum type, in the order they are declared.
VOID - Static variable in interface org.apache.commons.pipeline.Feeder
This Feeder implementation provides a standard, no-op sink for objects.

A B C D E F G H I K L M N O P Q R S T U V

Copyright © 2004-2009 The Apache Software Foundation. All Rights Reserved.