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

A

Action - Class in simple.template
The Action object provides a service controller implementation for taking an action before delegating to other service implementations, which will handle the view.
Action(Context) - Constructor for class simple.template.Action
Constructor for the Action object.
add(String, String) - Method in class simple.http.FilterRequest
This can be used to add a HTTP message header to this object.
add(String, int) - Method in class simple.http.FilterRequest
This can be used to add a HTTP message header to this object.
add(String, String) - Method in class simple.http.FilterResponse
This can be used to add a HTTP message header to this object.
add(String, int) - Method in class simple.http.FilterResponse
This can be used to add a HTTP message header to this object.
add(String, String) - Method in interface simple.http.GenericHeader
This can be used to add a HTTP message header to this object.
add(String, int) - Method in interface simple.http.GenericHeader
This can be used to add a HTTP message header to this object.
add(Object, long) - Method in class simple.util.PriorityQueue
This function adds the given object into the PriorityQueue, its priority is the long priority.
addDate(String, long) - Method in class simple.http.FilterRequest
This is used as a convenience method for adding a header that needs to be parsed into a HTTP-date string.
addDate(String, long) - Method in class simple.http.FilterResponse
This is used as a convenience method for adding a header that needs to be parsed into a HTTP-date string.
addDate(String, long) - Method in interface simple.http.GenericHeader
This is used as a convenience method for adding a header that needs to be parsed into a HTTP-date string.
addSource(FileSet) - Method in class simple.page.ant.CompileTask
This is used to set the configuration for the source files to build.
append(int) - Method in class simple.util.Buffer
This method is used to append bytes to the end of the Buffer.
append(byte[]) - Method in class simple.util.Buffer
This method is used to append bytes to the end of the Buffer.
append(byte[], int, int) - Method in class simple.util.Buffer
This method is used to append bytes to the end of the Buffer.
append(Buffer) - Method in class simple.util.Buffer
This method is used to append bytes to the end of the Buffer.
append(Buffer, int, int) - Method in class simple.util.Buffer
This method is used to append bytes to the end of the Buffer.
append(char) - Method in class simple.util.parse.ParseBuffer
This will add a char to the end of the buffer.
append(String) - Method in class simple.util.parse.ParseBuffer
This will add a String to the end of the buffer.
append(ParseBuffer) - Method in class simple.util.parse.ParseBuffer
This will add a ParseBuffer to the end of this.
append(char[], int, int) - Method in class simple.util.parse.ParseBuffer
This will add a char to the end of the buffer.
append(String, int, int) - Method in class simple.util.parse.ParseBuffer
This will add a String to the end of the buffer.
append(ParseBuffer, int, int) - Method in class simple.util.parse.ParseBuffer
This will add a ParseBuffer to the end of this.
Attributes - Interface in simple.http
This is an Attributes object which is used to convey attributes for a given connection.

B

base - Variable in class simple.http.serve.FileContext
This will be used to fetch the real OS system paths.
BasicPage - Class in simple.page
The BasicPage object provides the base class for all generated page objects.
BasicPage(Context, String) - Constructor for class simple.page.BasicPage
Constructor for the BasicPage object.
BlockingQueue - Class in simple.util
This provides a quick implementation for a thread safe queue.
BlockingQueue() - Constructor for class simple.util.BlockingQueue
When the size of the BlockingQueue is not specified then the default size of 30 is set, this BlockingQueue cannot resize so care is need when picking a size.
BlockingQueue(int) - Constructor for class simple.util.BlockingQueue
If the capacity given is less than 1 then the size of the queue is increased so that it becomes 1 this means that the queue can tolerate at least one add by a thread.
bubbleDown(int) - Method in class simple.util.PriorityQueue
Bubble down is used to put the element at subscript 'pos' into it's rightfull place in the heap (a heap is another name used for PriorityQueue).
bubbleUp(int) - Method in class simple.util.PriorityQueue
Bubble up is used to place an element relatively low in the queue to it's rightful place higher in the queue, but only if it's priority allows it to do so, similar to bubbleDown only in the other directon this swaps out its parents.
buf - Variable in class simple.util.parse.ParseBuffer
The char's this buffer accumulated.
buf - Variable in class simple.util.parse.Parser
This is the buffer that is being parsed.
Buffer - Class in simple.util
The Buffer is intended to be a general purpose byte Buffer.
Buffer() - Constructor for class simple.util.Buffer
This creates a default Buffer object.
Buffer(int) - Constructor for class simple.util.Buffer
This creates a Buffer.
Buffer(byte[]) - Constructor for class simple.util.Buffer
This creates a Buffer with the data given.
Buffer(Buffer) - Constructor for class simple.util.Buffer
This creates a Buffer with the data given.
Buffer(byte[], int, int) - Constructor for class simple.util.Buffer
This creates a Buffer with the data given.
Buffer(Buffer, int, int) - Constructor for class simple.util.Buffer
This creates a Buffer with the data given.
BufferedPipelineFactory - Class in simple.http
The BufferedPipelineFacotry object is used to buffer the output for network performance.
BufferedPipelineFactory() - Constructor for class simple.http.BufferedPipelineFactory
This creates a PipelineFactory that will issue instances of the Pipeline that buffers output so that 1Kb packets are sent to the underlying socket.
BufferedPipelineFactory(int) - Constructor for class simple.http.BufferedPipelineFactory
This creates a PipelineFactory that will issue instances of the Pipeline that buffers output to a specified size so that packets that are sent to the underlying socket are sufficently large.
ByteStore - Interface in simple.util
The ByteStore class is used to provide access to a byte buffer.

C

cache - Variable in class simple.http.serve.CacheContentFactory
This is used to cache the content objects created.
Cache - Class in simple.util.cache
This is a LRU, Least Recently Used, Cache used to store objects.
Cache() - Constructor for class simple.util.cache.Cache
This is used to create a Cache object for storing objects.
Cache(int, int) - Constructor for class simple.util.cache.Cache
This is used to create a Cache object for storing objects.
cache(Object, Object) - Method in class simple.util.cache.Cache
This will store the object given in the Cache under the reference specified.
cache(Object, Object) - Method in class simple.util.cache.TimeCache
This will store the object given in the TimeCache under the reference specified.
cache(Object, Object, int) - Method in class simple.util.cache.TimeCache
This will store the object given in the TimeCache under the reference specified.
cache - Variable in class simple.util.parse.ParseBuffer
This is used to quicken toString.
CacheContentFactory - Class in simple.http.serve
The CacheContentFactory is used to create a factory that can be used to create and cache files as instances of the Content interface.
CacheContentFactory() - Constructor for class simple.http.serve.CacheContentFactory
Constructor for the CacheContentFactory object.
CacheContentFactory(int) - Constructor for class simple.http.serve.CacheContentFactory
Constructor for the CacheContentFactory object.
CacheContentFactory(int, int, int) - Constructor for class simple.http.serve.CacheContentFactory
Constructor for the CacheContentFactory object.
CacheContext - Class in simple.http.serve
The CacheContext object is used to provide a caching implementation of the context.
CacheContext() - Constructor for class simple.http.serve.CacheContext
Constructor for the CacheContext object.
CacheContext(File) - Constructor for class simple.http.serve.CacheContext
Constructor for the CacheContext object.
CacheContext(File, int) - Constructor for class simple.http.serve.CacheContext
Constructor for the CacheContext object.
CacheContext(File, File) - Constructor for class simple.http.serve.CacheContext
Constructor for the CacheContext object.
CacheContext(File, File[]) - Constructor for class simple.http.serve.CacheContext
Constructor for the CacheContext object.
CacheContext(File, File[], int) - Constructor for class simple.http.serve.CacheContext
Constructor for the CacheContext object.
CacheList - Class in simple.util.cache
This is a LRU, Least Recently Used, list that will store a limited number of objects.
CacheList() - Constructor for class simple.util.cache.CacheList
This will create an list with a maximum allowed number of objects to be inserted into the list.
CacheList(int) - Constructor for class simple.util.cache.CacheList
This will create an list with a maximum allowed number of objects to be inserted into the list.
cancel() - Method in interface simple.util.lease.Lease
This will cancel the lease and release the resource.
capacity() - Method in class simple.util.Buffer
This provides the number of bytes that can fit inside this buffer without requiring an expensive resize.
capacity() - Method in class simple.util.cache.CacheList
This is used to that the capacity of the list can be determined.
capacity - Variable in class simple.util.PriorityQueue
This holds the number elements this queue can have.
capacity() - Method in class simple.util.process.ProcessQueue
This will return the number of threads that this pool currently has cached.
clean(String) - Method in interface simple.util.lease.Cleaner
This method is used to clean up after a the named resource.
Cleaner - Interface in simple.util.lease
The Cleaner represents an object that is used to clean up after the named resource.
clear() - Method in class simple.http.FilterRequest
This is used to clear all HTTP message headers from the message header.
clear() - Method in class simple.http.FilterResponse
This is used to clear all HTTP message headers from the message header.
clear() - Method in interface simple.http.GenericHeader
This is used to clear all HTTP message headers from the message header.
clear() - Method in interface simple.http.State
Removes all cookies from the state.
clear() - Method in class simple.util.Buffer
This will clear all data from the Buffer.
clear() - Method in class simple.util.cache.Cache
This will remove all items from the Cache.
clear() - Method in class simple.util.cache.CacheList
This is a simple method that will purge all entrys from this list.
clear() - Method in class simple.util.cache.TimeCache
This will remove all items from the TimeCache.
clear() - Method in class simple.util.parse.MapParser
The clear method is used to wipe out all the currently existing tokens from the collection.
clear() - Method in class simple.util.parse.ParseBuffer
This will empty the ParseBuffer so that the toString paramater will return null.
clear() - Method in class simple.util.parse.PropertyBuffer
This method is used to clear the contents of the buffer.
clear() - Method in class simple.util.PriorityQueue
This method will empty the queue.
clear() - Method in class simple.util.Resolver
This is used to clear all matches from the resolver.
close() - Method in class simple.http.FilterPipeline
This is a close method that ensures the communication link is shutdown.
close() - Method in class simple.http.Pipeline
This is a close method that ensures the communication link is shutdown.
commit() - Method in class simple.http.FilterResponse
This is used to write the headers that where given to the Response.
commit(Node) - Method in class simple.http.load.PrefixResolver
This is used to commit any data that has been collected during the processing of an element node.
commit() - Method in interface simple.http.Response
This is used to write the headers that where given to the Response.
commit(Node) - Method in class simple.util.xml.Traverser
Once an element and all its child elements have been processed this method is invoked to close the processing of the element.
compile(Source) - Method in class simple.page.compile.Compiler
This will compile an load the specified source specificaiton.
compile(Source, Path) - Method in class simple.page.compile.Compiler
This will compile an load the specified source specificaiton.
Compiler - Class in simple.page.compile
The Compiler object is used to compile a translated source.
Compiler(Workspace) - Constructor for class simple.page.compile.Compiler
Constructor for the Compiler object.
CompileTask - Class in simple.page.ant
The CompileTask represents an Ant task definition that can be used within an Ant build file to compile JSP templates.
CompileTask() - Constructor for class simple.page.ant.CompileTask
 
Component - Class in simple.http.serve
This is an abstract Resource that handles the basic HTTP status reports.
Component() - Constructor for class simple.http.serve.Component
Constructor that creates a Component without any Context object.
Component(Context) - Constructor for class simple.http.serve.Component
Constructor for the Component is given the Context so that it can generate status reports.
compose(String) - Method in class simple.page.Composer
This is used to acquire the Page instance for the named JSP source.
Composer - Class in simple.page
The Composer object is used to convert a requested JSP source file to an executable Java object.
Composer(Context) - Constructor for class simple.page.Composer
Constructor for the Composer object.
Composer(Context, Workspace) - Constructor for class simple.page.Composer
Constructor for the Composer object.
Configuration - Class in simple.http.load
The Configuration object is used to collect property values for services loaded using the mapper engine.
Configuration() - Constructor for class simple.http.load.Configuration
Constructor for the Configuration object.
Configuration(Properties) - Constructor for class simple.http.load.Configuration
Constructor for the Configuration object.
Configurator - Interface in simple.http.connect
The Configurator object is used to allow custom socket configurations to be used for the connected clients.
ConfiguratorFactory - Class in simple.http.connect
The ConfiguratorFactory retrives an instance of the Configurator interface, used to configure the connected TCP sockets.
ConfiguratorFactory() - Constructor for class simple.http.connect.ConfiguratorFactory
 
configure(Socket) - Method in interface simple.http.connect.Configurator
This method is used to configure the TCP connection before the Pipeline is created.
connect(ServerSocket) - Method in class simple.http.connect.Connection
This will establish a thread that will listen for connections using the issued ServerSocket.
Connection - Class in simple.http.connect
The Connection manages connections from ServerSocket's.
Connection(SocketHandler) - Constructor for class simple.http.connect.Connection
Constructor for the Connection object is used to create an instance that delegates all TCP connections to the issued SocketHandler.
ConnectionFactory - Class in simple.http.connect
This is used to create a Connection that will dispatch either HTTP requests or Pipeline objects to the handler specified.
ConnectionFactory() - Constructor for class simple.http.connect.ConnectionFactory
 
Container - Interface in simple.template
The Container object represents an interface to the templating system used by the TemplateEngine.
contains(String) - Method in interface simple.http.Attributes
The contains method is used to determine if a mapping exists for the given name.
contains(String) - Method in class simple.http.FilterRequest
This is used to see if there is a HTTP message header with the given name in this container.
contains(String, String) - Method in class simple.http.FilterRequest
This is used to see if there is a HTTP message header with the given name in this container, if it exists this will check to see if the provided value exists.
contains(String) - Method in class simple.http.FilterResponse
This is used to see if there is a HTTP message header with the given name in this container.
contains(String, String) - Method in class simple.http.FilterResponse
This is used to see if there is a HTTP message header with the given name in this container, if it exists this will check to see if the provided value exists.
contains(String) - Method in interface simple.http.GenericHeader
This is used to see if there is a HTTP message header with the given name in this container.
contains(String, String) - Method in interface simple.http.GenericHeader
This is used to see if there is a HTTP message header with the given name in this container, if it exists this will check to see if the provided value exists.
contains(String) - Method in class simple.http.Pipeline
This can be used to determine if an attribute of a given name is present int the attribute object.
contains(String) - Method in class simple.http.serve.DomainHandler
This is used to lookup a certain pattern match to see if the DomainHandler has it.
contains(String) - Method in interface simple.http.session.Session
This method is used to determine whether there is a value mapped to the specified name.
contains(String) - Method in interface simple.http.session.Store
This method is used to determine whether there is a value mapped to the specified name.
contains(String) - Method in interface simple.http.State
Checks to see if the cookie of the specified name exists in the State.
contains(String) - Method in interface simple.template.Database
The contains method is used to determine if a mapping exists for the given name.
contains(String) - Method in class simple.template.Environment
The contains method is used to determine if a mapping exists for the given name.
contains(Object) - Method in class simple.util.cache.Cache
This will check to see if an object exists within the Cache.
contains(Object) - Method in class simple.util.cache.CacheList
This method will search the list to see if there is an object stored in the list under that name.
contains(Object) - Method in class simple.util.cache.TimeCache
This will check to see if an object exists within the TimeCache.
contains(String) - Method in class simple.util.Resolver
This will check this Resolver to see if the pattern given is used by this Resolver, if it is this will return true.
contains(Match) - Method in class simple.util.Resolver
This will check this Resolver to see if the match given is used by this Resolver, if it is this will return true.
containsKey(Object) - Method in class simple.util.parse.MapParser
This is used to determine whether a token representing the name of a pair has been inserted into the internal map.
containsValue(Object) - Method in class simple.util.parse.MapParser
This method is used to determine whether any pair that has been inserted into the internal map had the presented value.
Content - Interface in simple.http.serve
The Content interface is used to provide an interface to content within a Context.
ContentException - Exception in simple.http.serve
The ContentException is thrown when the content factory cannot produce a suitable Content for an issued request URI.
ContentException() - Constructor for exception simple.http.serve.ContentException
This empty constructor is used if there is no explanation of the loading exception required.
ContentException(String) - Constructor for exception simple.http.serve.ContentException
This constructor is used if there is a description of the event that caused the exception required.
ContentFactory - Interface in simple.http.serve
The ContentFactory is used to create instances of the Content object.
ContentParser - Class in simple.util.parse
ContentParser provides access to the MIME type parts, that is the type subtype and an optional charset parameter.
ContentParser() - Constructor for class simple.util.parse.ContentParser
The default constructor will create a ContentParser that contains no charset, type or subtype.
ContentParser(String) - Constructor for class simple.util.parse.ContentParser
This is primarily a convineance constructor.
ContentType - Interface in simple.util.net
This provides access to the MIME type parts, that is the type subtype and an optional charset parameter.
context - Variable in class simple.http.load.LoaderEngine
This is the context this loader engine operates from.
context - Variable in class simple.http.serve.Component
The Context that this resource is in.
Context - Interface in simple.http.serve
The Context interface is used to give a view of the file system to the ResourceEngine.
context - Variable in class simple.http.serve.FileEngine
Each FileEngine operates using a context.
context - Variable in class simple.page.BasicPage
This provides a context to the underlying OS file system.
Controller - Class in simple.template
The Controller object represents a service that can access documents and properties provided by the templating system environment.
Controller(Context) - Constructor for class simple.template.Controller
Constructor for the Controller object.
cookie - Variable in class simple.http.session.ReflectionStore
This is the cookie that is used to identify the session.
Cookie - Class in simple.util.net
This class is used to represent a generic cookie.
Cookie() - Constructor for class simple.util.net.Cookie
Constructor of the Cookie that does not need the name or value to be set.
Cookie(String, String) - Constructor for class simple.util.net.Cookie
Constructor of the Cookie that uses a default version of 1, which is used by RFC 2109.
Cookie(String, String, String) - Constructor for class simple.util.net.Cookie
Constructor of the Cookie that uses a default version of 1, which is used by RFC 2109.
CookieCollection - Interface in simple.util.net
The CookieCollection object is used to represent a collection of one or more Cookie's.
CookieParser - Class in simple.util.parse
CookieParser is used to parse the cookie header.
CookieParser() - Constructor for class simple.util.parse.CookieParser
Create a CookieParser that contains no cookies.
CookieParser(String) - Constructor for class simple.util.parse.CookieParser
This is primarily a convineance constructor.
count - Variable in class simple.util.parse.ParseBuffer
This is the number of char's stored.
count - Variable in class simple.util.parse.Parser
This represents the length of the buffer.
count - Variable in class simple.util.PriorityQueue
Holds the number of elements currently in the queue.
createClasspath() - Method in class simple.page.ant.CompileTask
This is used to create a classpath element from the Ant task.
currentTime() - Method in class simple.util.schedule.Scheduler
This returns the currentTime in milliseconds from the creation of this.

D

data - Variable in class simple.http.load.MapperEngine
Contains the object that is passed to each service object.
data - Variable in class simple.template.Controller
This is the configuration object for this service object.
data - Variable in class simple.util.PriorityQueue
This contains the list of objects in the queue.
Database - Interface in simple.template
The Database interface is used to represent a source of data for a template.
DateParser - Class in simple.util.parse
This is used to create a Parser for the HTTP date format.
DateParser() - Constructor for class simple.util.parse.DateParser
The default constructor will create a parser that can parse Strings that contain dates in the form of RFC 1123, RFC 850 or asctime.
DateParser(long) - Constructor for class simple.util.parse.DateParser
This constructor will convienently parse the long argument in the constructor.
DateParser(String) - Constructor for class simple.util.parse.DateParser
This constructor will convienently parse the String argument in the constructor.
DEFAULT_FREQ - Static variable in class simple.util.schedule.PulseScheduler
The default frequency with which times are rounded.
DEFAULT_MAX - Static variable in class simple.util.schedule.Scheduler
The maximum length of time an object can be enqueued.
delegate - Variable in class simple.http.load.LoaderEngine
This is used to update any Loader objects.
delete(int) - Method in class simple.util.Buffer
This is used to delete a region of data from the Buffer.
delete(int, int) - Method in class simple.util.Buffer
This is used to delete a region of data from the Buffer.
dequeue() - Method in class simple.util.BlockingQueue
If this dequeues from a full queue it notifys any enqueuers who were waiting to add to the full queue, so that they do not block.
dequeue() - Method in class simple.util.MessageQueue
This is guaranteed to return an object.
dequeue() - Method in class simple.util.schedule.Scheduler
This is used to dequeue the objects from the Scheduler.
destroy() - Method in interface simple.http.session.Session
In order to free up any resources consumed by this object it must be destroyed when it is no longer useful.
destroy() - Method in interface simple.http.session.Store
In order to free up any resources consumed by this object it must be destroyed when it is no longer useful.
digit(char) - Method in class simple.util.parse.Parser
This is used to determine wheather or not a given character is a digit character.
Document - Interface in simple.template
A Document object represents a template with a set of properties.
DomainHandler - Class in simple.http.serve
This class is used to route requests to the proper host.
DomainHandler(ProtocolHandler) - Constructor for class simple.http.serve.DomainHandler
Constructor for the DomainHandler.

E

engine - Variable in class simple.http.load.Service
This is the loader engine used to load this service object.
enqueue(Object) - Method in class simple.util.BlockingQueue
If this enqueues to an empty queue it notifys any dequeuers that were trying to take from the empty queue.
enqueue(Object) - Method in class simple.util.MessageQueue
If this enqueues to an empty queue it notifys any dequeuers that were trying to take from the empty queue.
enqueue(Scheduler.Entry) - Method in class simple.util.schedule.PulseScheduler
This just adds some changes to the superclasses version of the enqueue method.
enqueue(Object, long) - Method in class simple.util.schedule.Scheduler
This schedules objects so that they will not be released until the specified timeout has expired.
enqueue(Scheduler.Entry) - Method in class simple.util.schedule.Scheduler
This adds an entry object into the SchedulerQueue this will set a priority based on the time this object is to be released at, that is the sooner that the entry is to be released the higher its priority.
ensureCapacity(int) - Method in class simple.util.parse.ParseBuffer
This ensure that there is enough space in the buffer to allow for more char's to be added.
ensureCapacity(int) - Method in class simple.util.parse.Parser
This ensure that there is enough space in the buffer to allow for more char's to be added.
entrySet() - Method in class simple.util.parse.MapParser
This method is used to acquire the name and value pairs that have currently been collected by this parser.
Environment - Class in simple.template
The Delegate provides a full implementation of an environment.
Environment(Container, Context) - Constructor for class simple.template.Environment
Constructor for the Delegate object.
equals(Buffer) - Method in class simple.util.Buffer
This is used to compare the contents of one Buffer with the contents of another.
error - Static variable in class simple.http.serve.ErrorReport
This is used to load the Error.properties file for a list of the matching HTTP error messages.
ErrorReport - Class in simple.http.serve
The ErrorReport is used to describe HTTP errors.
ErrorReport(Throwable, int) - Constructor for class simple.http.serve.ErrorReport
Constructor for the ErrorReport object.
execute() - Method in class simple.page.ant.CompileTask
This is used to execute the compile step.
execute(File, String[]) - Method in class simple.page.ant.CompileTask
This is used to execute the compile step.
execute(Request, Response) - Method in class simple.template.Action
The execute method is used to perform various operations before a request and response is forwarded.
execute(Request, Response) - Method in class simple.template.View
The execute method is used to perform various operations before a template is rendered.
execute(Request, Response, Document) - Method in class simple.template.View
The execute method is used to perform various operations before a template is rendered.
execute(Runnable) - Method in class simple.util.process.ProcessQueue
This is used to execute the Runnable objects with one of the threads from the pool.
exists(String) - Method in interface simple.template.Container
Determines whether the named template exists.
exists(String) - Method in class simple.template.Environment
Determines whether the named template exists.
exists(String) - Method in class simple.template.freemarker.FreemarkerContainer
Determines whether the named template exists.
exists(String) - Method in class simple.template.page.PageContainer
Determines whether the named template exists.
exists(String) - Method in class simple.template.velocity.VelocityContainer
Determines whether the named template exists.
expandCapacity() - Method in class simple.util.PriorityQueue
This ensures that there is enough space to keep adding elements to the priority queue.
extend - Variable in class simple.http.serve.ExtendedContext
The context used if a file is not found in this context.
ExtendedContext - Class in simple.http.serve
The ExtendedContext object is used to provide a file context that extends another seperate context.
ExtendedContext(File, File) - Constructor for class simple.http.serve.ExtendedContext
Constructor for the ExtendedContext object.
ExtendedContext(File, File, File[]) - Constructor for class simple.http.serve.ExtendedContext
Constructor for the ExtendedContext object.

F

factory - Variable in class simple.http.serve.FactoryContext
This is used to acquire Content implementations.
factory - Variable in class simple.page.compile.Compiler
This is used to create a compiler for the specified source.
FactoryContext - Class in simple.http.serve
e The FactoryContext is a context implementation that can be used to serve dynamic Content objects.
FactoryContext(ContentFactory) - Constructor for class simple.http.serve.FactoryContext
Constructor for the FactoryContext.
FactoryContext(ContentFactory, File) - Constructor for class simple.http.serve.FactoryContext
Constructor for the FactoryContext.
FactoryContext(ContentFactory, File, File) - Constructor for class simple.http.serve.FactoryContext
Constructor for the FactoryContext.
FactoryContext(ContentFactory, File, File[]) - Constructor for class simple.http.serve.FactoryContext
Constructor for the FactoryContext.
FileContext - Class in simple.http.serve
The FileContext provides an implementation of the Context object that provides a direct mapping from a request URI as defined in RFC 2616 to an OS specific target.
FileContext() - Constructor for class simple.http.serve.FileContext
Constructor for creating an instance that operates from the given current working path.
FileContext(File) - Constructor for class simple.http.serve.FileContext
Constructor for creating an instance that operates from the given OS specific base path.
FileContext(File, File) - Constructor for class simple.http.serve.FileContext
Constructor for creating an instance that operates from the given OS specific base path.
FileContext(File, File[]) - Constructor for class simple.http.serve.FileContext
Constructor for creating an instance that operates from the given OS specific base path.
FileContext(File, Locator) - Constructor for class simple.http.serve.FileContext
Constructor for creating an instance that operates from the given OS specific base path.
FileEngine - Class in simple.http.serve
The FileEngine is used to produce implementations of the Resource object to represent files on the underlying filesystem.
FileEngine() - Constructor for class simple.http.serve.FileEngine
Constructor for the FileEngine.
FileEngine(Context) - Constructor for class simple.http.serve.FileEngine
Constructor takes a Context implementation and operates relative to that implementation.
FileLocator - Class in simple.http.serve
The FileLocator provides an implementation of the Locator interface for locating files from a list of directories.
FileLocator() - Constructor for class simple.http.serve.FileLocator
Constructor for the FileLocator object.
FileLocator(File) - Constructor for class simple.http.serve.FileLocator
Constructor for the FileLocator object.
FileLocator(File[]) - Constructor for class simple.http.serve.FileLocator
Constructor for the FileLocator object.
FileProperties - Class in simple.util
The FileProperties object is used as a convienience class that is used to create a Properties object from a file path.
FileProperties(String) - Constructor for class simple.util.FileProperties
Constructor for the FileProperties object.
FileProperties(File, String) - Constructor for class simple.util.FileProperties
Constructor for the FileProperties object.
FileProperties(File) - Constructor for class simple.util.FileProperties
Constructor for the FileProperties object.
FilterPipeline - Class in simple.http
This is a FilterPipeline object that is used to wrap the Pipeline it is given.
FilterPipeline() - Constructor for class simple.http.FilterPipeline
/** This constructor allows the FilterPipeline to be extended in such a way that it does not do any initialization of the object itself.
FilterPipeline(Pipeline) - Constructor for class simple.http.FilterPipeline
This wraps the Pipeline given.
FilterRequest - Class in simple.http
The FilterRequest object is used so that the original Request object can be wrapped in a filtering proxy object.
FilterRequest(Request) - Constructor for class simple.http.FilterRequest
Constructor for FilterRequest allows the original Request object to be wrapped so that adjustments to the behavior of a Request object handed to a specialized ProtocolHandler can be done simply.
FilterResponse - Class in simple.http
The FilterResponse object is used so that the original Response object can be wrapped in a filtering proxy object.
FilterResponse(Response) - Constructor for class simple.http.FilterResponse
Constructor for FilterResponse allows the original Response object to be wrapped so that adjustments to the behavior of a Response object handed to a specialized ProtocolHandler can be done simply.
finish() - Method in class simple.http.load.PrefixResolver
Used to prepare the prefix paths so that they can be matched with relative URI paths quickly.
finish() - Method in class simple.util.xml.Traverser
When all elements of the KDOM have been traversed this method is used to perform post processing of the collected data.
format - Variable in class simple.http.serve.FileContext
This is the format instance used by this instance.
Format - Interface in simple.http.serve
The Format class is used to provide a specified format to pages retrived by the ResourceEngine.
FormatException - Exception in simple.http.serve
The FormatException is thrown is there was a problem aquiring contents from a Format object.
FormatException() - Constructor for exception simple.http.serve.FormatException
This empty constructor is used if there is no explanation of the format exception required.
FormatException(String) - Constructor for exception simple.http.serve.FormatException
This constructor is used if there is a description of the event that caused the exception required.
FormatFactory - Class in simple.http.serve
The FormatFactory retrives the Format implementation for the system.
FormatFactory() - Constructor for class simple.http.serve.FormatFactory
 
FreemarkerContainer - Class in simple.template.freemarker
The FreemarkerContainer provides an implementation of the Container object for Freemarker.
FreemarkerContainer() - Constructor for class simple.template.freemarker.FreemarkerContainer
Constructor for the FreemarkerContainer object.
FreemarkerContainer(Context) - Constructor for class simple.template.freemarker.FreemarkerContainer
Constructor for the FreemarkerContainer object.
FreemarkerContainer(Configuration) - Constructor for class simple.template.freemarker.FreemarkerContainer
Constructor for the FreemarkerContainer object.
FreemarkerContainer(Configuration, Context) - Constructor for class simple.template.freemarker.FreemarkerContainer
Constructor for the FreemarkerContainer object.

G

GenericHeader - Interface in simple.http
This is a GenericHeader object that can be used to represent the headers that can be found in a HTTP message header.
get(String) - Method in interface simple.http.Attributes
The get method is used to retrieve the value mapped to the specified name.
get(String) - Method in class simple.http.FilterPipeline
The get method is used to retrieve the value mapped to the specified name.
get(String) - Method in class simple.http.Pipeline
This will retrieve an attribute from this attributes class.
get(String) - Method in interface simple.http.session.Session
This method is used to acquire a session variable that has been previously stored with the put method.
get(String) - Method in interface simple.http.session.Store
This method is used to acquire a session variable that has been previously stored with the put method.
get(Object) - Method in class simple.page.Model
Acquire the attribute referenced by the provided key.
get(String) - Method in interface simple.template.Database
The get method is used to retrieve the value mapped to the specified name.
get(String) - Method in class simple.template.Environment
The get method is used to retrieve the value mapped to the specified name.
get(Object) - Method in class simple.util.parse.MapParser
The get method is used to acquire the value for a named pair.
getAttribute(String) - Method in class simple.http.FilterRequest
This is used as a shortcut for acquiring attributes for the request.
getAttribute(String) - Method in class simple.http.FilterResponse
This is used as a shortcut for acquiring attributes for the response.
getAttribute(String) - Method in interface simple.http.Request
This is used as a shortcut for acquiring attributes for the request.
getAttribute(String) - Method in interface simple.http.Response
This is used as a shortcut for acquiring attributes for the response.
getAttribute(String) - Method in interface simple.util.xml.Node
This method is used to acquire an attribute from the wrapped element object.
getAttributes() - Method in class simple.http.FilterRequest
This can be used to retrieve certain attributes about this Request.
getAttributes() - Method in class simple.http.FilterResponse
This can be used to retrieve certain attributes about this Response.
getAttributes() - Method in interface simple.http.Request
This can be used to retrieve certain attributes about this Request.
getAttributes() - Method in interface simple.http.Response
This can be used to retrieve certain attributes about this Response.
getBasePath() - Method in interface simple.http.serve.Context
This is used to retrieve the base path of the context.
getBasePath() - Method in class simple.http.serve.FileContext
This is used to retrieve the base path of the context.
getBoolean(Object) - Method in interface simple.util.net.Parameters
This extracts a boolean parameter for the named value.
getBoolean(Object) - Method in class simple.util.parse.ParameterParser
This extracts a boolean parameter for the named value.
getBuildFile(String) - Method in class simple.page.Workspace
This acquires a file for the specified build location.
getBuildPath() - Method in class simple.page.Workspace
This provides the root path for the build directory.
getByte(int) - Method in class simple.util.Buffer
This is used to read data from the Buffer.
getByte(int) - Method in interface simple.util.ByteStore
This is basically a simple read method for the bytes in the ByteStore.
getBytes(int, byte[]) - Method in class simple.util.Buffer
This is used to read data from the Buffer.
getBytes(int, byte[], int, int) - Method in class simple.util.Buffer
This is used to read data from the Buffer.
getBytes(int, byte[]) - Method in interface simple.util.ByteStore
This is basically a simple read method for the bytes in the ByteStore.
getBytes(int, byte[], int, int) - Method in interface simple.util.ByteStore
This is basically a simple read method for the bytes in the ByteStore.
getCause() - Method in class simple.http.serve.ErrorReport
This is used to acquire a detailed message describing the cause of the error.
getCause() - Method in interface simple.http.serve.Report
This is used to acquire a detailed message describing the cause of the error.
getCause() - Method in class simple.http.serve.StatusReport
This is used to acquire a detailed message describing the cause of the error.
getCharset() - Method in class simple.page.BasicPage
This retrieves the character encoding that should be used when marshalling the character stream provided by the page to a byte stream.
getCharset() - Method in interface simple.page.Page
This is used to provide the character encoding that will be used when the page is marshalled to a byte stream.
getCharset() - Method in interface simple.template.layout.Viewer
This provides the character encoding of the page.
getCharset() - Method in interface simple.util.net.ContentType
This is used to retrive the charset of this MIME type.
getCharset() - Method in class simple.util.parse.ContentParser
This is used to retrive the charset of this MIME type.
getClass(String) - Method in interface simple.http.load.Mapper
This method is used to acquire the fully qualified class name from the service instance name.
getClass(String) - Method in class simple.http.load.PatternMapper
This method is used to retrieve the fully qualified class name from the service instance name.
getClass(String) - Method in class simple.http.load.PrefixMapper
Used to resolve the class name using a service name.
getClass(String) - Method in class simple.http.load.PrefixResolver
Used to resolve the class name using a service name.
getClassNames() - Method in interface simple.http.load.Layout
This is used to retrieve the fully qualified class names of the resources loaded by the LoaderManager.
getCode() - Method in class simple.http.FilterResponse
This represents the status code of the HTTP response.
getCode() - Method in class simple.http.serve.ErrorReport
Returns the HTTP status code that this report represents.
getCode() - Method in interface simple.http.serve.Report
Returns the HTTP status code that this report represents.
getCode() - Method in class simple.http.serve.StatusReport
Returns the HTTP status code that this report represents.
getCode() - Method in interface simple.http.StatusLine
This represents the status code of the HTTP response.
getConfiguration(String) - Method in interface simple.http.load.Mapper
This method is used retrieve properties for a service by using the service name.
getConfiguration(String) - Method in class simple.http.load.PatternMapper
This method is used retrieve properties for a service by using the service name.
getConfiguration(String) - Method in class simple.http.load.PrefixMapper
This method is used retrieve properties for a service by using the service name.
getConfiguration(String) - Method in class simple.http.load.PrefixResolver
This method is used retrieve properties for a service by using the service name.
getConnection(ResourceEngine) - Static method in class simple.http.connect.ConnectionFactory
Creates the default PipelineHandler object using the PipelineHandlerFactory.getInstance method.
getConnection(ResourceEngine, PipelineFactory) - Static method in class simple.http.connect.ConnectionFactory
Creates the default PipelineHandler object using the PipelineHandlerFactory.getInstance method.
getConnection(ProtocolHandler) - Static method in class simple.http.connect.ConnectionFactory
Creates the default PipelineHandler object using the PipelineHandlerFactory.getInstance method.
getConnection(ProtocolHandler, PipelineFactory) - Static method in class simple.http.connect.ConnectionFactory
Creates the default PipelineHandler object using the PipelineHandlerFactory.getInstance method.
getConnection(PipelineHandler) - Static method in class simple.http.connect.ConnectionFactory
Creates Connection object using the PipelineHandler given.
getConnection(PipelineHandler, PipelineFactory) - Static method in class simple.http.connect.ConnectionFactory
Creates Connection object using the PipelineHandler given.
getContent(Context, String, int) - Method in class simple.http.serve.CacheContentFactory
This method allows a size to be specified for the maximum buffer size.
getContent(Context, String) - Method in class simple.http.serve.CacheContentFactory
This is used to create the Content instances.
getContent(String) - Method in interface simple.http.serve.Context
This enables the contents of some resource to be acquired using a request URI.
getContent(String) - Method in class simple.http.serve.FactoryContext
This creates instances of the Content object using the issued ContentFactory.
getContent(String) - Method in class simple.http.serve.FileContext
This retrieves a Content instance that wraps the specified resource.
getContentLength() - Method in class simple.http.FilterRequest
This is a convenience method that can be used to determine the length of the message body.
getContentLength() - Method in interface simple.http.Request
This is a convenience method that can be used to determine the length of the message body.
getContents(Context, String) - Method in interface simple.http.serve.Format
This is used to produce the contents of the specified resource.
getContentType() - Method in class simple.http.FilterRequest
This is used to acquire the Content-Type for any HTTP message body that may be sent with the request.
getContentType() - Method in interface simple.http.Request
This is used to acquire the Content-Type for any HTTP message body that may be sent with the request.
getContentType() - Method in interface simple.http.serve.Content
The content that is dynamically generated by the object us written as a specific MIME type, including charset information which determines the content encoding.
getContentType(String) - Method in interface simple.http.serve.Context
This method will extract the type attribute of this URI.
getContentType(String) - Method in class simple.http.serve.FileContext
This method will extract the type attribute of this URI.
getContentType() - Method in interface simple.http.serve.Format
The contents generated by this object may not be in HTML format, this is used to retrive the content type.
getContentType() - Method in interface simple.http.serve.Index
This allows the MIME type of this Index to be acquired.
getContentType() - Method in class simple.page.BasicPage
This provides the MIME content type and character encoding of for the page implementation.
getContentType() - Method in interface simple.page.Page
This is used to provide a MIME content type, which can be used by the HTTP service to the the Content-Type header.
getContentType() - Method in interface simple.template.Document
The content that is dynamically generated by the object is written as a specific MIME type, including charset information which determines the content encoding.
getContentType() - Method in interface simple.template.layout.Viewer
This is used to acquire a HTTP Content-Type header, which can be used to describe the contents of the viewer.
getCookie(String) - Method in class simple.http.FilterRequest
This method can be used to retrieve cookies from the header.
getCookie(String) - Method in interface simple.http.Request
This method can be used to retrieve cookies from the header.
getCookie(String) - Method in interface simple.http.State
This returns the Cookie object stored under the specified name.
getCookies() - Method in interface simple.http.State
The getCookies method returns all cookies that exist within the state.
getCountry() - Method in interface simple.util.net.Path
This will return the country that this path has taken from the locale of the path.
getCountry() - Method in class simple.util.parse.PathParser
This will return the country that this path has taken from the locale of the path.
getDate(int) - Method in class simple.http.FilterRequest
This can be used to get the value of the HTTP message header at the specified index.
getDate(String) - Method in class simple.http.FilterRequest
This can be used to get the date of the first message header that has the specified name.
getDate(int) - Method in class simple.http.FilterResponse
This can be used to get the value of the HTTP message header at the specified index.
getDate(String) - Method in class simple.http.FilterResponse
This can be used to get the date of the first message header that has the specified name.
getDate(int) - Method in interface simple.http.GenericHeader
This can be used to get the value of the HTTP message header at the specified index.
getDate(String) - Method in interface simple.http.GenericHeader
This can be used to get the date of the first message header that has the specified name.
getDate() - Static method in class simple.util.parse.DateParser
The parser contains this method so that the a date does not have to be parsed from System.currentTimeMillis.
getDirectory(String) - Method in interface simple.http.serve.Context
This is used to translate the HTTP request URI into the File object that it represent the parent directory of the URI.
getDirectory(String) - Method in class simple.http.serve.FileContext
This is used to translate the HTTP request URI into the File object that it represent the parent directory of the URI.
getDirectory() - Method in interface simple.http.serve.Index
This is used to acquire the File directory for the index target.
getDirectory() - Method in interface simple.page.translate.Source
This acquires the directory the source object is generated into.
getDirectory(String) - Method in class simple.page.Workspace
This will acquire the directory as acquired from the JSP source context.
getDirectory() - Method in interface simple.util.net.Path
This will return the highest directory that exists within the path.
getDirectory() - Method in class simple.util.parse.PathParser
This will return the highest directory that exists within the path.
getDomain() - Method in class simple.util.net.Cookie
This returns the domain for this cookie.
getDomain() - Method in interface simple.util.net.URI
This is used to retrive the domain of this URI.
getDomain() - Method in class simple.util.parse.URIParser
This is used to retrive the domain of this URI.
getElement() - Method in interface simple.util.xml.Node
This method is used to provide the source element that this object wraps.
getExpiry() - Method in interface simple.util.lease.Lease
Determines the duration remaining before the lease expires.
getExpiry() - Method in class simple.util.net.Cookie
This returns the number of seconds a cookie lives for.
getExtension() - Method in interface simple.util.net.Path
This will return the extension that the file name contains.
getExtension() - Method in class simple.util.parse.PathParser
This will return the extension that the file name contains.
getFile(String) - Method in interface simple.http.serve.Context
This is used to translate the HTTP request URI into the File object that it represents.
getFile(String) - Method in class simple.http.serve.FileContext
This is used to translate the HTTP request URI into the File object that it represents.
getFile(String) - Method in class simple.http.serve.FileLocator
This is used to produce a File object pointing to the location of the named resource.
getFile() - Method in interface simple.http.serve.Index
This is used to acquire the File reference for the index target.
getFile(String) - Method in interface simple.http.serve.Locator
This is used to produce a File object pointing to the location of the named resource.
getFloat(Object) - Method in interface simple.util.net.Parameters
This extracts a float parameter for the named value.
getFloat(Object) - Method in class simple.util.parse.ParameterParser
This extracts a float parameter for the named value.
getFormat() - Method in interface simple.http.serve.Context
Each Context object must be coupled with an instance of the Format object.
getFormat() - Method in class simple.http.serve.FileContext
Each Context object must be coupled with an instance of the Format object.
getIndex(String) - Method in interface simple.http.serve.Context
This is an all in one method that allows all the information on the target URI to be gathered at once.
getIndex(String) - Method in class simple.http.serve.ExtendedContext
This method is used to acquire an Index for the URI path provided.
getIndex(String) - Method in class simple.http.serve.FileContext
This is an all in one method that allows all the information on the target URI to be gathered at once.
getInetAddress() - Method in class simple.http.FilterPipeline
This corresponds to the identity of the host that created the connection.
getInetAddress() - Method in class simple.http.FilterRequest
Used to get the address from which this Request came from.
getInetAddress() - Method in class simple.http.FilterResponse
This can be used to get the I.P address for the browser that the Response goes to.
getInetAddress() - Method in class simple.http.Pipeline
This corresponds to the identity of the host that created the connection.
getInetAddress() - Method in interface simple.http.Request
Used to get the address from where this Request came from.
getInetAddress() - Method in interface simple.http.Response
This can be used to get the I.P address for the browser that the Response goes to.
getInputStream() - Method in class simple.http.FilterPipeline
Retrieves the InputStream.
getInputStream() - Method in class simple.http.FilterRequest
This is used to read the content body.
getInputStream() - Method in class simple.http.Pipeline
Retrieves the InputStream.
getInputStream() - Method in interface simple.http.Request
This is used to read the content body.
getInputStream() - Method in class simple.util.Buffer
This method is used so that the Buffer can be represented as an input stream.
getInstance(Socket) - Method in class simple.http.BufferedPipelineFactory
This will produce a Pipeline with the buffering output stream.
getInstance() - Static method in class simple.http.connect.ConfiguratorFactory
This produces the system wide Configurator to provide a uniform configuration for the server.
getInstance(Context) - Static method in class simple.http.load.MapperFactory
This is used to produce the system wide Mapper implementation so that the MapperEngine objects can remain consistant.
getInstance(Socket) - Method in interface simple.http.PipelineFactory
This will produce a Pipeline with the desired functionality once the implementation wraps the given Socket.
getInstance(ProtocolHandler) - Static method in class simple.http.PipelineHandlerFactory
This will create an instance of a PipelineHandler object for processing Pipeline objects using an instance of the ProtocolHandler.
getInstance(ProtocolHandler, int, int) - Static method in class simple.http.PipelineHandlerFactory
This will create an instance of a PipelineHandler object for processing Pipeline objects using an instance of the ProtocolHandler.
getInstance(Context, String) - Method in class simple.http.serve.CacheContentFactory
This implementation of the getInstance method will cache the created Content object.
getInstance(Context, String) - Method in interface simple.http.serve.ContentFactory
This will return a Content instance for the request URI issued.
getInstance() - Static method in class simple.http.serve.FormatFactory
This is used to produce the system wide Format implementation so that the FileEngine objects can remain consistant.
getInstance(ResourceEngine) - Static method in class simple.http.serve.ProtocolHandlerFactory
This will produce a ProtocolHandler that uses the ResourceEngine to retrieve delegate handlers for processing HTTP transactions.
getInstance(ViewerFactory, Context) - Static method in class simple.template.layout.LayoutFactory
This is used to produce the system wide Layout implementation so that a layout can be imposed on templates.
getInstance(PanelFactory, Context) - Static method in class simple.template.layout.LayoutFactory
This is used to produce the system wide Layout implementation so that a layout can be imposed on templates.
getInstance(String, Object, boolean) - Method in interface simple.template.layout.ViewerFactory
Creates a new Viewer object, which wraps the referenced template.
getInstance() - Static method in class simple.util.process.ProcessQueue
This allows the ProcessQueue to become a system static object.
getInteger(Object) - Method in interface simple.util.net.Parameters
This extracts an integer parameter for the named value.
getInteger(Object) - Method in class simple.util.parse.ParameterParser
This extracts an integer parameter for the named value.
getLanguage() - Method in class simple.http.FilterRequest
This provides Locale for the Accept-Language value.
getLanguage() - Method in interface simple.http.Request
This provides Locale for the Accept-Language value.
getLanguage() - Method in interface simple.page.translate.Source
The language property is used to specify the type of source that is to be generated and the compiler required to process that source.
getLanguage() - Method in interface simple.util.net.Path
This will return the language that this path has taken from the locale of the path.
getLanguage() - Method in class simple.util.parse.PathParser
This will return the language that this path has taken from the locale of the path.
getLocale(String) - Method in interface simple.http.serve.Context
This will parse the HTTP request URI specified and return the Locale for that resource.
getLocale(String) - Method in class simple.http.serve.FileContext
This will parse the HTTP request URI specified and return the Locale for that resource.
getLocale() - Method in interface simple.http.serve.Index
This gets the locale for this index object the locale is set to the Locale.getDefault if there is no locale information available for the index target.
getLocale() - Method in class simple.util.parse.LanguageParser
This will return the preferred Locale for this header.
getLocales() - Method in class simple.util.parse.LanguageParser
This will order the tokens based on the preference of the language.
getLocation(String) - Method in class simple.http.serve.FileLocator
This is used to discover the location of a resource using the name of the resource.
getLocation(String) - Method in interface simple.http.serve.Locator
This is used to discover the location of a resource using the name of the resource.
getLocator() - Method in interface simple.http.serve.Context
Each Context must supply a Locator to enable the system to locate configuration information and other resources that reside outside the context path.
getLocator() - Method in class simple.http.serve.FileContext
Each Context must supply a Locator to enable the system to locate configuration information and other resources that reside outside the context path.
getMajor() - Method in class simple.http.FilterRequest
This can be used to get the major number from a HTTP version.
getMajor() - Method in class simple.http.FilterResponse
This can be used to get the major number from a HTTP version.
getMajor() - Method in interface simple.http.RequestLine
This can be used to get the major number from a HTTP version.
getMajor() - Method in interface simple.http.StatusLine
This can be used to get the major number from a HTTP version.
getMatch() - Method in interface simple.util.Match
This is match that the getPattern result resolves for.
getMatch(int) - Method in class simple.util.Resolver
This will return the corrosponding Match at the specified position.
getMatch(String) - Method in class simple.util.Resolver
This will return the corrosponding Match at the specified position.
getMatches() - Method in interface simple.http.load.Layout
This is used to retrieve the links that have been made with the LoaderManager.
getMatches() - Method in class simple.util.Resolver
Retrives an array of Match's of each pair that was entered into this Resolver.
getMessage(Context, String, Report) - Method in interface simple.http.serve.Format
The HTTP protocol defines certain status codes that are to be sent with descriptive message bodys, this method is used to create the message body for that status code.
getMethod() - Method in class simple.http.FilterRequest
This can be used to get the HTTP method for this request.
getMethod() - Method in interface simple.http.RequestLine
This can be used to get the HTTP method for this request.
getMinor() - Method in class simple.http.FilterRequest
This can be used to get the major number from a HTTP version.
getMinor() - Method in class simple.http.FilterResponse
This can be used to get the minor number from a HTTP version.
getMinor() - Method in interface simple.http.RequestLine
This can be used to get the major number from a HTTP version.
getMinor() - Method in interface simple.http.StatusLine
This can be used to get the minor number from a HTTP version.
getName(int) - Method in class simple.http.FilterRequest
This is used to get the name value of the HTTP message header at the specified index.
getName(int) - Method in class simple.http.FilterResponse
This is used to get the name value of the HTTP message header at the specified index.
getName(int) - Method in interface simple.http.GenericHeader
This is used to get the name value of the HTTP message header at the specified index.
getName(String) - Method in interface simple.http.load.Mapper
This method is used to transform a path to a service name.
getName(String) - Method in class simple.http.load.PatternMapper
 
getName(String) - Method in class simple.http.load.PrefixMapper
This will resolve the service instance name given a URI path.
getName(String) - Method in class simple.http.load.PrefixResolver
Used to resolve the service name using a path prefix.
getName(String) - Method in interface simple.http.serve.Context
This will parse and return the file name that this request URI references.
getName(String) - Method in class simple.http.serve.FileContext
This will parse and return the file name that this request URI references.
getName() - Method in interface simple.http.serve.Index
This allows the name for this object to be acquired.
getName() - Method in interface simple.page.translate.Source
The provides the name of the resulting object.
getName() - Method in class simple.page.Workspace
This provides the name of this JSP project workspace.
getName() - Method in interface simple.template.layout.Tile
This provides the name of the tile which is the same name as the Source it wraps.
getName() - Method in class simple.util.net.Cookie
This returns the name for this cookie.
getName() - Method in interface simple.util.net.Path
This will return the full name of the file without the path.
getName() - Method in interface simple.util.net.Principal
The getName method is used to retreive the name of the principal.
getName() - Method in class simple.util.parse.PathParser
This will return the full name of the file without the path.
getName() - Method in class simple.util.parse.PrincipalParser
Gets the users name from the Authorization header value.
getName() - Method in interface simple.util.xml.Node
This method is used to acquire the name of the element that this Node instance wraps.
getNames() - Method in interface simple.http.load.Layout
This is used to retrieve the unique names of resource instances loaded by the LoaderManager.
getOutputStream() - Method in class simple.http.FilterPipeline
Retrieves the OutputStream.
getOutputStream() - Method in class simple.http.FilterResponse
Used to write a message body with the Response.
getOutputStream(int) - Method in class simple.http.FilterResponse
Used to write a message body with the Response.
getOutputStream() - Method in class simple.http.Pipeline
Retrieves the OutputStream.
getOutputStream() - Method in interface simple.http.Response
Used to write a message body with the Response.
getOutputStream(int) - Method in interface simple.http.Response
Used to write a message body with the Response.
getPackage() - Method in interface simple.page.translate.Source
This is used by the source code generator to determine the package the target object is using.
getPanel(String, Object, boolean) - Method in interface simple.template.layout.Layout
This method will retreive a Panel object that implements the layout for the specified target.
getPanel(String, Object, boolean) - Method in class simple.template.layout.PlainLayout
This method basically acts as an adapter method to the provided PanelFactory.
getPanel(String, Object, boolean) - Method in class simple.template.layout.TileLayout
This method will retrieve a Panel object to represent the specified target.
getParameter(String) - Method in class simple.http.FilterRequest
This is used to provide quick access to the parameters.
getParameter(String) - Method in interface simple.http.Request
This is used to provide quick access to the parameters.
getParameter(Object) - Method in interface simple.util.net.Parameters
This extracts a value for the given name.
getParameter(String) - Method in interface simple.util.net.URI
This will return the value of the parameter with the given name.
getParameter(Object) - Method in class simple.util.parse.ParameterParser
This extracts a value for the given name.
getParameter(String) - Method in class simple.util.parse.URIParser
This will return the value of the parameter with the given name.
getParameterNames() - Method in interface simple.util.net.Parameters
This enumerates the names of every parameter.
getParameterNames() - Method in interface simple.util.net.URI
This extracts the parameter names from the uniform resource identifier represented by this object.
getParameterNames() - Method in class simple.util.parse.ParameterParser
This enumerates the names of every parameter.
getParameterNames() - Method in class simple.util.parse.URIParser
This extracts the parameter names from the uniform resource identifier represented by this object.
getParameters() - Method in class simple.http.FilterRequest
This provides access to HTML form and query parameters.
getParameters() - Method in interface simple.http.Request
This provides access to HTML form and query parameters.
getPassword() - Method in interface simple.util.net.Principal
The getPassword method is used to retreive the password of the principal.
getPassword() - Method in class simple.util.parse.PrincipalParser
Gets the users password parsed from the Authorization header value.
getPath() - Method in class simple.http.FilterRequest
This method is used to acquire the normalized path part of the HTTP request URI.
getPath(String) - Method in interface simple.http.load.Mapper
This method is used to determine the normalized path of the issued URI path.
getPath(String) - Method in class simple.http.load.PatternMapper
This method is used to acquire a path given the unmodified URI path.
getPath(String) - Method in class simple.http.load.PrefixMapper
This method is used to acquire a path relative to the prefix path.
getPath(String) - Method in class simple.http.load.PrefixResolver
Used to acquire the path relative to the prefix.
getPath() - Method in interface simple.http.Request
This method is used to acquire the normalized path part of the HTTP request URI.
getPath(String) - Method in interface simple.http.serve.Context
This is used to translate the HTTP request URI into the Path object that it represents.
getPath(String) - Method in class simple.http.serve.FileContext
This is used to translate the HTTP request URI into the Path object that it represents.
getPath() - Method in interface simple.http.serve.Index
This is used to acquire the Path object that exposes various parts of the URI path.
getPath() - Method in class simple.util.net.Cookie
This returns the path for this cookie.
getPath() - Method in interface simple.util.net.Path
This will return the normalized path.
getPath() - Method in interface simple.util.net.URI
This is used to retrive the path of this URI.
getPath() - Method in class simple.util.parse.PathParser
This will return the normalized path.
getPath() - Method in class simple.util.parse.URIParser
This is used to retrive the path of this URI.
getPattern() - Method in interface simple.util.Match
This is the pattern that this match was stored under in the Resolver.
getPort() - Method in interface simple.util.net.URI
This is used to retrive the port of the uniform resource identifier.
getPort() - Method in class simple.util.parse.URIParser
This is used to retrive the port of the uniform resource identifier.
getPrefix(String) - Method in class simple.http.load.PrefixMapper
This will determine the prefix path that matches the given URI path.
getPrefix(String) - Method in class simple.http.load.PrefixResolver
Used to get the prefix path for the given relative URI path, which must be normalized.
getPrimary() - Method in interface simple.util.net.ContentType
This is used to retrive the type of this MIME type.
getPrimary() - Method in class simple.util.parse.ContentParser
This is used to retrive the type of this MIME type.
getPrincipal() - Method in class simple.http.FilterRequest
This is a convenience method that is used to retrieve the client authorized to this server.
getPrincipal() - Method in interface simple.http.Request
This is a convenience method that is used to retrieve the client authorized to this server.
getPrintStream() - Method in class simple.http.FilterResponse
This method is provided for convenience so that the HTTP content can be written using the print methods provided by the PrintStream.
getPrintStream(int) - Method in class simple.http.FilterResponse
This method is provided for convenience so that the HTTP content can be written using the print methods provided by the PrintStream.
getPrintStream() - Method in interface simple.http.Response
This method is provided for convenience so that the HTTP content can be written using the print methods provided by the PrintStream.
getPrintStream(int) - Method in interface simple.http.Response
This method is provided for convenience so that the HTTP content can be written using the print methods provided by the PrintStream.
getProperties(String) - Method in interface simple.http.serve.Context
This provides a convenient way for a Java properties file to be loaded.
getProperties(String) - Method in class simple.http.serve.FileContext
This provides a convenient way for an XML configuration file to be loaded.
getProperties(String) - Method in class simple.http.serve.FileLocator
This is used to produce a Properties object that contains the contents of the named Java properties file.
getProperties(String) - Method in interface simple.http.serve.Locator
This is used to produce a Properties object that contains the contents of the named Java properties file.
getProperty(String) - Method in interface simple.util.xml.Node
This method is used to acquire a transformed value for the named attribute.
getProperty() - Method in interface simple.util.xml.Node
This is used to acquire the transformed value of a text element.
getQuery() - Method in interface simple.util.net.URI
This is used to retrive the query of this URI.
getQuery() - Method in class simple.util.parse.URIParser
This is used to retrive the query of this URI.
getRealPath(String) - Method in interface simple.http.serve.Context
This is used to translate the HTTP request URI into the OS specific path that it represents.
getRealPath(String) - Method in class simple.http.serve.FileContext
This is used to translate the HTTP request URI into the OS specific path that it represents.
getRealPath() - Method in interface simple.http.serve.Index
This is used to get the path that this object refers to.
getReference() - Method in interface simple.page.translate.Source
This provides a key component for the JSP engine, which is used to determine when a JSP page or its includes have expired.
getRelative(String) - Method in interface simple.util.net.Path
This will return the path as it is relative to the issued path.
getRelative(String) - Method in class simple.util.parse.PathParser
This will return the path as it is relative to the issued path.
getRequestPath(String) - Method in interface simple.http.serve.Context
This is used to translate the HTTP request URI into the URI path normalized and without query or parameter parts.
getRequestPath(String) - Method in class simple.http.serve.FileContext
This is used to translate the HTTP request URI into the URI path normalized and without query or parameter parts.
getRequestPath() - Method in interface simple.http.serve.Index
This is used to acquire the normalized URI style path for the index target.
getResource(String) - Method in class simple.http.serve.FileLocator
This is provided so that a ClassLoader can be used to load the named resource.
getResource(String) - Method in interface simple.http.serve.Locator
This is provided so that a ClassLoader can be used to load the named resource.
getScheme() - Method in interface simple.util.net.URI
This allows the scheme of the URL given to be returned.
getScheme() - Method in class simple.util.parse.URIParser
This allows the scheme of the URL given to be returned.
getSecondary() - Method in interface simple.util.net.ContentType
This is used to retrive the subtype of this MIME type.
getSecondary() - Method in class simple.util.parse.ContentParser
This is used to retrive the subtype of this MIME type.
getSection(String) - Method in class simple.http.load.Configuration
This is used to acquire the properties for a named section.
getSecure() - Method in class simple.util.net.Cookie
This determines whether the cookie is secure.
getSegments() - Method in interface simple.util.net.Path
This method is used to break the path into individual parts called segments, see RFC 2396.
getSegments() - Method in class simple.util.parse.PathParser
This method is used to break the path into individual parts called segments, see RFC 2396.
getSession() - Method in class simple.http.FilterRequest
This method is used to acquire a Session for the request.
getSession() - Method in interface simple.http.Request
This method is used to acquire a Session for the request.
getSession(State) - Static method in class simple.http.session.Manager
This will either retrieve an active session or create a new one.
getSession(State, Object) - Static method in class simple.http.session.Manager
This will either retrieve an active session or create a new one.
getSetCookies() - Method in interface simple.http.State
The getSetCookies method is used to retrieve the cookies that have been added to the state.
getSource() - Method in interface simple.page.translate.Source
Provides the OS file system reference for the source file.
getSourceFile(String) - Method in class simple.page.Workspace
This acquires a file for the specified JSP source.
getState() - Method in class simple.http.FilterRequest
The State represents the collection of cookies sent with this HTTP request.
getState() - Method in interface simple.http.Request
The State represents the collection of cookies sent with this HTTP request.
getTarget() - Method in interface simple.page.translate.Source
Provides the fully qualified package name for the resulting object.
getText() - Method in class simple.http.FilterResponse
This can be used to retrieve the text of a HTTP status line.
getText() - Method in class simple.http.serve.ErrorReport
Returns a short description of what caused this report.
getText() - Method in interface simple.http.serve.Report
Returns a short description of what caused this report.
getText() - Method in class simple.http.serve.StatusReport
Returns a short description of what caused this report.
getText() - Method in interface simple.http.StatusLine
This can be used to retrive the text of a HTTP status line.
getText() - Method in interface simple.util.xml.Node
This is used to acquire the string value for the element text.
getURI() - Method in class simple.http.FilterRequest
This can be used to get the URI specified for this HTTP request.
getURI() - Method in interface simple.http.RequestLine
This can be used to get the URI specified for this HTTP request.
getValue(int) - Method in class simple.http.FilterRequest
This is used to get the date value of the HTTP message header at the specified index.
getValue(String) - Method in class simple.http.FilterRequest
This can be used to get the value of the first message header that has the specified name.
getValue(int) - Method in class simple.http.FilterResponse
This is used to get the date value of the HTTP message header at the specified index.
getValue(String) - Method in class simple.http.FilterResponse
This can be used to get the value of the first message header that has the specified name.
getValue(int) - Method in interface simple.http.GenericHeader
This is used to get the text value of the HTTP message header at the specified index.
getValue(String) - Method in interface simple.http.GenericHeader
This can be used to get the value of the first message header that has the specified name.
getValue(String) - Method in interface simple.http.State
This is used to retreive the value of the Cookie stored under the specified name.
getValue() - Method in interface simple.template.layout.Tile
This method causes the Source.getValue method to be invoked.
getValue() - Method in class simple.util.net.Cookie
This returns the value for this cookie.
getValue() - Method in class simple.util.parse.PropertyBuffer
This method is used to parse the value of the buffered text and return the corrosponding string.
getValues(String) - Method in class simple.http.FilterRequest
This can be used to get the values of HTTP message headers that have the specified name.
getValues(String) - Method in class simple.http.FilterResponse
This can be used to get the values of HTTP message headers that have the specified name.
getValues(String) - Method in interface simple.http.GenericHeader
This can be used to get the values of HTTP message headers that have the specified name.
getVersion() - Method in class simple.util.net.Cookie
This returns the version for this cookie.

H

half - Variable in class simple.util.schedule.PulseScheduler
This is just a simple operation saving variable.
handle(Request, Response) - Method in class simple.http.load.Process
This enables the Resource to be handled in a separate thread of execution.
handle(Request, Response) - Method in interface simple.http.ProtocolHandler
Used to pass the Request and Response to the ProtocolHandler for processing.
handle(Request, Response) - Method in class simple.http.serve.Component
This handle is provided so that if any errors occur when processing a HTTP transaction a '500 Server Error' message will be sent to the client.
handle(Request, Response, int) - Method in class simple.http.serve.Component
This is used to generate the status report from a status code.
handle(Request, Response, Report) - Method in class simple.http.serve.Component
This is used to generate a formatted message using a report to describe the change in status.
handle(Request, Response) - Method in class simple.http.serve.DomainHandler
This is used to route the request to the correct handler.
handle(Request, Response) - Method in interface simple.http.serve.Resource
This acts as the main processing method for the resources.
handle(Request, Response, int) - Method in interface simple.http.serve.Resource
When an error occurs while processing the HTTP request then this method will handle the error according to the suggested code.
handle(Request, Response, Report) - Method in interface simple.http.serve.Resource
This is used to generate a formatted message using a report to describe the change in status.
hasMore() - Method in interface simple.util.net.CookieCollection
This is used to determine wheather or not there are any more Cookies left in the collection.
hasMore() - Method in class simple.util.parse.CookieParser
Determine wheather or not there are any Cookies left in the String.
headerCount() - Method in class simple.http.FilterRequest
This can be used to determine how many HTTP message headers this object contains.
headerCount() - Method in class simple.http.FilterResponse
This can be used to determine how many HTTP message headers this object contains.
headerCount() - Method in interface simple.http.GenericHeader
This can be used to determine how many HTTP message headers this object contains.

I

Index - Interface in simple.http.serve
The Index object is used to represent the properties a URI can contain.
indexer - Variable in class simple.http.serve.FileContext
This is used to extract any user specified MIME types.
indexOf(String) - Method in class simple.http.FilterRequest
This can be used to find the first occurrence of the specified HTTP message header.
indexOf(String, int) - Method in class simple.http.FilterRequest
This can be used to find the first occurrence of the specified HTTP message header from a given index.
indexOf(String) - Method in class simple.http.FilterResponse
This can be used to find the first occurrence of the specified HTTP message header.
indexOf(String, int) - Method in class simple.http.FilterResponse
This can be used to find the first occurrence of the specified HTTP message header from a given index.
indexOf(String) - Method in interface simple.http.GenericHeader
This can be used to find the first occurrence of the specified HTTP message header.
indexOf(String, int) - Method in interface simple.http.GenericHeader
This can be used to find the first occurrence of the specified HTTP message header from a given index.
indexOf(String) - Method in class simple.util.Resolver
Used to find the position of the Match stored using the specified pattern.
indexOf(String, int) - Method in class simple.util.Resolver
Used to find the position of the Match stored using the specified pattern.
init(Context) - Method in class simple.template.freemarker.FreemarkerContainer
In the event that the Configuration instance is uninitialized this attempts to set the root path for loading of templates to the root context path.
init(String) - Method in class simple.template.freemarker.FreemarkerContainer
In the event that the Configuration instance is uninitialized this attempts to set the root path for loading of templates to the specified path.
init(Context) - Method in class simple.template.velocity.VelocityContainer
In the event that the VelocityEngine instance is uninitialized this attempts to load a Java properties file to provide configuration information.
init(Locator) - Method in class simple.template.velocity.VelocityContainer
In the event that the VelocityEngine instance is uninitialized this attempts to load a Java properties file to provide configuration information.
init() - Method in class simple.util.parse.ContentParser
This will initialize the parser when it is ready to parse a new String.
init() - Method in class simple.util.parse.CookieParser
Resets the cookie and the buffer variables for this CookieParser.
init() - Method in class simple.util.parse.DateParser
This is used to reset the date and the buffer variables for this DateParser.
init() - Method in class simple.util.parse.LanguageParser
This will initialize the parser when it is ready to parse a new String.
init() - Method in class simple.util.parse.ListParser
Initializes the parser so that tokens can be extracted from the list.
init() - Method in class simple.util.parse.ParameterParser
This initializes the parser so that it can be used several times.
init() - Method in class simple.util.parse.Parser
This will initialize the Parser when it is ready to parse a new String.
init() - Method in class simple.util.parse.PathParser
This will initialize the parser so that it is in a ready state.
init() - Method in class simple.util.parse.PrincipalParser
This will initialize the Parser when it is ready to parse a new String.
init() - Method in class simple.util.parse.URIParser
This will empty each tokens cache.
insert(ProtocolHandler, String) - Method in class simple.http.serve.DomainHandler
This will insert a new ProtocolHandler for the specified pattern.
insert(int, int) - Method in class simple.util.Buffer
This method is used to insert bytes into the Buffer at the specified position.
insert(int, byte[]) - Method in class simple.util.Buffer
This method is used to insert bytes into the Buffer at the specified position.
insert(int, byte[], int, int) - Method in class simple.util.Buffer
This method is used to insert bytes into the Buffer at the specified position.
insert(int, Buffer) - Method in class simple.util.Buffer
This method is used to insert bytes into the Buffer at the specified position.
insert(int, Buffer, int, int) - Method in class simple.util.Buffer
This method is used to insert bytes into the Buffer at the specified position.
insert(Object, Object) - Method in class simple.util.cache.CacheList
This uses a doubly linked list to store the object within this list.
insert(String, String) - Method in class simple.util.Resolver
This will add a new pattern with its resolution.
insert(String, String, int) - Method in class simple.util.Resolver
This will add a new pattern with its resolution.
interrupt(Scheduler.Entry) - Method in class simple.util.schedule.Scheduler
This method is important for enqueuing items as it tells the Registry what the timeout of an incomming item is.
Introspector - Class in simple.util
The Introspector provides a means to invoke methods of arbitrary objects by matching a parameter list and name.
Introspector(Class) - Constructor for class simple.util.Introspector
Constructor for the Introspector class.
invoke(String, Object, Object) - Method in class simple.util.Introspector
Performs a reflective invocation on a target object by means of discovering a method compatible with the arguments.
invoke(String, Object, Object[]) - Method in class simple.util.Introspector
Performs a reflective invocation on a target object by means of discovering a method compatible with the arguments.
isCommitted() - Method in class simple.http.FilterResponse
This can be used to determine whether the Response has been committed.
isCommitted() - Method in interface simple.http.Response
This can be used to determine whether the Response has been committed.
isElement() - Method in interface simple.util.xml.Node
This method is used to determine the type of node this object represents.
isEmpty() - Method in interface simple.http.session.Session
This is a convenience method that can be used to determine whether there are any variables within the session.
isEmpty() - Method in interface simple.http.State
Checks to see if the State is empty.
isEmpty() - Method in class simple.util.parse.MapParser
Thsi method is used to determine whether the parser has any tokens available.
isEmpty() - Method in class simple.util.Resolver
This can be used to determine wheather or not there is any entrys in the Resolver.
isKeepAlive() - Method in class simple.http.FilterRequest
This is a convenience method that is used to determine whether or not this message has the Connection: close header.
isKeepAlive() - Method in interface simple.http.Request
This is a convenience method that is used to determine whether or not this message has the Connection: close header.
isModified() - Method in interface simple.page.translate.Reference
This checks if the source or its includes have expired.
isName(String) - Method in interface simple.util.xml.Node
This is used to check for the name of the element that this node object wraps.

K

keySet() - Method in interface simple.http.Attributes
To ascertain what mappings exist, the names of all values previously put into this attributes can be retrieved with this method.
keySet() - Method in class simple.http.FilterPipeline
To ascertain what mappings exist, the names of all values previously put into this attributes can be retrieved with this method.
keySet() - Method in class simple.http.Pipeline
This will provide an Set object for attribute names for this pipeline object.
keySet() - Method in interface simple.http.session.Session
To ascertain what mappings exist, the names of all values previously put into a session can be retrieved with this method.
keySet() - Method in interface simple.http.session.Store
To ascertain what mappings exist, the names of all values previously put into this store can be retrieved with this method.
keySet() - Method in interface simple.template.Database
To ascertain what mappings exist, the names of all values previously put into thhis database can be retrieved with this method.
keySet() - Method in class simple.template.Environment
To ascertain what mappings exist, the names of all values previously put into thhis database can be retrieved with this method.
keySet() - Method in class simple.util.parse.MapParser
This is used to acquire the names for all the tokens that have currently been collected by this parser.

L

LanguageParser - Class in simple.util.parse
LanguageParser is used to parse the HTTP Accept-Language header.
LanguageParser() - Constructor for class simple.util.parse.LanguageParser
Used to create a language parser for the Accept-Language HTTP header value.
LanguageParser(String) - Constructor for class simple.util.parse.LanguageParser
This is used to create a language parser for the Accept-Language HTTP header value.
Layout - Interface in simple.http.load
The Layout represents the layout of the links and resources within a specific LoaderManager.
Layout - Interface in simple.template.layout
The Layout object is used to perform a layout given a specific target path.
LayoutFactory - Class in simple.template.layout
The LayoutFactory retrieves a Layout implementation for the system.
LayoutFactory() - Constructor for class simple.template.layout.LayoutFactory
 
Lease - Interface in simple.util.lease
The Lease object is used to keep a named resource active.
lease(String, long) - Method in class simple.util.lease.LeaseManager
This method will issue a Lease object that can be used to manage the release of a named resource.
LeaseException - Exception in simple.util.lease
The LeaseException is used to indicate that some operation failed when attempting to use a Lease.
LeaseException() - Constructor for exception simple.util.lease.LeaseException
This empty constructor is used if there is no explanation of the leasing exception required.
LeaseException(String) - Constructor for exception simple.util.lease.LeaseException
This constructor is used if there is a description of the event that caused the exception required.
LeaseManager - Class in simple.util.lease
The LeaseManager is used to issue a lease for a named resource.
LeaseManager(Cleaner) - Constructor for class simple.util.lease.LeaseManager
Constructor for the LeaseManager object.
length() - Method in class simple.util.BlockingQueue
This returns the number of objects that are actually enqueued into the BlockingQueue.
length() - Method in class simple.util.Buffer
This returns the number of bytes that have been appended to this Buffer object.
length() - Method in interface simple.util.ByteStore
This returns the number of bytes that this ByteStore object contains.
length() - Method in class simple.util.cache.CacheList
This will simply return the number of items in the list.
length() - Method in class simple.util.parse.ParseBuffer
This will return the number of bytes that have been appended to the ParseBuffer.
length() - Method in class simple.util.PriorityQueue
The number of elements in the queue.
link(String, String) - Method in class simple.http.load.LoaderEngine
This is used to link a Service to a wild card pattern.
link(String, String, int) - Method in class simple.http.load.LoaderEngine
This is used to link a Service to a wild card pattern.
link(String, String) - Method in interface simple.http.load.LoaderManager
This is used to link a Service to a wild card pattern.
link(String, String, int) - Method in interface simple.http.load.LoaderManager
This is used to link a Service to a wild card pattern.
list() - Method in class simple.util.parse.ListParser
This will build an ordered list of values extracted from the comma seperated header value.
ListParser - Class in simple.util.parse
The ListParser is used to extract a comma seperated list of HTTP header values.
ListParser() - Constructor for class simple.util.parse.ListParser
Constructor for the ListParser.
ListParser(String) - Constructor for class simple.util.parse.ListParser
Constructor for the ListParser.
ListParser(String[]) - Constructor for class simple.util.parse.ListParser
Constructor for the ListParser.
load(String, String) - Method in class simple.http.load.LoaderEngine
This loads the class into the system.
load(String, String, Object) - Method in class simple.http.load.LoaderEngine
This loads the class into the system.
load(String, String, Object[]) - Method in class simple.http.load.LoaderEngine
This loads the class into the system.
load(String, String) - Method in interface simple.http.load.LoaderManager
This loads the class into the system.
load(String, String, Object) - Method in interface simple.http.load.LoaderManager
This loads the class into the system.
load(String, String, Object[]) - Method in interface simple.http.load.LoaderManager
This loads the class into the system.
load(Source) - Method in class simple.page.compile.Compiler
This is used to load the compiled class from the project build directory.
load(InputStream) - Method in class simple.util.FileProperties
This overloads the Properties.load so that XML properties can be loaded as well as standard properties.
load(InputStream) - Method in class simple.util.URLProperties
This overloads the Properties.load so that XML properties can be loaded as well as standard properties.
Loader - Interface in simple.http.load
The Loader object represents an object that uses the LoaderManager to load and link resources.
loader - Variable in class simple.page.compile.Compiler
This is used to load the class files from the workspace.
LoaderEngine - Class in simple.http.load
The LoaderEngine is used to load Service implementations into the system so that they can be executed by a ProtocolHandler.
LoaderEngine() - Constructor for class simple.http.load.LoaderEngine
Constructor for the LoaderEngine that uses the class loader of the current instance to load the services.
LoaderEngine(Context) - Constructor for class simple.http.load.LoaderEngine
Constructor for the LoaderEngine that uses the class loader of the current instance to load the services.
LoaderEngine(Context, File) - Constructor for class simple.http.load.LoaderEngine
Constructor for the LoaderEngine takes a file classpath.
LoaderEngine(Context, URL) - Constructor for class simple.http.load.LoaderEngine
Constructor for the LoaderEngine that uses the class loader of the current instance to load the services.
LoaderEngine(Context, URL[]) - Constructor for class simple.http.load.LoaderEngine
Constructor for the LoaderEngine takes a URL classpath.
LoaderManager - Interface in simple.http.load
The LoaderManager is used to load Service implementation classes.
LoaderPermission - Class in simple.http.load
The LoaderPermission is used to provide access to the functions of the LoaderManager.
LoaderPermission(String) - Constructor for class simple.http.load.LoaderPermission
Constructor fot the LoaderPermission requires an action string.
LoadingException - Exception in simple.http.load
The LoadingException is thrown when the loading of a Service fails for some reason.
LoadingException() - Constructor for exception simple.http.load.LoadingException
This empty constructor is used if there is no explanation of the loading exception required.
LoadingException(String) - Constructor for exception simple.http.load.LoadingException
This constructor is used if there is a description of the event that caused the exception required.
LoadingException(Throwable) - Constructor for exception simple.http.load.LoadingException
This constructor is used if there is a description of the event that caused the exception required.
LocateException - Exception in simple.http.serve
The LocateException is thrown when the discovery of a resource by a Locator fails.
LocateException() - Constructor for exception simple.http.serve.LocateException
This empty constructor is used if there is no explanation of the locating exception required.
LocateException(String) - Constructor for exception simple.http.serve.LocateException
This constructor is used if there is a description of the event that caused the exception required.
locator - Variable in class simple.http.serve.FileContext
This is used to locate the configuration information.
Locator - Interface in simple.http.serve
The Locator interface is used to locate resources outside the scope of a Context.
lookup(String) - Method in class simple.http.load.LoaderEngine
This will look for and retrieve the requested resource.
lookup(String) - Method in class simple.http.load.MapperEngine
This will look for and retrieve the requested resource.
lookup(String) - Method in class simple.http.load.Redirect
This method is used to retrieve services using the name for that service.
lookup(String) - Method in class simple.http.serve.DomainHandler
Used to lookup a specific ProtocolHandler for a specific domain.
lookup(String) - Method in class simple.template.Action
This method is used to retrieve services using the name for that service.
lookup(String) - Method in interface simple.template.Container
Looks for the named template and wraps the template within a new Document instance.
lookup(String) - Method in class simple.template.Environment
Looks for the named template and wraps the template within a new Document instance.
lookup(String) - Method in class simple.template.freemarker.FreemarkerContainer
Looks for the named template and wraps the template within a new Document instance.
lookup(String, boolean) - Method in class simple.template.freemarker.FreemarkerContainer
Looks for the named template and wraps the template within a new Document instance.
lookup(String, Object, boolean) - Method in class simple.template.freemarker.FreemarkerContainer
Looks for the named template and wraps the template within a new Document instance.
lookup(String) - Method in class simple.template.page.PageContainer
Looks for the named template and wraps the template within a new Document instance.
lookup(String, boolean) - Method in class simple.template.page.PageContainer
Looks for the named template and wraps the template within a new Document instance.
lookup(String, Object, boolean) - Method in class simple.template.page.PageContainer
Looks for the named template and wraps the template within a new Document instance.
lookup(String) - Method in class simple.template.velocity.VelocityContainer
Looks for the named template and wraps the template within a new Document instance.
lookup(String, boolean) - Method in class simple.template.velocity.VelocityContainer
Looks for the named template and wraps the template within a new Document instance.
lookup(String, Object, boolean) - Method in class simple.template.velocity.VelocityContainer
Looks for the named template and wraps the template within a new Document instance.
lookup(String) - Method in class simple.template.View
This method is used to retrieve templates using the name or path for that template.
lookup(Object) - Method in class simple.util.cache.Cache
This will search the Cache to see if the item in the cache.
lookup(Object) - Method in class simple.util.cache.CacheList
This method will search to see if it can find the object stored under the key specified and return it.
lookup(Object) - Method in class simple.util.cache.TimeCache
This will search the TimeCache to see if the item in the time cache.

M

Maintainer - Interface in simple.http.session
The Maintainer is used to determine how long a session is to remain active between references.
Manager - Class in simple.http.session
The Manager object provides the interface to the session management system.
Manager() - Constructor for class simple.http.session.Manager
 
map - Variable in class simple.util.parse.MapParser
This is the internal map that provides storage for tokens.
MapParser - Class in simple.util.parse
The MapParser object represents a parser for name value pairs.
MapParser() - Constructor for class simple.util.parse.MapParser
Constructor for the MapParser object.
Mapper - Interface in simple.http.load
The Mapper is intended to provide a mapping from a URI path to a service.
mapper - Variable in class simple.http.load.MapperEngine
This is the mapper used by this engine to resolve URIs.
MapperEngine - Class in simple.http.load
The MapperEngine provides an implementation of the LoaderEngine that does not require administration.
MapperEngine() - Constructor for class simple.http.load.MapperEngine
Constructor for the MapperEngine.
MapperEngine(Context) - Constructor for class simple.http.load.MapperEngine
Constructor for the MapperEngine.
MapperEngine(Context, Object) - Constructor for class simple.http.load.MapperEngine
Constructor for the MapperEngine.
MapperEngine(Context, String) - Constructor for class simple.http.load.MapperEngine
Constructor for the MapperEngine.
MapperEngine(Context, String, Object) - Constructor for class simple.http.load.MapperEngine
Constructor for the MapperEngine.
MapperEngine(Context, File) - Constructor for class simple.http.load.MapperEngine
Constructor for the MapperEngine.
MapperEngine(Context, File, Object) - Constructor for class simple.http.load.MapperEngine
Constructor for the MapperEngine.
MapperFactory - Class in simple.http.load
The MapperFactory retrieves the Mapper implementation for the system.
MapperFactory() - Constructor for class simple.http.load.MapperFactory
 
match(String, Class) - Method in class simple.util.Introspector
This method performs the "discovery" of methods within the instance class.
match(String, Class[]) - Method in class simple.util.Introspector
This method performs the "discovery" of methods within the instance class.
Match - Interface in simple.util
This object is used with the Resolver to store and retrive the pattern match pairs.
max - Variable in class simple.util.schedule.Scheduler
The default maximum time a object can wait.
maxPriority - Variable in class simple.util.PriorityQueue
The maximum priority possible in this priority queue.
MessageQueue - Class in simple.util
This provides a means to pass messages between threads.
MessageQueue() - Constructor for class simple.util.MessageQueue
This creates a new MessageQueue object for passing messages between threads.
Model - Class in simple.page
The Model is used to store all attributes that are to be passed into the page.
Model() - Constructor for class simple.page.Model
Constructor for the Model object.
Model(Map) - Constructor for class simple.page.Model
Constructor for the Model object.

N

next() - Method in interface simple.util.net.CookieCollection
The next method is used to retrive the next Cookie in the list.
next() - Method in class simple.util.parse.CookieParser
Extracts the next Cookie object from the string given.
Node - Interface in simple.util.xml
The Node object acts as a wrapper for a KDOM element that contains various convinience methods.

O

object - Variable in class simple.util.schedule.Scheduler.Entry
 
off - Variable in class simple.util.parse.Parser
This represents the current read offset.

P

Page - Interface in simple.page
The Page object is used to define the interface to a compile page object.
PageContainer - Class in simple.template.page
The PageContainer provides an implementation of the Container object for Page objects.
PageContainer(Context) - Constructor for class simple.template.page.PageContainer
Constructor for the PageContainer object.
PageContainer(Workspace, Context) - Constructor for class simple.template.page.PageContainer
Constructor for the PageContainer object.
Panel - Interface in simple.template.layout
The Panel object is used to represent a means for a document to be written into a frame definition or screen.
ParameterParser - Class in simple.util.parse
The ParameterParser is used to parse data encoded in the application/x-www-form-urlencoded MIME type.
ParameterParser() - Constructor for class simple.util.parse.ParameterParser
Constructor for the ParameterParser.
ParameterParser(String) - Constructor for class simple.util.parse.ParameterParser
Constructor for the ParameterParser.
Parameters - Interface in simple.util.net
The Parameters object is used to represent HTTP parameters.
parse() - Method in class simple.util.parse.ContentParser
Reads and parses the MIME type from the given String object.
parse() - Method in class simple.util.parse.CookieParser
This will extract the next Cookie from the buffer.
parse(long) - Method in class simple.util.parse.DateParser
This is used to extract the date from a long.
parse() - Method in class simple.util.parse.DateParser
This is used to parse the contents of the buf.
parse() - Method in class simple.util.parse.LanguageParser
This will iteratively take language tokens from the HTTP header list.
parse(String[]) - Method in class simple.util.parse.ListParser
This allows multiple header values to be represented as one single comma seperated list.
parse() - Method in class simple.util.parse.ListParser
This ensures that tokens are taken from the comma seperated list as long as there bytes left to be examined within the source text.
parse() - Method in class simple.util.parse.ParameterParser
This performs the actual parsing of the parameter text.
parse(String) - Method in class simple.util.parse.Parser
This is used to parse the String given to it.
parse() - Method in class simple.util.parse.Parser
This is the method that should be implemented to read the buf.
parse() - Method in class simple.util.parse.PathParser
This will parse the path in such a way that it ensures that at no stage there are trailing back references, using path normalization.
parse() - Method in class simple.util.parse.PrincipalParser
Used to parse the actual header data.
parse() - Method in class simple.util.parse.URIParser
This will check to see what type of URI this is if it is an absoluteURI or a relativeURI.
parse(String) - Method in class simple.util.xml.Traverser
This is used to parse the provided source document.
parse(File) - Method in class simple.util.xml.Traverser
This is used to parse the provided source document.
parse(File, String) - Method in class simple.util.xml.Traverser
This is used to parse the provided source document.
parse(InputStream) - Method in class simple.util.xml.Traverser
This is used to parse the provided source document.
parse(InputStream, String) - Method in class simple.util.xml.Traverser
This is used to parse the provided source document.
parse(Reader) - Method in class simple.util.xml.Traverser
This is used to parse the provided source document.
parse(Element) - Method in class simple.util.xml.Traverser
This is used to parse the provided KDOM element.
parse(Node) - Method in class simple.util.xml.Traverser
This method is provided as a convinience for parsing the node provided.
ParseBuffer - Class in simple.util.parse
This is primarily used to replace the StringBuffer class, as a way for the Parser to store the char's for a specific region within the parse data that constitutes a desired value.
ParseBuffer() - Constructor for class simple.util.parse.ParseBuffer
Constructor for ParseBuffer.
ParseBuffer(int) - Constructor for class simple.util.parse.ParseBuffer
This creates a ParseBuffer with a specific default size.
Parser - Class in simple.util.parse
This Parser object is to be used as a simple template for parsing uncomplicated expressions.
Parser() - Constructor for class simple.util.parse.Parser
This is a no argument constructor for the Parser.
path - Variable in class simple.page.BasicPage
The path that the translated JSP source was created from.
Path - Interface in simple.util.net
The Path represents the path part of a URI.
PathParser - Class in simple.util.parse
This is used to parse a path given as part of a URI.
PathParser() - Constructor for class simple.util.parse.PathParser
The default constructor will create a PathParser that contains no specifics.
PathParser(String) - Constructor for class simple.util.parse.PathParser
This is primarily a convineance constructor.
PatternMapper - Class in simple.http.load
The PatternMapper provides a mapper that is used to perform mapping using patterns.
PatternMapper(Context) - Constructor for class simple.http.load.PatternMapper
Constructor for the PatternMapper.
pipe - Variable in class simple.http.FilterPipeline
This is the Pipeline that is wrapped.
Pipeline - Class in simple.http
This is a Pipeline object that is used to represent a HTTP Pipeline.
Pipeline() - Constructor for class simple.http.Pipeline
This constructor allows the Pipeline to be extended in such a way that it does not involve ant initialization of the Pipeline itself.
Pipeline(Socket) - Constructor for class simple.http.Pipeline
This creates a Pipeline from a Socket object.
PipelineFactory - Interface in simple.http
The PipelineFactory enables any object that is using a PipelineHandler to produce the object desired for processing with a Socket.
PipelineHandler - Interface in simple.http
The PipelineHandler interface is used to represent an object that handles Pipeline objects in sequence with a ProtocolHandler.
PipelineHandlerFactory - Class in simple.http
The PipelineHandlerFactory is used to hide a specific implementation of the PipelineHandler used.
PipelineHandlerFactory() - Constructor for class simple.http.PipelineHandlerFactory
 
PlainLayout - Class in simple.template.layout
The PlainLayout object provides an implementation of the Layout interface, which performs no layout.
PlainLayout(PanelFactory) - Constructor for class simple.template.layout.PlainLayout
Constructor for the PlainLayout object.
PrefixMapper - Class in simple.http.load
The PrefixMapper provides a mapper that is used to perform mapping using prefix paths.
PrefixMapper(Context) - Constructor for class simple.http.load.PrefixMapper
Constructor for the PrefixMapper.
PrefixResolver - Class in simple.http.load
The PrefixResolver is used to extract service names and types from an XML configuration file.
PrefixResolver(Locator) - Constructor for class simple.http.load.PrefixResolver
Constructor for the PrefixResolver.
PrefixResolver(Locator, int) - Constructor for class simple.http.load.PrefixResolver
Constructor for the PrefixResolver.
prepare(LoaderEngine, Object[]) - Method in class simple.http.load.Service
This method is used as a driver to the prepare method implemented by the subclass.
prepare(Object) - Method in class simple.http.session.ReflectionStore
This method is used as a driver to the prepare method implemented by the subclass.
prepare(Object) - Method in interface simple.http.session.Store
This method is used to prepare the Store for use with an active session.
prepare(Configuration, Environment) - Method in class simple.template.Controller
Initialize the controller with the environment used by the templating engine.
prepare(Configuration) - Method in class simple.template.Controller
This can be overridden by a subclass to perform preparation of the controller.
Principal - Interface in simple.util.net
The Principal interface is used to describe a user that has a name and password.
PrincipalParser - Class in simple.util.parse
PrincipalParser is a parser class for the HTTP basic authorization header.
PrincipalParser() - Constructor for class simple.util.parse.PrincipalParser
Creates a Parser for the basic authorization scheme.
PrincipalParser(String) - Constructor for class simple.util.parse.PrincipalParser
Creates a Parser for the basic authorization scheme.
PriorityQueue - Class in simple.util
This class implements a PriorityQueue.
PriorityQueue() - Constructor for class simple.util.PriorityQueue
Creates a new PriorityQueue object.
PriorityQueue(int) - Constructor for class simple.util.PriorityQueue
Creates a new PriorityQueue object.
PriorityQueue(int, long) - Constructor for class simple.util.PriorityQueue
Creates a new PriorityQueue object.
process(Socket) - Method in class simple.http.connect.SocketHandler
Once the Socket has been configured it can be used to create a Pipeline object.
process(Node) - Method in class simple.http.load.PrefixResolver
This is used to process a element node extracted from the XML document.
Process - Class in simple.http.load
The Process can be used to exploit the asynchronous ability of the simple.http framework.
Process(Context) - Constructor for class simple.http.load.Process
Constructor for the Process object is used so that the Context can be acquired.
process(Request, Response) - Method in class simple.http.load.Redirect
This process method is used to drive the redirect method.
process(Pipeline) - Method in interface simple.http.PipelineHandler
Used to process the Pipeline which is a full duplex communication link which may contain several http requests.
process(Request, Response, int) - Method in class simple.http.serve.Component
This method is used to handle the HTTP status reports so that if any Exception occurs the handle method can capture and deal with the exception.
process(Request, Response, Report) - Method in class simple.http.serve.Component
This method is used to handle the HTTP status reports so that if any Exception occurs the handle method can capture and deal with the exception.
process(Request, Response) - Method in class simple.http.serve.Component
This method is used to handle the HTTP transaction by subclasses of the Component.
process(Request, Response) - Method in class simple.template.Action
This process method is used to drive the execute method.
process(Request, Response) - Method in class simple.template.View
This process method is used to drive the execute methods.
process(Node) - Method in class simple.util.xml.Traverser
This is used to process an element from the KDOM document.
ProcessPermission - Class in simple.util.process
The ProcessPermission is used to provide access to the ProcessQueue.
ProcessPermission(String) - Constructor for class simple.util.process.ProcessPermission
Constructor for the LoaderPermission requires an action string.
ProcessQueue - Class in simple.util.process
The ProcessQueue object provides a means for quick independent executions.
profile - Variable in class simple.http.load.LoaderEngine
This contains the configuration of the loader engine.
PropertyBuffer - Class in simple.util.parse
The PropertyBuffer object is used to create strings which have system variable names replaced with their values.
PropertyBuffer() - Constructor for class simple.util.parse.PropertyBuffer
Constructor for the PropertyBuffer object.
PropertyException - Exception in simple.util
The PropertyException is used to describe the error that occurs when a properties file cannot be read.
PropertyException() - Constructor for exception simple.util.PropertyException
Constructor for the PropertyException.
PropertyException(Throwable) - Constructor for exception simple.util.PropertyException
Constructor for the PropertyException.
ProtocolHandler - Interface in simple.http
This is a ProtocolHandler that is used to process HTTP Request and Response objects.
ProtocolHandlerFactory - Class in simple.http.serve
The ProtocolHandlerFactory is used to retrieve a ProtocolHandler to handle HTTP transactions.
ProtocolHandlerFactory() - Constructor for class simple.http.serve.ProtocolHandlerFactory
 
pulse - Variable in class simple.util.schedule.PulseScheduler
The frequency that this Scheduler uses.
PulseScheduler - Class in simple.util.schedule
The PulseScheduler is a scheduler that is used when the time accuracy is not of great importance.
PulseScheduler() - Constructor for class simple.util.schedule.PulseScheduler
This creates a PulseScheduler to schedule objects.
PulseScheduler(long) - Constructor for class simple.util.schedule.PulseScheduler
This creates a PulseScheduler to schedule objects.
PulseScheduler(long, long) - Constructor for class simple.util.schedule.PulseScheduler
This creates a PulseScheduler to schedule objects.
put(String, Object) - Method in interface simple.http.Attributes
The put method is used to insert a mapping to the attributes that pairs the issued name with the issued value.
put(String, Object) - Method in class simple.http.FilterPipeline
The put method is used to insert a mapping to the attributes that pairs the issued name with the issued value.
put(String, Object) - Method in class simple.http.Pipeline
This can be used to set an attribute.
put(String, Object) - Method in interface simple.http.session.Session
This maps the given session variable to the provided name.
put(String, Object) - Method in interface simple.http.session.Store
This maps the given session variable to the provided name.
put(String, Object) - Method in interface simple.template.Database
The put method is used to insert a mapping in the database that pairs the issued name with the issued value.
put(String, Object) - Method in class simple.template.Environment
The put method is used to insert a mapping in the environment that pairs the issued name with the issued value.
put(Object, Object) - Method in class simple.util.parse.MapParser
The put method is used to insert the name and value provided into the collection of tokens.
putAll(Map) - Method in class simple.util.parse.MapParser
This method is used to insert a collection of tokens into the parsers map.

Q

queue - Variable in class simple.util.schedule.Scheduler
This is the PriorityQueue for the objects.

R

Redirect - Class in simple.http.load
The Redirect object provides a redirectable implementation of the Service object.
Redirect(Context) - Constructor for class simple.http.load.Redirect
Constructor for the Redirect object.
redirect(Request, Response) - Method in class simple.http.load.Redirect
The redirect method is used to perform various operations before a request or client is redirected.
Reference - Interface in simple.page.translate
The Reference object is used to determine whether any of the files used to compose the JSP have changed.
ReflectionStore - Class in simple.http.session
The ReflectionStore enables initialization to be achieved using arbitrary prepare methods.
ReflectionStore(Cookie) - Constructor for class simple.http.session.ReflectionStore
Constructor for the ReflectionStore.
regionMatches(int, byte[], int, int) - Method in class simple.util.Buffer
This is used to examine the bytes that are stored in the Buffer.
regionMatches(int, Buffer, int, int) - Method in class simple.util.Buffer
This is used to examine the bytes that are stored in the Buffer.
register(long) - Method in class simple.util.schedule.Scheduler
This will register with the Registry object.
registry - Variable in class simple.http.load.LoaderEngine
This contains the loaded Service's.
registry - Variable in class simple.util.schedule.Scheduler
List of current dequeuers for this Scheduler.
remove(String) - Method in interface simple.http.Attributes
The remove method is used to remove the named value from the attributes.
remove(String) - Method in class simple.http.FilterPipeline
The remove method is used to remove the named value from the attributes.
remove(int) - Method in class simple.http.FilterRequest
This can be used to remove the HTTP message header at the specified index.
remove(int) - Method in class simple.http.FilterResponse
This can be used to remove the HTTP message header at the specified index.
remove(int) - Method in interface simple.http.GenericHeader
This can be used to remove the HTTP message header at the specified index.
remove(String) - Method in class simple.http.load.LoaderEngine
This is used to terminate updates on a Loader object which has previously registered for updates.
remove(String) - Method in interface simple.http.load.LoaderManager
This is used to terminate updates on a Loader object which has previously registered for updates.
remove(String) - Method in class simple.http.Pipeline
This removes the attribute from this object.
remove(String) - Method in class simple.http.serve.DomainHandler
This will remove any ProtocolHandler for the specified pattern match.
remove(String) - Method in interface simple.http.session.Session
This removes the mapping for the specified name.
remove(String) - Method in interface simple.http.session.Store
This removes the mapping for the specified name.
remove(String) - Method in interface simple.http.State
This method removes and returns the removed cookie object from the State.
remove(String) - Method in interface simple.template.Database
The remove method is used to remove the named value from the database.
remove(String) - Method in class simple.template.Environment
The remove method is used to remove the mapping from the environment.
remove(Object) - Method in class simple.util.cache.Cache
This will remove the object cached using the specified key.
remove(Object) - Method in class simple.util.cache.CacheList
This method will search the list to see if there is an object stored in the list under that name.
remove(Object) - Method in class simple.util.cache.TimeCache
This will remove the object cached using the specified key.
remove(Object) - Method in class simple.util.parse.MapParser
The remove method is used to remove the named token pair from the collection of tokens.
remove() - Method in class simple.util.PriorityQueue
Remove is a function to remove the element in the queue with the maximum priority.
remove(int) - Method in class simple.util.Resolver
This will remove the entry in this Resolver so that the pattern will not be used to resolve String's any more.
remove(String) - Method in class simple.util.Resolver
This will remove the entry in this Resolver so that the pattern will not be used to resolve String's any more.
remove(Match) - Method in class simple.util.Resolver
This will remove the entry in this Resolver so that the pattern will not be used to resolve String's any more.
removeAll(String) - Method in class simple.http.FilterRequest
This can be used to remove all HTTP message headers with the specified name.
removeAll(String) - Method in class simple.http.FilterResponse
This can be used to remove all HTTP message headers with the specified name.
removeAll(String) - Method in interface simple.http.GenericHeader
This can be used to remove all HTTP message headers with the specified name.
renew(Lease, Store) - Method in interface simple.http.session.Maintainer
This method is used to determine the length of time the session should linger between references.
renew(long) - Method in interface simple.util.lease.Lease
This ensures that the leased resource is maintained for the specified duration.
Report - Interface in simple.http.serve
The Report interface is used to describe a HTTP response message.
req - Variable in class simple.http.FilterRequest
This is the object that is being wrapped.
Request - Interface in simple.http
This interface is used to represent a HTTP request.
RequestLine - Interface in simple.http
The RequestLine is used to represent a HTTP request line.
reset() - Method in class simple.http.FilterResponse
The reset method is used to reset the output from an issued OutputStream.
reset() - Method in interface simple.http.Response
The reset method is used to reset the output from an issued OutputStream.
reset() - Method in interface simple.util.net.CookieCollection
This is used so that the collection of Cookies can be reiterated.
reset() - Method in class simple.util.parse.CookieParser
This is used so that the collection of Cookies can be reiterated.
resize(int) - Method in class simple.util.Buffer
This ensure that there is enough space in the Buffer to allow for more chars to be added.
resize(int) - Method in class simple.util.cache.CacheList
This simply specifies the maximum size that this list can grow and then purges the Least Recently Used items in the list, that is items at the tail.
resize(int) - Method in class simple.util.process.ProcessQueue
This is used to either increase or decrease the number of threads that are active in the ProcessQueue.
resolve(String) - Method in class simple.http.load.LoaderEngine
This will look for and retrieve the requested resource.
resolve(String) - Method in class simple.http.load.MapperEngine
This will detetmine whether the URI string issued contains a reference to a service object.
resolve(String) - Method in class simple.http.load.Redirect
This method is used to retrieve services using a specific URI.
resolve(String) - Method in class simple.http.serve.FileEngine
This will look for and retrieve the requested resource.
resolve(String, File) - Method in class simple.http.serve.FileEngine
This will look for and retrieve the requested resource.
resolve(String) - Method in interface simple.http.serve.ResourceEngine
This will look for and retrieve the requested resource.
resolve(String) - Method in class simple.template.Action
This method is used to retrieve services using the path for that service.
resolve(String) - Method in class simple.template.Environment
Looks for the named template and wraps the template within a new Document instance.
resolve(String) - Method in class simple.template.TemplateEngine
This will look for and retrieve the requested resource.
resolve(String) - Method in class simple.template.View
This method is used to retrieve templates using a specific URI.
resolve(String) - Method in class simple.util.Resolver
This will search the patterns in this Resolver to see if there is a pattern in it that matches the string given.
resolver - Variable in class simple.http.load.LoaderEngine
The Resolver for the linked classes.
Resolver - Class in simple.util
This is used to match String's with the first pattern that String matches.
Resolver() - Constructor for class simple.util.Resolver
The default constructor will create a Resolver without a large cache size.
Resolver(int) - Constructor for class simple.util.Resolver
This constructor allows resolves to be cached for increased performance.
Resource - Interface in simple.http.serve
A Resource provides an abstraction of any given object that can be retrieved using a HTTP request.
ResourceEngine - Interface in simple.http.serve
The ResourceEngine is used to create implementations of the Resource interface that suit the targeted resource.
resp - Variable in class simple.http.FilterResponse
This is the object that is being wrapped.
Response - Interface in simple.http
This is used to represent the HTTP response.
root - Variable in class simple.page.compile.Compiler
This is the build directory for the provided workspace.

S

Scheduler - Class in simple.util.schedule
The Scheduler is used for scheduling arbitrary objects.
Scheduler() - Constructor for class simple.util.schedule.Scheduler
This will create a default Scheduler.
Scheduler(long) - Constructor for class simple.util.schedule.Scheduler
This creates a Scheduler object with the maximum timeout specified.
Scheduler.Entry - Class in simple.util.schedule
This is used to keep objects with there time of release.
Scheduler.Entry() - Constructor for class simple.util.schedule.Scheduler.Entry
 
Service - Class in simple.http.load
The Service is a loadable component that is used to process requests.
Service(Context) - Constructor for class simple.http.load.Service
Constructor to the Service object.
Session - Interface in simple.http.session
The Session object is used to store session data relating to a specific HTTP client.
set(String, String) - Method in class simple.http.FilterRequest
This can be used to set a HTTP message header to this object.
set(String, int) - Method in class simple.http.FilterRequest
This can be used to set a HTTP message header to this object.
set(String, String) - Method in class simple.http.FilterResponse
This can be used to set a HTTP message header to this object.
set(String, int) - Method in class simple.http.FilterResponse
This can be used to set a HTTP message header to this object.
set(String, String) - Method in interface simple.http.GenericHeader
This can be used to set a HTTP message header to this object.
set(String, int) - Method in interface simple.http.GenericHeader
This can be used to set a HTTP message header to this object.
setBuild(File) - Method in class simple.page.ant.CompileTask
This is used to collect the build directory, which is where the JSP source files are translated and compiled to.
setByte(int, int) - Method in class simple.util.Buffer
This is used to write bytes into the Buffer at an arbitrary position.
setBytes(int, byte[], int, int) - Method in class simple.util.Buffer
This is used to write bytes into the Buffer at an arbitrary position.
setBytes(int, Buffer) - Method in class simple.util.Buffer
This is used to write bytes into the Buffer at an arbitrary position.
setBytes(int, Buffer, int, int) - Method in class simple.util.Buffer
This is used to write bytes into the Buffer at an arbitrary position.
setCharset(String) - Method in interface simple.util.net.ContentType
This will set the charset to whatever value is in the String object.
setCharset(String) - Method in class simple.util.parse.ContentParser
This will set the charset to whatever value is in the String object.
setClasspath(Path) - Method in class simple.page.ant.CompileTask
This is used to set the classpath from an attribute.
setCode(int) - Method in class simple.http.FilterResponse
This method allows the status for the response to be changed.
setCode(int) - Method in interface simple.http.StatusLine
This method allows the status for the response to be changed.
setContentLength(int) - Method in class simple.http.FilterResponse
This should be used when the size of the message body is known.
setContentLength(int) - Method in interface simple.http.Response
This should be used when the size of the message body is known.
setCookie(Cookie) - Method in interface simple.http.State
The setCookie method is used to set a cookie value with the cookie name.
setCookie(String, String) - Method in interface simple.http.State
The setCookie method is used to set a cookie value for a specified name.
setCookie(String, String, String) - Method in interface simple.http.State
The setCookie method is used to set a cookie value for a specified name.
setDate(String, long) - Method in class simple.http.FilterRequest
This is used as a convenience method for setting a header that needs to be parsed into a HTTP-date string.
setDate(String, long) - Method in class simple.http.FilterResponse
This is used as a convenience method for setting a header that needs to be parsed into a HTTP-date string.
setDate(String, long) - Method in interface simple.http.GenericHeader
This is used as a convenience method for setting a header that needs to be parsed into a HTTP-date string.
setDomain(String) - Method in class simple.util.net.Cookie
This enables the domain for this Cookie to be set.
setDomain(String) - Method in interface simple.util.net.URI
This will set the domain to whatever value is in the string parameter.
setDomain(String) - Method in class simple.util.parse.URIParser
This will set the domain to whatever value is in the string parameter.
setExpiry(int) - Method in class simple.util.net.Cookie
This allows a lifetime to be specified for the cookie.
setMajor(int) - Method in class simple.http.FilterRequest
This can be used to specify the major version for the HTTP request.
setMajor(int) - Method in class simple.http.FilterResponse
This can be used to specify the major version.
setMajor(int) - Method in interface simple.http.RequestLine
This can be used to specify the major version for the HTTP request.
setMajor(int) - Method in interface simple.http.StatusLine
This can be used to specify the major version.
setMethod(String) - Method in class simple.http.FilterRequest
This is used to set the method for this HTTP request object.
setMethod(String) - Method in interface simple.http.RequestLine
This is used to set the method for this HTTP request object.
setMinor(int) - Method in class simple.http.FilterRequest
This can be used to specify the minor version for the HTTP request.
setMinor(int) - Method in class simple.http.FilterResponse
This can be used to specify the minor version.
setMinor(int) - Method in interface simple.http.RequestLine
This can be used to specify the minor version for the HTTP request.
setMinor(int) - Method in interface simple.http.StatusLine
This can be used to specify the minor version.
setPath(String) - Method in class simple.util.net.Cookie
This is used to set the cookie path for this cookie.
setPath(String) - Method in interface simple.util.net.URI
This will set the path to whatever value it is given.
setPath(Path) - Method in interface simple.util.net.URI
This will set the path to whatever value it is given.
setPath(String) - Method in class simple.util.parse.URIParser
This will set the path to whatever value it is given.
setPath(Path) - Method in class simple.util.parse.URIParser
This will set the path to whatever value it is given.
setPort(int) - Method in interface simple.util.net.URI
This will set the port to whatever value it is given.
setPort(int) - Method in class simple.util.parse.URIParser
This will set the port to whatever value it is given.
setPrimary(String) - Method in interface simple.util.net.ContentType
This sets the type to whatever value is in the String object.
setPrimary(String) - Method in class simple.util.parse.ContentParser
Sets the type to whatever value is in the String object.
setProject(String) - Method in class simple.page.ant.CompileTask
This is used to specify the name of the JSP workspace.
setQuery(String) - Method in interface simple.util.net.URI
This will set the query to whatever value it is given.
setQuery(Parameters) - Method in interface simple.util.net.URI
This will set the query to whatever value it is given.
setQuery(String) - Method in class simple.util.parse.URIParser
This will set the query to whatever value it is given.
setQuery(Parameters) - Method in class simple.util.parse.URIParser
This will set the query to whatever value it is given.
setScheme(String) - Method in interface simple.util.net.URI
This allows the scheme for the uri to be specified.
setScheme(String) - Method in class simple.util.parse.URIParser
This allows the scheme for the URI to be specified.
setSecondary(String) - Method in interface simple.util.net.ContentType
Sets the subtype to whatever value is in the String object.
setSecondary(String) - Method in class simple.util.parse.ContentParser
Sets the subtype to whatever value is in the String object.
setSecure(boolean) - Method in class simple.util.net.Cookie
This is used to determine if the client browser should send this cookie over a secure protocol.
setText(String) - Method in class simple.http.FilterResponse
This is used to set the text of the HTTP status line.
setText(String) - Method in interface simple.http.StatusLine
This is used to set the text of the HTTP status line.
setURI(String) - Method in class simple.http.FilterRequest
This can be used to set the URI for this HTTP request.
setURI(String) - Method in interface simple.http.RequestLine
This can be used to set the URI for this HTTP request.
setValue(String) - Method in class simple.util.net.Cookie
This enables the value of the cookie to be changed.
setVersion(int) - Method in class simple.util.net.Cookie
This enables the version of the Cookie to be set.
simple.http - package simple.http
 
simple.http.connect - package simple.http.connect
 
simple.http.load - package simple.http.load
 
simple.http.serve - package simple.http.serve
 
simple.http.session - package simple.http.session
 
simple.page - package simple.page
 
simple.page.ant - package simple.page.ant
 
simple.page.compile - package simple.page.compile
 
simple.page.translate - package simple.page.translate
 
simple.template - package simple.template
 
simple.template.freemarker - package simple.template.freemarker
 
simple.template.layout - package simple.template.layout
 
simple.template.page - package simple.template.page
 
simple.template.velocity - package simple.template.velocity
 
simple.util - package simple.util
 
simple.util.cache - package simple.util.cache
 
simple.util.lease - package simple.util.lease
 
simple.util.net - package simple.util.net
 
simple.util.parse - package simple.util.parse
 
simple.util.process - package simple.util.process
 
simple.util.schedule - package simple.util.schedule
 
simple.util.xml - package simple.util.xml
 
size - Variable in class simple.http.serve.CacheContentFactory
This is the maximum allowed size for a cached file.
size() - Method in interface simple.http.State
Returns the number of cookies that exist within the state.
size() - Method in class simple.util.parse.MapParser
This obviously enough provides the number of tokens that have been inserted into the internal map.
size() - Method in class simple.util.Resolver
This will return the number of entrys that have been inserted into this Resolver.
skip(String) - Method in class simple.util.parse.CookieParser
This is used to skip an arbitrary String within the char buf.
skip(String) - Method in class simple.util.parse.Parser
This is used to skip an arbitrary String within the char buf.
sleep(long) - Method in class simple.util.schedule.Scheduler
This will put the curent thread to sleep.
sock - Variable in class simple.http.Pipeline
This is the socket that provides the input and output.
SocketHandler - Class in simple.http.connect
The SocketHandler object is used in conjunction with the Connection to dispatch Pipeline objects to a PipelineHandler for incoming TCP connections.
SocketHandler(PipelineHandler) - Constructor for class simple.http.connect.SocketHandler
This constructor creates a SocketHandler using a PipelineHandler object.
SocketHandler(PipelineHandler, PipelineFactory) - Constructor for class simple.http.connect.SocketHandler
This constructor creates a SocketHandler using a PipelineHandler object.
Source - Interface in simple.page.translate
The Source object is used to describe a translated JSP page.
space(char) - Method in class simple.util.parse.Parser
This is used to determine if a given ISO-8859-1 character is a space character.
start() - Method in class simple.http.load.PrefixResolver
This method is used to initialize this resolver.
start() - Method in class simple.util.xml.Traverser
This is used to initialize the XML parser.
State - Interface in simple.http
The State is used by the Request to examine the cookies that have been issued with the HTTP request.
status - Static variable in class simple.http.serve.StatusReport
This is used to load the Error.properties file for a list of the matching HTTP status messages.
StatusLine - Interface in simple.http
The StatusLine is used to represent a HTTP status line.
StatusReport - Class in simple.http.serve
The StatusReport is used to describe HTTP status messages.
StatusReport(int) - Constructor for class simple.http.serve.StatusReport
Constructor for the StatusReport object.
stop() - Method in class simple.util.process.ProcessQueue
This is a convenience method that is used to deactivate all the threads in the ProcessQueue this is similar a resize with zero.
Store - Interface in simple.http.session
The Store object provides the persistence scheme used by sessions.
StoreException - Exception in simple.http.session
The StoreException is used to indicate that some operation failed when attempting to use a Store.
StoreException() - Constructor for exception simple.http.session.StoreException
This empty constructor is used if there is no explanation of the leasing exception required.
StoreException(String) - Constructor for exception simple.http.session.StoreException
This constructor is used if there is a description of the event that caused the exception required.
system - Variable in class simple.template.Controller
Represents the environment the controller exists within.

T

table - Variable in class simple.http.Pipeline
This is used to store properties for this connection.
TemplateEngine - Class in simple.template
The TemplateEngine provides the core functionality required to process templates.
TemplateEngine(Context, Container) - Constructor for class simple.template.TemplateEngine
Constructor for the TemplateEngine object.
TemplateEngine(Context, Container, File) - Constructor for class simple.template.TemplateEngine
Constructor for the TemplateEngine object.
TemplateEngine(Context, Environment, File) - Constructor for class simple.template.TemplateEngine
Constructor for the TemplateEngine object.
Tile - Interface in simple.template.layout
The Tile object is used to represent a value that has been acquired from a Source.
TileLayout - Class in simple.template.layout
The TileLayout provides a document layout that can be used to build a graph of templates that can be used to create a single view.
TileLayout(PanelFactory, Context) - Constructor for class simple.template.layout.TileLayout
Constructor for the TileLayout object.
TimeCache - Class in simple.util.cache
This is a LRU, Least Recently Used, TimeCache for caching objects.
TimeCache() - Constructor for class simple.util.cache.TimeCache
This is used to create a TimeCache object for storing objects.
TimeCache(int, int) - Constructor for class simple.util.cache.TimeCache
This is used to create a TimeCache object for storing objects.
TimeCache(int, int, int) - Constructor for class simple.util.cache.TimeCache
This is a constructor method used by 'this' to specify the characteristics that the TimeCache may have.
timeout - Variable in class simple.util.schedule.Scheduler.Entry
 
toArray() - Method in class simple.util.Buffer
This is used to create a copy of the bytes that are stored in the Buffer object.
toClientString() - Method in class simple.util.net.Cookie
This will give the correct string value of this cookie.
token(Object) - Method in class simple.util.parse.MapParser
The token method is used to acquire the value as a string.
toLong() - Method in class simple.util.parse.DateParser
This returns the date in as a long, given the exact time this will use the java.util.Date to parse this date into a long.
toLower(char) - Method in class simple.util.parse.Parser
This takes a unicode character and assumes an encoding of ISO-8859-1.
toString() - Method in class simple.http.FilterRequest
This method is used so that the original HTTP header can be reconstructed This returns a String that contains each header formatted according to the HTTP/1.1 header format.
toString() - Method in class simple.http.FilterResponse
This constructs the HTTP message header according to the format of RFC 2616.
toString() - Method in interface simple.http.Request
This method is used so that the original HTTP header can be reconstructed This returns a String that contains each header formatted according to the HTTP/1.1 header format.
toString() - Method in interface simple.http.Response
This constructs the HTTP message header according to the format of RFC 2616.
toString() - Method in interface simple.http.serve.Content
This method is used to embed the generated contents into other strings and capture the value of the content as a string.
toString() - Method in interface simple.template.Document
Produces the generated template output as a string.
toString() - Method in interface simple.template.layout.Tile
This invokes the toString method of the source value.
toString() - Method in class simple.util.Buffer
This method is used to acquire the buffered bytes as a string.
toString() - Method in interface simple.util.lease.Lease
Provides the name of the resource that this lease represents.
toString() - Method in interface simple.util.net.ContentType
This will return the String value of the MIME type.
toString() - Method in class simple.util.net.Cookie
The toString method converts the cookie to the Set-Cookie value.
toString() - Method in interface simple.util.net.Parameters
This will return all parameters represented using the HTTP URL query format.
toString() - Method in interface simple.util.net.Path
This will return the normalized path.
toString() - Method in interface simple.util.net.URI
This is used to convert this URI object into a String object.
toString() - Method in class simple.util.parse.ContentParser
This will return the String value of the MIME type.
toString() - Method in class simple.util.parse.DateParser
This prints the date in the format of a RFC 1123 date.
toString(Set) - Method in class simple.util.parse.ParameterParser
This toString method is used to compose an string in the application/x-www-form-urlencoded MIME type.
toString() - Method in class simple.util.parse.ParameterParser
This toString method is used to compose an string in the application/x-www-form-urlencoded MIME type.
toString() - Method in class simple.util.parse.ParseBuffer
This will return the characters that have been appended to the ParseBuffer as a String object.
toString() - Method in class simple.util.parse.PathParser
This will return the normalized path.
toString() - Method in class simple.util.parse.PropertyBuffer
This method is used to parse the value of the buffered text and return the corrosponding string.
toString() - Method in class simple.util.parse.URIParser
This is used to convert this URI object into a String object.
translate(String) - Method in class simple.page.translate.Translator
This method performs the translation of the JSP source file.
Translator - Class in simple.page.translate
The Translator object is used to translate a JSP source file to a Java or Groovy source file.
Translator(Workspace) - Constructor for class simple.page.translate.Translator
Constructor for the Translator object.
traverse(Element) - Method in class simple.util.xml.Traverser
This method is used to traverse all KDOM nodes acquired.
traverse(Element, int) - Method in class simple.util.xml.Traverser
This method is used to traverse all KDOM nodes acquired.
Traverser - Class in simple.util.xml
The Traverser object is used to parse an XML document in a simple element by element manner.
Traverser() - Constructor for class simple.util.xml.Traverser
Constructor for the Traverser object this is used to create a new instance with a new document builder object.
type - Variable in class simple.page.BasicPage
This is the MIME type specified by the page implementation.

U

unlink(String) - Method in class simple.http.load.LoaderEngine
This is used to unlink a loaded Service that was linked to the specified pattern.
unlink(Match) - Method in class simple.http.load.LoaderEngine
This is used to unlink a loaded Service that was linked to the specified match.
unlink(String) - Method in interface simple.http.load.LoaderManager
This is used to unlink a loaded Service that was linked to the specified pattern.
unlink(Match) - Method in interface simple.http.load.LoaderManager
This is used to unlink a loaded Service that was linked to the specified match.
unload(String) - Method in class simple.http.load.LoaderEngine
When an instance has been loaded by the load method this can be used to purge it from the system and subsequently remove all links to it.
unload(String) - Method in interface simple.http.load.LoaderManager
When an instance has been loaded by the load method this can be used to purge it from the system and subsequently remove all links to it.
unregister() - Method in class simple.util.schedule.Scheduler
This will unregister the current thread from the Registry object.
update(LoaderManager, Layout) - Method in interface simple.http.load.Loader
The update method is invoked when there is a change in the layout.
update(String, Loader) - Method in class simple.http.load.LoaderEngine
This is used to insert a Loader object which is used to recieve updates on the configuration.
update(String, Loader) - Method in interface simple.http.load.LoaderManager
This is used to insert a Loader object which is used to recieve updates on the configuration.
URI - Interface in simple.util.net
The URI interface is used to represent a generic uniform resource identifier .
URIParser - Class in simple.util.parse
This parser is used to parse uniform resource identifiers.
URIParser() - Constructor for class simple.util.parse.URIParser
Default constructor will create a URIParser that contains no specifics.
URIParser(String) - Constructor for class simple.util.parse.URIParser
This is primarily a convineance constructor.
URLProperties - Class in simple.util
The URLProperties object is used as a convienience class that is used to create a Properties object from a URL.
URLProperties(String) - Constructor for class simple.util.URLProperties
Constructor for the URLProperties object.
URLProperties(URL) - Constructor for class simple.util.URLProperties
Constructor for the URLProperties object.

V

value - Variable in class simple.util.PriorityQueue
This contains the list of prioritys in the queue.
values() - Method in class simple.util.parse.MapParser
This method is used to acquire the value for all tokens that have currently been collected by this parser.
VelocityContainer - Class in simple.template.velocity
The VelocityContainer provides an implementation of the Container object for Velocity.
VelocityContainer() - Constructor for class simple.template.velocity.VelocityContainer
Constructor for the VelocityContainer object.
VelocityContainer(Context) - Constructor for class simple.template.velocity.VelocityContainer
Constructor for the VelocityContainer object.
VelocityContainer(VelocityEngine) - Constructor for class simple.template.velocity.VelocityContainer
Constructor for the VelocityContainer object.
VelocityContainer(VelocityEngine, Context) - Constructor for class simple.template.velocity.VelocityContainer
Constructor for the VelocityContainer object.
View - Class in simple.template
The View object provides a service controller implementation for providing a document view.
View(Context) - Constructor for class simple.template.View
Constructor for the View object.
Viewer - Interface in simple.template.layout
A Viewer object represents a template with a set of properties.
ViewerFactory - Interface in simple.template.layout
The ViewerFactory serves to resolve a template view from a specified path.

W

Workspace - Class in simple.page
The Workspace object is used to specify the source and build context for the JSP translation and compilation process.
Workspace(Context) - Constructor for class simple.page.Workspace
Constructor for the Workspace object.
Workspace(Context, String) - Constructor for class simple.page.Workspace
Constructor for the Workspace object.
Workspace(Context, String, String) - Constructor for class simple.page.Workspace
Constructor for the Workspace object.
Workspace(Context, String, File) - Constructor for class simple.page.Workspace
Constructor for the Workspace object.
write(OutputStream) - Method in interface simple.http.serve.Content
This writes the contents of the instance to the issued stream.
write(PrintWriter, Object) - Method in class simple.page.Model
This method is used to write the value of the referenced value directly to the PrintWriter.
write(PrintWriter, Model) - Method in interface simple.page.Page
This is used to write the contents of the JSP page to the writer provided.
write(OutputStream) - Method in interface simple.template.Document
Displays the contents of the generated template output to the OutputStream.
write(PrintWriter) - Method in interface simple.template.layout.Panel
This is used to write the contents of the document without the need for an adapter, such as an output stream writer.
write(PrintWriter) - Method in interface simple.template.layout.Tile
This is used to write the contents of the tile to the provided writer.
write(PrintWriter) - Method in interface simple.template.layout.Viewer
Displays the contents of the generated template output to the issued Writer.
writeTo(OutputStream) - Method in class simple.util.Buffer
This is used to emit data from the Buffer out to an OutputStream.
writeTo(OutputStream, int, int) - Method in class simple.util.Buffer
This is used to emit data from the Buffer out to an OutputStream.

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