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

A

AbstractBufferedItemReaderItemStream - Class in org.springframework.batch.item.support
Abstract superclass for ItemReaders which use item buffering to support reset/rollback.
AbstractBufferedItemReaderItemStream() - Constructor for class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
 
AbstractItemReader - Class in org.springframework.batch.item.support
Base class for ItemReader implementations.
AbstractItemReader() - Constructor for class org.springframework.batch.item.support.AbstractItemReader
 
AbstractItemStreamItemReader - Class in org.springframework.batch.item.support
Base class for ItemReader implementations.
AbstractItemStreamItemReader() - Constructor for class org.springframework.batch.item.support.AbstractItemStreamItemReader
 
AbstractItemStreamItemWriter - Class in org.springframework.batch.item.support
Base class for ItemWriter implementations.
AbstractItemStreamItemWriter() - Constructor for class org.springframework.batch.item.support.AbstractItemStreamItemWriter
 
AbstractItemWriter - Class in org.springframework.batch.item.support
Abstract ItemWriter that allows for base classes to only implement the AbstractItemWriter.flush() and AbstractItemWriter.clear() methods if they need it.
AbstractItemWriter() - Constructor for class org.springframework.batch.item.support.AbstractItemWriter
 
AbstractLineTokenizer - Class in org.springframework.batch.item.file.transform
Abstract class handling common concerns of various LineTokenizer implementations such as dealing with names and actual construction of FieldSet
AbstractLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
AbstractMethodInvokingDelegator - Class in org.springframework.batch.item.adapter
Superclass for delegating classes which dynamically call a custom method of injected object.
AbstractMethodInvokingDelegator() - Constructor for class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
AbstractStatefulRetryPolicy - Class in org.springframework.batch.retry.policy
Base class for stateful retry policies: those that operate in the context of a callback that is called once per retry execution (usually to enforce that it is only called once per transaction).
AbstractStatefulRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.AbstractStatefulRetryPolicy
 
AbstractStatelessRetryPolicy - Class in org.springframework.batch.retry.policy
Base class for "normal" retry policies: those that operate in the context of a callback that is called repeatedly in a loop until it succeeds, or the policy decides to terminate.
AbstractStatelessRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.AbstractStatelessRetryPolicy
 
AbstractTransactionalResourceItemWriter - Class in org.springframework.batch.item.database
Stores items in transactional resource and flushes aggressively in case of failure.
AbstractTransactionalResourceItemWriter() - Constructor for class org.springframework.batch.item.database.AbstractTransactionalResourceItemWriter
 
add(XMLEvent) - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
 
addExitDescription(String) - Method in class org.springframework.batch.repeat.ExitStatus
Add an exit description to an existing ExitStatus.
after(RepeatContext, ExitStatus) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
after(RepeatContext, ExitStatus) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
after(RepeatContext, ExitStatus) - Method in interface org.springframework.batch.repeat.RepeatListener
Called by the framework after each item has been processed, unless the item processing results in an exception.
afterPropertiesSet() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
afterPropertiesSet() - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.BatchSqlUpdateItemWriter
Check mandatory properties - there must be a delegate.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.DrivingQueryItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernateAwareItemWriter
Check mandatory properties - there must be a delegate and hibernateTemplate.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Assert that mandatory properties are set.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.support.IbatisKeyCollector
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.support.MultipleColumnJdbcKeyCollector
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.support.SingleColumnJdbcKeyCollector
 
afterPropertiesSet() - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Assert that mandatory properties (resource) are set.
afterPropertiesSet() - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Check that precisely one of type or prototype bean name is specified.
afterPropertiesSet() - Method in class org.springframework.batch.item.support.DelegatingItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.support.DelegatingItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.item.transform.CompositeItemTransformer
 
afterPropertiesSet() - Method in class org.springframework.batch.item.transform.ItemTransformerItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.item.validator.SpringValidator
 
afterPropertiesSet() - Method in class org.springframework.batch.item.validator.ValidatingItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.xml.stax.DefaultTransactionalEventReader
Deprecated.  
afterPropertiesSet() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
Ensure that all required dependencies for the ItemReader to run are provided after all properties have been set.
afterPropertiesSet() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
 
aggregate(FieldSet) - Method in class org.springframework.batch.item.file.transform.DelimitedLineAggregator
Method used to create string representing object.
aggregate(FieldSet) - Method in class org.springframework.batch.item.file.transform.FixedLengthLineAggregator
Aggregate provided strings into single line using specified column ranges.
aggregate(FieldSet) - Method in interface org.springframework.batch.item.file.transform.LineAggregator
Method used to create a string to be stored from the array of values.
AggregateItemReader - Class in org.springframework.batch.item.support
An ItemReader that delivers a list as its item, storing up objects from the injected ItemReader until they are ready to be packed out as a collection.
AggregateItemReader() - Constructor for class org.springframework.batch.item.support.AggregateItemReader
 
Alignment - Class in org.springframework.batch.item.file.transform
 
Alignment(String, String) - Constructor for class org.springframework.batch.item.file.transform.Alignment
 
AlwaysRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that always permits a retry.
AlwaysRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.AlwaysRetryPolicy
 
and(boolean) - Method in class org.springframework.batch.repeat.ExitStatus
Create a new ExitStatus with a logical combination of the continuable flag.
and(ExitStatus) - Method in class org.springframework.batch.repeat.ExitStatus
Create a new ExitStatus with a logical combination of the continuable flag, and a concatenation of the descriptions.
attributeNames() - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 

B

backOff(BackOffContext) - Method in interface org.springframework.batch.retry.backoff.BackOffPolicy
Back off/pause in an implementation-specific fashion.
backOff(BackOffContext) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Pause for a length of time equal to 'exp(backOffContext.expSeed)'.
backOff(BackOffContext) - Method in class org.springframework.batch.retry.backoff.StatelessBackOffPolicy
Delegates directly to the StatelessBackOffPolicy.doBackOff() method without passing on the BackOffContext argument which is not needed for stateless implementations.
BackOffContext - Interface in org.springframework.batch.retry.backoff
 
BackOffInterruptedException - Exception in org.springframework.batch.retry.backoff
Exception class signifiying that an attempt to back off using a BackOffPolicy was interrupted, most likely by an InterruptedException during a call to Thread.sleep(long).
BackOffInterruptedException(String) - Constructor for exception org.springframework.batch.retry.backoff.BackOffInterruptedException
 
BackOffInterruptedException(String, Throwable) - Constructor for exception org.springframework.batch.retry.backoff.BackOffInterruptedException
 
BackOffPolicy - Interface in org.springframework.batch.retry.backoff
Strategy interface to control back off between attempts in a single retry operation.
BatchSqlUpdateItemWriter - Class in org.springframework.batch.item.database
ItemWriter that uses the batching features from PreparedStatement if available and can take some rudimentary steps to locate a failure during a flush, and identify the items that failed.
BatchSqlUpdateItemWriter() - Constructor for class org.springframework.batch.item.database.BatchSqlUpdateItemWriter
 
BeanWrapperFieldSetMapper - Class in org.springframework.batch.item.file.mapping
FieldSetMapper implementation based on bean property paths.
BeanWrapperFieldSetMapper() - Constructor for class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
 
before(RepeatContext) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
before(RepeatContext) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
before(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatListener
Called by the framework before each batch item.
begin(Object) - Method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
Make a copy of the target that can be used inside a transaction to isolate changes from the original.
BEGIN_RECORD - Static variable in class org.springframework.batch.item.support.AggregateItemReader
Marker for the beginning of a multi-object record.
BinaryExceptionClassifier - Class in org.springframework.batch.support
A ExceptionClassifier that has only two classes of exception.
BinaryExceptionClassifier() - Constructor for class org.springframework.batch.support.BinaryExceptionClassifier
 
BindingException - Exception in org.springframework.batch.item.file.mapping
 
BindingException(String) - Constructor for exception org.springframework.batch.item.file.mapping.BindingException
 

C

canContinue(ExitStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Check return value from batch operation.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.AlwaysRetryPolicy
Always returns true.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.CompositeRetryPolicy
Delegate to the policies that were in operation when the context was created.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Delegate to the policy currently activated in the context.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.NeverRetryPolicy
Returns false after the first exception.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.RecoveryCallbackRetryPolicy
Check the history of this item, and if it has reached the retry limit, then return false.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Test for retryable operation based on the status.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
Only permits a retry if the timeout has not expired.
canRetry(RetryContext) - Method in interface org.springframework.batch.retry.RetryPolicy
 
CENTER - Static variable in class org.springframework.batch.item.file.transform.Alignment
 
classify(Throwable) - Method in class org.springframework.batch.support.BinaryExceptionClassifier
Returns either ExceptionClassifierSupport.DEFAULT or BinaryExceptionClassifier.NON_DEFAULT depending on the type of the throwable.
classify(Throwable) - Method in interface org.springframework.batch.support.ExceptionClassifier
Classify the given exception and return a non-null object.
classify(Throwable) - Method in class org.springframework.batch.support.ExceptionClassifierSupport
Always returns the value of ExceptionClassifierSupport.DEFAULT.
classify(Throwable) - Method in class org.springframework.batch.support.SubclassExceptionClassifier
Return the value from the type map whose key is the class of the given Throwable, or its nearest ancestor if a subclass.
clear() - Method in class org.springframework.batch.item.adapter.ItemWriterAdapter
 
clear() - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
clear() - Method in class org.springframework.batch.item.database.AbstractTransactionalResourceItemWriter
Delegate to subclass and unbind transactional resources, effectively clearing the item buffer.
clear() - Method in class org.springframework.batch.item.file.FlatFileItemWriter
 
clear() - Method in interface org.springframework.batch.item.ItemWriter
Clear any buffers that are being held.
clear() - Method in class org.springframework.batch.item.support.AbstractItemWriter
 
clear() - Method in class org.springframework.batch.item.support.CompositeItemWriter
 
clear() - Method in class org.springframework.batch.item.support.DelegatingItemWriter
Delegates to ItemWriter.clear()
clear() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Clear the output buffer
clear() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Clear the current context at the end of a batch - should only be used by RepeatOperations implementations.
clear() - Static method in class org.springframework.batch.retry.support.RetrySynchronizationManager
Clear the current context at the end of a batch - should only be used by RepeatOperations implementations.
clearDirtyFlag() - Method in class org.springframework.batch.item.ExecutionContext
Clears the dirty flag.
ClearFailedException - Exception in org.springframework.batch.item
Unchecked exception indicating that an error has occurred while trying to call ItemWriter.clear()
ClearFailedException(String, Throwable) - Constructor for exception org.springframework.batch.item.ClearFailedException
Create a new ClearFailedException based on a message and another exception.
ClearFailedException(String) - Constructor for exception org.springframework.batch.item.ClearFailedException
Create a new ClearFailedException based on a message.
close(ExecutionContext) - Method in class org.springframework.batch.item.database.DrivingQueryItemReader
Close the resource by setting the list of keys to null, allowing them to be garbage collected.
close(ExecutionContext) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
 
close(ExecutionContext) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Close the MultiResourceItemReader.setDelegate(ResourceAwareItemReaderItemStream) reader and reset instance variable values.
close() - Method in interface org.springframework.batch.item.file.separator.LineReader
 
close() - Method in class org.springframework.batch.item.file.separator.ResourceLineReader
Close the reader associated with this input source.
close(ExecutionContext) - Method in interface org.springframework.batch.item.ItemStream
If any resources are needed for the stream to operate they need to be destroyed here.
close(ExecutionContext) - Method in class org.springframework.batch.item.ItemStreamSupport
No-op.
close(ExecutionContext) - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
 
close(ExecutionContext) - Method in class org.springframework.batch.item.support.CompositeItemStream
Broadcast the call to close.
close(ExecutionContext) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Flush and close the output source.
close() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
close(RepeatContext) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
close(RepeatContext) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
close() - Method in interface org.springframework.batch.repeat.RepeatContext
Allow resources to be cleared, especially in destruction callbacks.
close(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatListener
Called once at the end of a complete batch, after normal or abnormal completion (i.e.
close(RetryContext, RetryCallback, Throwable) - Method in class org.springframework.batch.retry.listener.RetryListenerSupport
 
close(RetryContext) - Method in class org.springframework.batch.retry.policy.CompositeRetryPolicy
Delegate to the policies that were in operation when the context was created.
close(RetryContext) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Delegate to the policy currently activated in the context.
close(RetryContext) - Method in class org.springframework.batch.retry.policy.NeverRetryPolicy
Do nothing.
close(RetryContext) - Method in class org.springframework.batch.retry.policy.RecoveryCallbackRetryPolicy
Delegates to the delegate context.
close(RetryContext) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
 
close(RetryContext) - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
 
close(RetryContext, RetryCallback, Throwable) - Method in interface org.springframework.batch.retry.RetryListener
Called after the final attempt (successful or not).
close(RetryContext) - Method in interface org.springframework.batch.retry.RetryPolicy
 
ColumnMapItemPreparedStatementSetter - Class in org.springframework.batch.item.database.support
Implementation of the ItemPreparedStatementSetter interface that assumes all keys are contained within a Map with the column name as the key.
ColumnMapItemPreparedStatementSetter() - Constructor for class org.springframework.batch.item.database.support.ColumnMapItemPreparedStatementSetter
 
commit(Object, Object) - Method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
Take the working copy state and commit it back to the original target.
CompletionPolicy - Interface in org.springframework.batch.repeat
Interface for batch completion policies, to enable batch operations to strategise normal completion conditions.
CompletionPolicySupport - Class in org.springframework.batch.repeat.policy
Very simple base class for CompletionPolicy implementations.
CompletionPolicySupport() - Constructor for class org.springframework.batch.repeat.policy.CompletionPolicySupport
 
CompositeCompletionPolicy - Class in org.springframework.batch.repeat.policy
Composite policy that loops through a list of delegate policies and answers calls by a concensus.
CompositeCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
 
CompositeCompletionPolicy.CompositeBatchContext - Class in org.springframework.batch.repeat.policy
Composite context that knows about the policies and contexts is was created with.
CompositeCompletionPolicy.CompositeBatchContext(RepeatContext, List) - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy.CompositeBatchContext
 
CompositeExceptionHandler - Class in org.springframework.batch.repeat.exception
Composiste ExceptionHandler that loops though a list of delegates.
CompositeExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.CompositeExceptionHandler
 
CompositeItemStream - Class in org.springframework.batch.item.support
Simple ItemStream that delegates to a list of other streams.
CompositeItemStream() - Constructor for class org.springframework.batch.item.support.CompositeItemStream
 
CompositeItemTransformer - Class in org.springframework.batch.item.transform
Composite ItemTransformer that passes the item through a sequence of injected ItemTransformers (return value of previous transformation is the entry value of the next).
CompositeItemTransformer() - Constructor for class org.springframework.batch.item.transform.CompositeItemTransformer
 
CompositeItemWriter - Class in org.springframework.batch.item.support
Calls a collection of ItemWriters in fixed-order sequence.
CompositeItemWriter() - Constructor for class org.springframework.batch.item.support.CompositeItemWriter
 
CompositeRepeatListener - Class in org.springframework.batch.repeat.listener
 
CompositeRepeatListener() - Constructor for class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
CompositeRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that composes a list of other policies and delegates calls to them in order.
CompositeRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.CompositeRetryPolicy
 
containsKey(String) - Method in class org.springframework.batch.item.ExecutionContext
Indicates whether or not a key is represented in this context.
containsKey(Object) - Method in class org.springframework.batch.retry.policy.MapRetryContextCache
 
containsKey(Object) - Method in interface org.springframework.batch.retry.policy.RetryContextCache
 
containsValue(Object) - Method in class org.springframework.batch.item.ExecutionContext
Indicates whether or not a value is represented in this context.
CONTINUABLE - Static variable in class org.springframework.batch.repeat.ExitStatus
Convenient constant value representing unfinished processing.
ConversionException - Exception in org.springframework.batch.item.file.transform
 
ConversionException(String) - Constructor for exception org.springframework.batch.item.file.transform.ConversionException
 
COUNT - Static variable in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Session key for global counter.
CountingCompletionPolicy - Class in org.springframework.batch.repeat.policy
Abstract base class for policies that need to count the number of occurrences of some event (e.g.
CountingCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
CountingCompletionPolicy.CountingBatchContext - Class in org.springframework.batch.repeat.policy
 
CountingCompletionPolicy.CountingBatchContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
 
createBinder(Object) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Create a binder for the target object.
createFieldSet(Object) - Method in class org.springframework.batch.item.file.transform.LineAggregatorItemTransformer
Extension point for subclasses.
createInstance() - Method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createInternalState(RepeatContext) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Create an internal state object that is used to store data needed internally in the scope of an iteration.
createInternalState(RepeatContext) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
 
createTransactionalList() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalMap() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalSet() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 

D

DataFieldMaxValueIncrementerFactory - Interface in org.springframework.batch.item.database.support
Factory for creating DataFieldMaxValueIncrementer implementations based upon a provided string.
DEBUG - Static variable in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Key for ExceptionClassifier signalling that the throwable should be logged at debug level.
DEFAULT - Static variable in class org.springframework.batch.support.ExceptionClassifierSupport
Default classification key.
DEFAULT_CAPACITY - Static variable in class org.springframework.batch.retry.policy.MapRetryContextCache
Default value for maximum capacity of the cache.
DEFAULT_CHARSET - Static variable in class org.springframework.batch.item.file.FlatFileItemReader
 
DEFAULT_CHUNK_SIZE - Static variable in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
DEFAULT_INITIAL_INTERVAL - Static variable in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
The default 'initialInterval' value - 100 millisecs.
DEFAULT_MAX_ATTEMPTS - Static variable in class org.springframework.batch.retry.policy.SimpleRetryPolicy
The default limit to the number of attempts for a new policy.
DEFAULT_MAX_INTERVAL - Static variable in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
The default maximum backoff time (30 seconds).
DEFAULT_MULTIPLIER - Static variable in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
The default 'multiplier' value - value 2 (100% increase per backoff).
DEFAULT_QUOTE_CHARACTER - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Convenient constant for the common case of a " character used to escape delimiters or line endings.
DEFAULT_SUFFIX - Static variable in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Default value for record terminator suffix.
DEFAULT_THROTTLE_LIMIT - Static variable in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Default limit for maximum number of concurrent unfinished results allowed by the template.
DEFAULT_TIMEOUT - Static variable in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Default timeout value in millisecs (the value equivalent to 30 seconds).
DEFAULT_TIMEOUT - Static variable in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
Default value for timeout (milliseconds).
DefaultDataFieldMaxValueIncrementerFactory - Class in org.springframework.batch.item.database.support
Default implementation of the DataFieldMaxValueIncrementerFactory interface.
DefaultDataFieldMaxValueIncrementerFactory(DataSource) - Constructor for class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
DefaultExceptionHandler - Class in org.springframework.batch.repeat.exception
Default implementation of ExceptionHandler - just re-throws the exception it encounters.
DefaultExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.DefaultExceptionHandler
 
DefaultFieldSet - Class in org.springframework.batch.item.file.mapping
Default implementation of FieldSet using Java using Java primitive and standard types and utilities.
DefaultFieldSet(String[]) - Constructor for class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
DefaultFieldSet(String[], String[]) - Constructor for class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
DefaultFragmentEventReader - Class in org.springframework.batch.item.xml.stax
Default implementation of FragmentEventReader
DefaultFragmentEventReader(XMLEventReader) - Constructor for class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
Caches the StartDocument event for later use.
DefaultPropertyEditorRegistrar - Class in org.springframework.batch.support
A re-usable PropertyEditorRegistrar that can be used wherever one needs to register custom PropertyEditor instances with a PropertyEditorRegistry (like a bean wrapper, or a type converter).
DefaultPropertyEditorRegistrar() - Constructor for class org.springframework.batch.support.DefaultPropertyEditorRegistrar
 
DefaultRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
A RecordSeparatorPolicy that treats all lines as record endings, as long as they do not have unterminated quotes, and do not end in a continuation marker.
DefaultRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Default constructor.
DefaultRecordSeparatorPolicy(String) - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Convenient constructor with quote character as parameter.
DefaultRecordSeparatorPolicy(String, String) - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Convenient constructor with quote character and continuation marker as parameters.
DefaultResultCompletionPolicy - Class in org.springframework.batch.repeat.policy
Very simple CompletionPolicy that bases its decision on the result of a batch operation.
DefaultResultCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
 
DefaultTransactionalEventReader - Class in org.springframework.batch.item.xml.stax
Deprecated. no longer used, to be removed in 2.0
DefaultTransactionalEventReader(XMLEventReader) - Constructor for class org.springframework.batch.item.xml.stax.DefaultTransactionalEventReader
Deprecated. Creates instance of this class and wraps XMLEventReader.
DelegatingItemReader - Class in org.springframework.batch.item.support
Simple wrapper around ItemReader.
DelegatingItemReader() - Constructor for class org.springframework.batch.item.support.DelegatingItemReader
Default constructor.
DelegatingItemReader(ItemReader) - Constructor for class org.springframework.batch.item.support.DelegatingItemReader
Convenience constructor for setting mandatory property.
DelegatingItemWriter - Class in org.springframework.batch.item.support
Simple wrapper around ItemWriter.
DelegatingItemWriter() - Constructor for class org.springframework.batch.item.support.DelegatingItemWriter
Default constructor.
DelegatingItemWriter(ItemWriter) - Constructor for class org.springframework.batch.item.support.DelegatingItemWriter
 
DelimitedLineAggregator - Class in org.springframework.batch.item.file.transform
Class used to create string representing object.
DelimitedLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineAggregator
 
DelimitedLineTokenizer - Class in org.springframework.batch.item.file.transform
 
DelimitedLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Create a new instance of the DelimitedLineTokenizer class for the common case where the delimiter is a comma.
DelimitedLineTokenizer(char) - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Create a new instance of the DelimitedLineTokenizer class.
DELIMITER_COMMA - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Convenient constant for the common case of a comma delimiter.
DELIMITER_TAB - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Convenient constant for the common case of a tab delimiter.
deserializeFragment(XMLEventReader) - Method in interface org.springframework.batch.item.xml.EventReaderDeserializer
 
deserializeFragment(XMLEventReader) - Method in class org.springframework.batch.item.xml.oxm.UnmarshallingEventReaderDeserializer
 
doBackOff() - Method in class org.springframework.batch.retry.backoff.FixedBackOffPolicy
Pause for the FixedBackOffPolicy.setBackOffPeriod(long).
doBackOff() - Method in class org.springframework.batch.retry.backoff.NoBackOffPolicy
 
doBackOff() - Method in class org.springframework.batch.retry.backoff.StatelessBackOffPolicy
Sub-classes should implement this method to perform the actual back off.
doBegin(Object, TransactionDefinition) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doClear() - Method in class org.springframework.batch.item.database.AbstractTransactionalResourceItemWriter
Callback method of AbstractTransactionalResourceItemWriter.clear().
doClear() - Method in class org.springframework.batch.item.database.BatchSqlUpdateItemWriter
No-op.
doClear() - Method in class org.springframework.batch.item.database.HibernateAwareItemWriter
Call the delegate clear() method, and then clear the hibernate session.
doClose() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Close the cursor and hibernate session.
doClose() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Close the cursor and database connection.
doClose() - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
doClose() - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
Close the resources opened in AbstractBufferedItemReaderItemStream.doOpen().
doClose() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
doCommit(DefaultTransactionStatus) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doFlush() - Method in class org.springframework.batch.item.database.AbstractTransactionalResourceItemWriter
Callback method of AbstractTransactionalResourceItemWriter.flush().
doFlush() - Method in class org.springframework.batch.item.database.BatchSqlUpdateItemWriter
Create and execute batch prepared statement.
doFlush() - Method in class org.springframework.batch.item.database.HibernateAwareItemWriter
Delegate to subclass and flush the hibernate session.
doGetTransaction() - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doInIteration(RepeatContext) - Method in class org.springframework.batch.repeat.callback.ItemReaderRepeatCallback
Use the writer to process the next item if there is one.
doInIteration(RepeatContext) - Method in class org.springframework.batch.repeat.callback.NestedRepeatCallback
Simply calls template.execute(callback).
doInIteration(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatCallback
Implementations return true if they can continue processing - e.g.
doOpen() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Open hibernate session and create a forward-only cursor for the HibernateCursorItemReader.setQueryString(String).
doOpen() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Execute the JdbcCursorItemReader.setSql(String) query.
doOpen() - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
doOpen() - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
Open resources necessary to start reading input.
doOpen() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
doProcess(Object) - Method in class org.springframework.batch.item.support.DelegatingItemWriter
By default returns the argument.
doProcess(Object) - Method in class org.springframework.batch.item.transform.ItemTransformerItemWriter
Transform the item using the ItemTransformerItemWriter.setItemTransformer(ItemTransformer).
doRead() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
 
doRead() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Read next row and map it to item, verify cursor position if JdbcCursorItemReader.setVerifyCursorPosition(boolean) is true.
doRead() - Method in class org.springframework.batch.item.file.FlatFileItemReader
Reads a line from input, tokenizes is it using the FlatFileItemReader.setLineTokenizer(LineTokenizer) and maps to domain object using FlatFileItemReader.setFieldSetMapper(FieldSetMapper).
doRead() - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
Read next item from input.
doRead() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
Move to next fragment and map it to item.
doRollback(DefaultTransactionStatus) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doTokenize(String) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
doTokenize(String) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
doTokenize(String) - Method in class org.springframework.batch.item.file.transform.FixedLengthTokenizer
Yields the tokens resulting from the splitting of the supplied line.
doUpdate(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Extension point for subclasses.
doWithRetry(RetryContext) - Method in class org.springframework.batch.retry.callback.RecoveryRetryCallback
 
doWithRetry(RetryContext) - Method in interface org.springframework.batch.retry.RetryCallback
Execute an operation with retry semantics.
doWrite(Object) - Method in class org.springframework.batch.item.database.AbstractTransactionalResourceItemWriter
Callback method of AbstractTransactionalResourceItemWriter.write(Object).
doWrite(Object) - Method in class org.springframework.batch.item.database.BatchSqlUpdateItemWriter
No-op.
doWrite(Object) - Method in class org.springframework.batch.item.database.HibernateAwareItemWriter
 
DrivingQueryItemReader - Class in org.springframework.batch.item.database
Convenience class for driving query item readers.
DrivingQueryItemReader() - Constructor for class org.springframework.batch.item.database.DrivingQueryItemReader
 
DrivingQueryItemReader(List) - Constructor for class org.springframework.batch.item.database.DrivingQueryItemReader
Initialize the input source with the provided keys list.
DynamicMethodInvocationException - Exception in org.springframework.batch.item.adapter
Indicates an error has been encountered while trying to dynamically call a method e.g.
DynamicMethodInvocationException(Throwable) - Constructor for exception org.springframework.batch.item.adapter.DynamicMethodInvocationException
 
DynamicMethodInvocationException(String, Throwable) - Constructor for exception org.springframework.batch.item.adapter.DynamicMethodInvocationException
 

E

END_RECORD - Static variable in class org.springframework.batch.item.support.AggregateItemReader
Marker for the end of a multi-object record.
endDocument(XMLEventWriter) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Writes the EndDocument tag manually.
entrySet() - Method in class org.springframework.batch.item.ExecutionContext
Returns the entry set containing the contents of this context.
equals(Object) - Method in class org.springframework.batch.item.ExecutionContext
 
equals(Object) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
equals(Object) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
equals(Object) - Method in class org.springframework.batch.repeat.ExitStatus
Compare the fields one by one.
ERROR - Static variable in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Key for ExceptionClassifier signalling that the throwable should be logged at error level.
EventReaderDeserializer - Interface in org.springframework.batch.item.xml
Deserializes XML fragment to domain object.
EventWriterSerializer - Interface in org.springframework.batch.item.xml
Interface wrapping the serialization of an object to xml.
ExceptionClassifier - Interface in org.springframework.batch.support
Interface for a classifier of exceptions.
ExceptionClassifierRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that dynamically adapts to one of a set of injected policies according to the value of the latest exception.
ExceptionClassifierRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
 
ExceptionClassifierSupport - Class in org.springframework.batch.support
Base class for ExceptionClassifier implementations.
ExceptionClassifierSupport() - Constructor for class org.springframework.batch.support.ExceptionClassifierSupport
 
ExceptionHandler - Interface in org.springframework.batch.repeat.exception
Handler to allow strategies for re-throwing exceptions.
execute(RetryCallback) - Method in interface org.springframework.batch.retry.RetryOperations
Execute the supplied RetryCallback with the configured retry semantics.
execute(RetryCallback) - Method in class org.springframework.batch.retry.support.RetryTemplate
Keep executing the callback until it either succeeds or the policy dictates that we stop, in which case the most recent exception thrown by the callback will be rethrown.
executeAfterInterceptors(RepeatContext, ExitStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Convenience method to execute after interceptors on a callback result.
ExecutionContext - Class in org.springframework.batch.item
Object representing a context for an ItemStream.
ExecutionContext() - Constructor for class org.springframework.batch.item.ExecutionContext
Default constructor.
ExecutionContext(Map) - Constructor for class org.springframework.batch.item.ExecutionContext
Initializes a new execution context with the contents of another map.
ExecutionContext(ExecutionContext) - Constructor for class org.springframework.batch.item.ExecutionContext
 
ExecutionContextUserSupport - Class in org.springframework.batch.item.util
Facilitates assigning names to objects persisting data in ExecutionContext and generating keys for ExecutionContext based on the name.
ExecutionContextUserSupport() - Constructor for class org.springframework.batch.item.util.ExecutionContextUserSupport
 
EXHAUSTED - Static variable in class org.springframework.batch.retry.policy.RecoveryCallbackRetryPolicy
 
ExhaustedRetryException - Exception in org.springframework.batch.retry
 
ExhaustedRetryException(String, Throwable) - Constructor for exception org.springframework.batch.retry.ExhaustedRetryException
 
ExhaustedRetryException(String) - Constructor for exception org.springframework.batch.retry.ExhaustedRetryException
 
ExitStatus - Class in org.springframework.batch.repeat
Value object used to carry information about the status of a RepeatOperations.
ExitStatus(boolean) - Constructor for class org.springframework.batch.repeat.ExitStatus
 
ExitStatus(boolean, String) - Constructor for class org.springframework.batch.repeat.ExitStatus
 
ExitStatus(boolean, String, String) - Constructor for class org.springframework.batch.repeat.ExitStatus
 
ExponentialBackOffPolicy - Class in org.springframework.batch.retry.backoff
Implementation of BackOffPolicy that increases the back off period for each retry attempt in a given set using the exponential function.
ExponentialBackOffPolicy() - Constructor for class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
 

F

FAILED - Static variable in class org.springframework.batch.repeat.ExitStatus
Convenient constant value representing finished processing with an error.
FieldSet - Interface in org.springframework.batch.item.file.mapping
Interface used by flat file input sources to encapsulate concerns of converting an array of Strings to Java native types.
FieldSetCreator - Interface in org.springframework.batch.item.file.mapping
Strategy interface for mapping between arbitrary objects and FieldSet.
FieldSetMapper - Interface in org.springframework.batch.item.file.mapping
Interface that is used to map data obtained from a FieldSet into an object.
FileUtils - Class in org.springframework.batch.item.util
Utility methods for files used in batch processing.
FINISHED - Static variable in class org.springframework.batch.repeat.ExitStatus
Convenient constant value representing finished processing.
FixedBackOffPolicy - Class in org.springframework.batch.retry.backoff
Implementation of BackOffPolicy that pauses for a fixed period of time before continuing.
FixedBackOffPolicy() - Constructor for class org.springframework.batch.retry.backoff.FixedBackOffPolicy
 
FixedLengthLineAggregator - Class in org.springframework.batch.item.file.transform
LineAggregator implementation which produces line by aggregating provided strings into columns with fixed length.
FixedLengthLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.FixedLengthLineAggregator
 
FixedLengthTokenizer - Class in org.springframework.batch.item.file.transform
Tokenizer used to process data obtained from files with fixed-length format.
FixedLengthTokenizer() - Constructor for class org.springframework.batch.item.file.transform.FixedLengthTokenizer
 
FlatFileFormatException - Exception in org.springframework.batch.item.file.transform
Exception indicating that some type of error has occured while attempting to parse a line of input into tokens.
FlatFileFormatException(String) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
Create a new FlatFileFormatException based on a message.
FlatFileFormatException(String, Throwable) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
Create a new FlatFileFormatException based on a message and another exception.
FlatFileItemReader - Class in org.springframework.batch.item.file
This class represents a ItemReader, that reads lines from text file, tokenizes them to structured tuples (FieldSets) instances and maps the FieldSets to domain objects.
FlatFileItemReader() - Constructor for class org.springframework.batch.item.file.FlatFileItemReader
 
FlatFileItemWriter - Class in org.springframework.batch.item.file
This class is an item writer that writes data to a file or stream.
FlatFileItemWriter() - Constructor for class org.springframework.batch.item.file.FlatFileItemWriter
 
FlatFileParseException - Exception in org.springframework.batch.item.file
Exception thrown when errors are encountered parsing flat files.
FlatFileParseException(String, String) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
 
FlatFileParseException(String, String, int) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
 
FlatFileParseException(String, Throwable, String, int) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
 
flush() - Method in class org.springframework.batch.item.adapter.ItemWriterAdapter
 
flush() - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
flush() - Method in class org.springframework.batch.item.database.AbstractTransactionalResourceItemWriter
Flushing delegated to subclass surrounded by binding and unbinding of transactional resources.
flush() - Method in class org.springframework.batch.item.file.FlatFileItemWriter
 
flush() - Method in interface org.springframework.batch.item.ItemWriter
Flush any buffers that are being held.
flush() - Method in class org.springframework.batch.item.support.AbstractItemWriter
 
flush() - Method in class org.springframework.batch.item.support.CompositeItemWriter
 
flush() - Method in class org.springframework.batch.item.support.DelegatingItemWriter
Delegates to ItemWriter.flush()
flush() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Writes buffered items to XML stream and marks restore point.
FlushFailedException - Exception in org.springframework.batch.item
Unchecked exception indicating that an error has occurred while trying to call ItemWriter.flush()
FlushFailedException(String, Throwable) - Constructor for exception org.springframework.batch.item.FlushFailedException
Create a new FlushFailedException based on a message and another exception.
FlushFailedException(String) - Constructor for exception org.springframework.batch.item.FlushFailedException
Create a new FlushFailedException based on a message.
FragmentEventReader - Interface in org.springframework.batch.item.xml.stax
Interface for event readers which support treating XML fragments as standalone XML documents by wrapping the fragments with StartDocument and EndDocument events.

G

get(String) - Method in class org.springframework.batch.item.ExecutionContext
Getter for the value represented by the provided key.
get(Object) - Method in class org.springframework.batch.retry.policy.MapRetryContextCache
 
get(Object) - Method in interface org.springframework.batch.retry.policy.RetryContextCache
 
getAbortCount() - Method in interface org.springframework.batch.retry.RetryStatistics
Get the number of times a block failed to complete successfully, even after retry.
getActualCount() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
getActualLength() - Method in exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
getAsText() - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
getAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
getCompleteCount() - Method in interface org.springframework.batch.retry.RetryStatistics
 
getContext() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Getter for the current context.
getContext() - Static method in class org.springframework.batch.retry.support.RetrySynchronizationManager
Public accessor for the locally enclosing RetryContext.
getCount() - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
 
getCount(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Extension point for subclasses.
getCounter() - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
 
getCurrentItemCount() - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
 
getCurrentKey() - Method in class org.springframework.batch.item.database.DrivingQueryItemReader
Get the current key.
getDefault() - Method in interface org.springframework.batch.support.ExceptionClassifier
Get a default value, normally the same as would be returned by ExceptionClassifier.classify(Throwable) with null argument.
getDefault() - Method in class org.springframework.batch.support.ExceptionClassifierSupport
Wrapper for a call to ExceptionClassifierSupport.classify(Throwable) with argument null.
getDouble(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Double represented by the provided key.
getDouble(String, double) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Double represented by the provided key with default value to return if key is not represented.
getEncoding() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get used encoding.
getErrorCount() - Method in interface org.springframework.batch.retry.RetryStatistics
Get the number of errors detected, whether or not they resulted in a retry.
getExceptionTranslator() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Return the exception translator for this instance.
getExitCode() - Method in class org.springframework.batch.repeat.ExitStatus
Getter for the exit code (defaults to blank).
getExitDescription() - Method in class org.springframework.batch.repeat.ExitStatus
Getter for the exit description (defaults to blank)
getExpectedCount() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
getExpectedLength() - Method in exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
getFieldCount() - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
getFieldCount() - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Return the number of fields in this 'FieldSet'.
getIncrementer(String, String) - Method in interface org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
Return the DataFieldMaxValueIncrementer for the provided database type.
getIncrementer(String, String) - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
getInput() - Method in exception org.springframework.batch.item.file.FlatFileParseException
 
getItem() - Method in class org.springframework.batch.retry.callback.RecoveryRetryCallback
 
getKey(Object) - Method in interface org.springframework.batch.item.ItemKeyGenerator
Get a unique identifier for the item that can be used to cache it between calls if necessary, and then identify it later.
getKey(Object) - Method in class org.springframework.batch.item.jms.JmsItemReader
If the message is a Message then returns the JMS message ID.
getKey(String) - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
Prefix the argument with the name of the item stream to create a unique key that can be safely used to identify data stored in ExecutionContext.
getKey() - Method in class org.springframework.batch.retry.callback.RecoveryRetryCallback
Public getter for the key.
getLastThrowable() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
getLastThrowable() - Method in interface org.springframework.batch.retry.RetryContext
Accessor for the exception object that caused the current retry.
getLineNumber() - Method in exception org.springframework.batch.item.file.FlatFileParseException
 
getLong(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Long represented by the provided key.
getLong(String, long) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Long represented by the provided key with default value to return if key is not represented.
getMax() - Method in class org.springframework.batch.item.file.transform.Range
 
getMin() - Method in class org.springframework.batch.item.file.transform.Range
 
getName() - Method in interface org.springframework.batch.retry.RetryStatistics
Get an identifier for the retry block for reporting purposes.
getNames() - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
getNames() - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Accessor for the names of the fields.
getNextResult(RepeatContext, RepeatCallback, RepeatInternalState) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Get the next completed result, possibly executing several callbacks until one finally finishes.
getNextResult(RepeatContext, RepeatCallback, RepeatInternalState) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Use the TaskExecutorRepeatTemplate.setTaskExecutor(TaskExecutor) to generate a result.
getParent() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
getParent() - Method in interface org.springframework.batch.repeat.RepeatContext
If batches are nested, then the inner batch will be created with the outer one as a parent.
getParent() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
getParent() - Method in interface org.springframework.batch.retry.RetryContext
Accessor for the parent context if retry blocks are nested.
getPosition() - Method in interface org.springframework.batch.item.file.separator.LineReader
 
getPosition() - Method in class org.springframework.batch.item.file.separator.ResourceLineReader
Getter for current line count (not the current number of lines returned).
getProcessed() - Method in class org.springframework.batch.item.database.AbstractTransactionalResourceItemWriter
Accessor for the list of processed items in this transaction.
getProperties() - Method in class org.springframework.batch.item.ExecutionContext
Deprecated. to be removed with no replacement in 2.0. Should not be part of public API (test purposes only)
getProperties() - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
getProperties() - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Construct name-value pairs from the field names and string values.
getReader() - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
getRecoveryCallback() - Method in class org.springframework.batch.retry.callback.RecoveryRetryCallback
Accessor for the RecoveryCallback.
getResourceKey() - Method in class org.springframework.batch.item.database.AbstractTransactionalResourceItemWriter
 
getResourceKey() - Method in class org.springframework.batch.item.database.BatchSqlUpdateItemWriter
 
getResourceKey() - Method in class org.springframework.batch.item.database.HibernateAwareItemWriter
 
getRetryCount() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
getRetryCount() - Method in interface org.springframework.batch.retry.RetryContext
Counts the number of retry attempts.
getRootElementAttributes() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get attributes of the root element.
getRootTagName() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get the tag name of the root element.
getSqlMapClientTemplate() - Method in class org.springframework.batch.item.database.support.IbatisKeyCollector
 
getStartedCount() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
getStartedCount() - Method in interface org.springframework.batch.repeat.RepeatContext
Public access to a counter for the number of operations attempted.
getStartedCount() - Method in interface org.springframework.batch.retry.RetryStatistics
Get the number of times a retry block has been entered, irrespective of how many times the operation was retried.
getString(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the String represented by the provided key.
getString(String, String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the String represented by the provided key with default value to return if key is not represented.
getSupportedIncrementerTypes() - Method in interface org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
Returns the list of supported database incrementer types
getSupportedIncrementerTypes() - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
getThrowables() - Method in interface org.springframework.batch.repeat.support.RepeatInternalState
 
getThrowables() - Method in class org.springframework.batch.repeat.support.RepeatInternalStateSupport
 
getValues() - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
getValues() - Method in interface org.springframework.batch.item.file.mapping.FieldSet
 
getVersion() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get XML version.

H

handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.CompositeExceptionHandler
Iterate over the handlers delegating the call to each in turn.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.DefaultExceptionHandler
Re-throw the throwable.
handleException(RepeatContext, Throwable) - Method in interface org.springframework.batch.repeat.exception.ExceptionHandler
Deal with a Throwable during a batch - decide whether it should be re-thrown in the first place.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Classify the throwables and decide whether to rethrow based on the result.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Classify the throwables and decide whether to re-throw based on the result.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Rethrows only if the limit is breached for this context on the exception type specified.
handleRetryExhausted(RetryContext) - Method in class org.springframework.batch.retry.policy.AbstractStatefulRetryPolicy
Return null.
handleRetryExhausted(RetryContext) - Method in class org.springframework.batch.retry.policy.AbstractStatelessRetryPolicy
Throw an exception.
handleRetryExhausted(RetryContext) - Method in class org.springframework.batch.retry.policy.RecoveryCallbackRetryPolicy
Call recovery path (if any) and clean up context history.
handleRetryExhausted(RetryContext) - Method in interface org.springframework.batch.retry.RetryPolicy
Handle an exhausted retry.
hasAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
hashCode() - Method in class org.springframework.batch.item.ExecutionContext
 
hashCode() - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
hashCode() - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
hashCode() - Method in class org.springframework.batch.repeat.ExitStatus
Compatible with the equals implementation.
hasMaxValue() - Method in class org.springframework.batch.item.file.transform.Range
 
hasNames() - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
hasNames() - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Check if there are names defined for the fields.
hasNames() - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
hasNext() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
hasNext() - Method in class org.springframework.batch.item.xml.stax.DefaultTransactionalEventReader
Deprecated. Check if there are more events.
HibernateAwareItemWriter - Class in org.springframework.batch.item.database
ItemWriter that is aware of the Hibernate session and can take some responsibilities to do with chunk boundaries away from a less smart ItemWriter (the delegate).
HibernateAwareItemWriter() - Constructor for class org.springframework.batch.item.database.HibernateAwareItemWriter
 
HibernateCursorItemReader - Class in org.springframework.batch.item.database
ItemReader for reading database records built on top of Hibernate.
HibernateCursorItemReader() - Constructor for class org.springframework.batch.item.database.HibernateCursorItemReader
 

I

IbatisDrivingQueryItemReader - Class in org.springframework.batch.item.database
Extension of DrivingQueryItemReader that maps keys to objects.
IbatisDrivingQueryItemReader() - Constructor for class org.springframework.batch.item.database.IbatisDrivingQueryItemReader
 
IbatisKeyCollector - Class in org.springframework.batch.item.database.support
KeyCollector based on iBATIS ORM framework.
IbatisKeyCollector() - Constructor for class org.springframework.batch.item.database.support.IbatisKeyCollector
 
IncorrectLineLengthException - Exception in org.springframework.batch.item.file.transform
Exception indicating that the line size expected is different from what is expected.
IncorrectLineLengthException(String, int, int) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
IncorrectLineLengthException(int, int) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
IncorrectTokenCountException - Exception in org.springframework.batch.item.file.transform
Exception indicating that an incorrect number of tokens have been found while parsing a file.
IncorrectTokenCountException(String, int, int) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
IncorrectTokenCountException(int, int) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
increment(int) - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
Increment the counter.
increment() - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
Increment by 1.
increment() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
Used by clients to increment the started count.
indexOf(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
Read and trim the String value from column with given 'name.
initBinder(DataBinder) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Initialize a new binder instance.
IntArrayPropertyEditor - Class in org.springframework.batch.support
 
IntArrayPropertyEditor() - Constructor for class org.springframework.batch.support.IntArrayPropertyEditor
 
invoke(MethodInvocation) - Method in class org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
Invoke the proceeding method call repeatedly, according to the properties of the injected RepeatOperations.
invoke(MethodInvocation) - Method in class org.springframework.batch.retry.interceptor.RetryOperationsInterceptor
 
invoke(MethodInvocation) - Method in class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
Wrap the method invocation in a stateful retry with the policy and other helpers provided.
invokeDelegateMethod() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Invoker the target method with no arguments.
invokeDelegateMethodWithArgument(Object) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Invokes the target method with given argument.
invokeDelegateMethodWithArguments(Object[]) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Invokes the target method with given arguments.
isComplete(RepeatContext, ExitStatus) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Determine whether a batch is complete given the latest result from the callback.
isComplete(RepeatContext) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Allow policy to signal completion according to internal state, without having to wait for the callback to complete.
isComplete(RepeatContext, ExitStatus) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
Return true if exit status is not continuable, otherwise delegate to CompletionPolicySupport.isComplete(RepeatContext).
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
Always true.
isComplete(RepeatContext, ExitStatus) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
This policy is complete if any of the composed policies is complete.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
This policy is complete if any of the composed policies is complete.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
isComplete(RepeatContext, ExitStatus) - Method in class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
True if the result is null, or a ExitStatus indicating completion.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
Always false.
isComplete(RepeatContext, ExitStatus) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Terminate if the chunk size has been reached, or the result is null.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Terminate if the chunk size has been reached.
isComplete() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Check the timeout and complete gracefully if it has expires.
isComplete() - Method in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy.TimeoutBatchContext
 
isComplete(RepeatContext, ExitStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to CompletionPolicy.
isCompleteOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
isCompleteOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Public accessor for the complete flag.
isContinuable() - Method in class org.springframework.batch.repeat.ExitStatus
Flag to signal that processing can continue.
isDefault(Throwable) - Method in class org.springframework.batch.support.BinaryExceptionClassifier
Convenience method to return boolean if the throwable is classified as default.
isDirty() - Method in class org.springframework.batch.item.ExecutionContext
Indicates if context has been changed with a "put" operation since the dirty flag was last cleared.
isEmpty() - Method in class org.springframework.batch.item.ExecutionContext
Indicates whether or not the context is empty.
isEndOfRecord(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Return true if the line does not have unterminated quotes (delimited by "), and does not end with a continuation marker ('\').
isEndOfRecord(String) - Method in interface org.springframework.batch.item.file.separator.RecordSeparatorPolicy
Signal the end of a record based on the content of a line, being the latest line read from an input source.
isEndOfRecord(String) - Method in class org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
Always returns true.
isEndOfRecord(String) - Method in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Return true if the line ends with the specified substring.
isExhaustedOnly() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
isExhaustedOnly() - Method in interface org.springframework.batch.retry.RetryContext
Public accessor for the exhausted flag RetryContext.setExhaustedOnly().
isForceRefresh() - Method in class org.springframework.batch.retry.callback.RecoveryRetryCallback
 
isNew(Object) - Method in class org.springframework.batch.item.jms.JmsItemReader
If the item is a message, check the JMS re-delivered flag, otherwise return false to be on the safe side.
isNew(Object) - Method in interface org.springframework.batch.item.NewItemIdentifier
Inspect the item and determine if it has never been processed before.
isQuoteCharacter(char) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Is the supplied character a quote character?
isRunning() - Method in class org.springframework.batch.repeat.ExitStatus
Check if this status represents a running process.
isSupportedIncrementerType(String) - Method in interface org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
Returns boolean indicated whether or not the provided string is supported by this factory.
isSupportedIncrementerType(String) - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
isTerminateOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
isTerminateOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Public accessor for the termination flag.
ItemKeyGenerator - Interface in org.springframework.batch.item
Extension of the ItemReader interface that allows items to be identified and tagged by a unique key.
ItemPreparedStatementSetter - Interface in org.springframework.batch.item.database
A convenient strategy for SQL updates, acting effectively as the inverse of RowMapper.
ItemReader - Interface in org.springframework.batch.item
Strategy interface for providing the data.
ItemReaderAdapter - Class in org.springframework.batch.item.adapter
Invokes a custom method on a delegate plain old Java object which itself provides an item.
ItemReaderAdapter() - Constructor for class org.springframework.batch.item.adapter.ItemReaderAdapter
 
ItemReaderException - Exception in org.springframework.batch.item
A base exception class that all exceptions thrown from an ItemReader extend.
ItemReaderException(String, Throwable) - Constructor for exception org.springframework.batch.item.ItemReaderException
Create a new ItemReaderException based on a message and another exception.
ItemReaderException(String) - Constructor for exception org.springframework.batch.item.ItemReaderException
Create a new ItemReaderException based on a message.
ItemReaderRepeatCallback - Class in org.springframework.batch.repeat.callback
Simple wrapper for two business interfaces: get the next item from a reader and apply the given writer to the result (if not null).
ItemReaderRepeatCallback(ItemReader, ItemWriter) - Constructor for class org.springframework.batch.repeat.callback.ItemReaderRepeatCallback
 
ItemReaderRepeatCallback(ItemReader) - Constructor for class org.springframework.batch.repeat.callback.ItemReaderRepeatCallback
Default writer is null, in which case we do nothing - subclasses can extend this behaviour, but must be careful to actually exhaust the provider by calling next().
ItemRecoverer - Interface in org.springframework.batch.item
Strategy interface for recovery action when processing of an item fails.
ItemStream - Interface in org.springframework.batch.item
Marker interface defining a contract for periodically storing state and restoring from that state should an error occur.
ItemStreamException - Exception in org.springframework.batch.item
Exception representing any errors encountered while processing a stream.
ItemStreamException(String) - Constructor for exception org.springframework.batch.item.ItemStreamException
 
ItemStreamException(String, Throwable) - Constructor for exception org.springframework.batch.item.ItemStreamException
Constructs a new instance with a message and nested exception.
ItemStreamException(Throwable) - Constructor for exception org.springframework.batch.item.ItemStreamException
Constructs a new instance with a nested exception and empty message.
ItemStreamSupport - Class in org.springframework.batch.item
Empty method implementation of ItemStream.
ItemStreamSupport() - Constructor for class org.springframework.batch.item.ItemStreamSupport
 
ItemTransformer - Interface in org.springframework.batch.item.transform
Interface for item transformations during processing phase.
ItemTransformerItemWriter - Class in org.springframework.batch.item.transform
Transforms the item using injected ItemTransformer before it is written to output by ItemWriter.
ItemTransformerItemWriter() - Constructor for class org.springframework.batch.item.transform.ItemTransformerItemWriter
 
ItemWriter - Interface in org.springframework.batch.item
Basic interface for generic output operations.
ItemWriterAdapter - Class in org.springframework.batch.item.adapter
Delegates item processing to a custom method - passes the item as an argument for the delegate method.
ItemWriterAdapter() - Constructor for class org.springframework.batch.item.adapter.ItemWriterAdapter
 
ItemWriterException - Exception in org.springframework.batch.item
A base exception class that all exceptions thrown from an ItemWriter extend.
ItemWriterException(String, Throwable) - Constructor for exception org.springframework.batch.item.ItemWriterException
Create a new ItemWriterException based on a message and another exception.
ItemWriterException(String) - Constructor for exception org.springframework.batch.item.ItemWriterException
Create a new ItemWriterException based on a message.
iterate(RepeatCallback) - Method in interface org.springframework.batch.repeat.RepeatOperations
Execute the callback repeatedly, until a decision can be made to complete.
iterate(RepeatCallback) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Execute the batch callback until the completion policy decides that we are finished.

J

JdbcCursorItemReader - Class in org.springframework.batch.item.database
Simple item reader that opens a JDBC cursor and continually retrieves the next row in the ResultSet.
JdbcCursorItemReader() - Constructor for class org.springframework.batch.item.database.JdbcCursorItemReader
 
JmsItemReader - Class in org.springframework.batch.item.jms
An ItemReader for JMS using a JmsTemplate.
JmsItemReader() - Constructor for class org.springframework.batch.item.jms.JmsItemReader
 
jumpToItem(int) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Use ResultSet.absolute(int) if possible, otherwise scroll by calling ResultSet.next().
jumpToItem(int) - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
Move to the given item index.

K

KeyCollector - Interface in org.springframework.batch.item.database
Strategy interface used to collect keys in driving query input.

L

LEFT - Static variable in class org.springframework.batch.item.file.transform.Alignment
 
LineAggregator - Interface in org.springframework.batch.item.file.transform
Interface used to create string used to create string representing object.
LineAggregatorItemTransformer - Class in org.springframework.batch.item.file.transform
An ItemTransformer that expects a String[] as input and delegates to a LineAggregator.
LineAggregatorItemTransformer() - Constructor for class org.springframework.batch.item.file.transform.LineAggregatorItemTransformer
 
LineReader - Interface in org.springframework.batch.item.file.separator
 
LineTokenizer - Interface in org.springframework.batch.item.file.transform
Interface that is used by framework to split string obtained typically from a file into tokens.
ListItemReader - Class in org.springframework.batch.item.support
An ItemReader that pulls data from a list.
ListItemReader(List) - Constructor for class org.springframework.batch.item.support.ListItemReader
 
logger - Variable in class org.springframework.batch.item.jms.JmsItemReader
 
logger - Variable in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
 
logger - Variable in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
 
logger - Variable in class org.springframework.batch.repeat.support.RepeatTemplate
 
logger - Variable in class org.springframework.batch.retry.policy.RecoveryCallbackRetryPolicy
 
logger - Variable in class org.springframework.batch.retry.support.RetryTemplate
 
LogOrRethrowExceptionHandler - Class in org.springframework.batch.repeat.exception
Implementation of ExceptionHandler based on an ExceptionClassifier.
LogOrRethrowExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
 

M

mapItem(Object) - Method in interface org.springframework.batch.item.file.mapping.FieldSetCreator
 
mapItem(Object) - Method in class org.springframework.batch.item.file.mapping.PassThroughFieldSetMapper
If the input is a FieldSet pass it to the caller.
mapLine(FieldSet) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Map the DefaultFieldSet to an object retrieved from the enclosing Spring context, or to a new instance of the required type if no prototype is available.
mapLine(FieldSet) - Method in interface org.springframework.batch.item.file.mapping.FieldSetMapper
Method used to map data obtained from a FieldSet into an object.
mapLine(FieldSet) - Method in class org.springframework.batch.item.file.mapping.PassThroughFieldSetMapper
 
MapRetryContextCache - Class in org.springframework.batch.retry.policy
Map-based implementation of RetryContextCache.
MapRetryContextCache() - Constructor for class org.springframework.batch.retry.policy.MapRetryContextCache
Create a MapRetryContextCache with default capacity.
MapRetryContextCache(int) - Constructor for class org.springframework.batch.retry.policy.MapRetryContextCache
 
mark() - Method in class org.springframework.batch.item.adapter.ItemReaderAdapter
No-op.
mark() - Method in class org.springframework.batch.item.database.DrivingQueryItemReader
Mark is supported as long as this ItemStream is used in a single-threaded environment.
mark() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Mark is supported as long as this ItemStream is used in a single-threaded environment.
mark() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Remove the longer needed items from buffer, mark the index position and call mark() on delegate so that it clears its buffers.
mark() - Method in class org.springframework.batch.item.file.separator.ResourceLineReader
Mark the state for return later with reset.
mark() - Method in interface org.springframework.batch.item.ItemReader
Mark the stream so that it can be reset later and the items backed out.
Mark is called before reading a new chunk of items - in case of rollback mark will not be called again before re-processing the chunk.
mark() - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
Mark is supported as long as this ItemStream is used in a single-threaded environment.
mark() - Method in class org.springframework.batch.item.support.AbstractItemReader
 
mark() - Method in class org.springframework.batch.item.support.DelegatingItemReader
 
MarkFailedException - Exception in org.springframework.batch.item
An exception class thrown when an ItemReader fails to mark its current state for future retry.
MarkFailedException(String) - Constructor for exception org.springframework.batch.item.MarkFailedException
Create a new MarkFailedException based on a message.
MarkFailedException(String, Throwable) - Constructor for exception org.springframework.batch.item.MarkFailedException
Create a new MarkFailedException based on a message and another exception.
markFragmentProcessed() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
Finishes reading the fragment in case the fragment was processed without being read until the end.
markFragmentProcessed() - Method in interface org.springframework.batch.item.xml.stax.FragmentEventReader
Tells the event reader the current fragment has been processed.
markStartFragment() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
markStartFragment() - Method in interface org.springframework.batch.item.xml.stax.FragmentEventReader
Tells the event reader its cursor position is exactly before the fragment.
MarshallingEventWriterSerializer - Class in org.springframework.batch.item.xml.oxm
Object to xml serializer that wraps a Spring OXM Marshaller object.
MarshallingEventWriterSerializer(Marshaller) - Constructor for class org.springframework.batch.item.xml.oxm.MarshallingEventWriterSerializer
 
moveCursorToNextFragment(XMLEventReader) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
Responsible for moving the cursor before the StartElement of the fragment root.
MultipleColumnJdbcKeyCollector - Class in org.springframework.batch.item.database.support
JDBC implementation of the KeyCollector interface that works for composite keys.
MultipleColumnJdbcKeyCollector() - Constructor for class org.springframework.batch.item.database.support.MultipleColumnJdbcKeyCollector
 
MultipleColumnJdbcKeyCollector(JdbcTemplate, String) - Constructor for class org.springframework.batch.item.database.support.MultipleColumnJdbcKeyCollector
Construct a new ItemReader.
MultiResourceItemReader - Class in org.springframework.batch.item.file
Reads items from multiple resources sequentially - resource list is given by MultiResourceItemReader.setResources(Resource[]), the actual reading is delegated to MultiResourceItemReader.setDelegate(ResourceAwareItemReaderItemStream).
MultiResourceItemReader() - Constructor for class org.springframework.batch.item.file.MultiResourceItemReader
 

N

names - Variable in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
NestedRepeatCallback - Class in org.springframework.batch.repeat.callback
Callback that delegates to another callback, via a RepeatOperations instance.
NestedRepeatCallback(RepeatOperations, RepeatCallback) - Constructor for class org.springframework.batch.repeat.callback.NestedRepeatCallback
Constructor setting mandatory fields.
NeverRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that allows the first attempt but never permits a retry.
NeverRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.NeverRetryPolicy
 
NewItemIdentifier - Interface in org.springframework.batch.item
Strategy interface to distinguish a new item from one that has been processed before and one that has not, e.g.
next() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
nextEvent() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
nextEvent() - Method in class org.springframework.batch.item.xml.stax.DefaultTransactionalEventReader
Deprecated. Get the next XMLEvent
NoBackOffPolicy - Class in org.springframework.batch.retry.backoff
Implementation of BackOffPolicy that performs a no-op and as such all retry operation in a given set proceed one after the other with no pause.
NoBackOffPolicy() - Constructor for class org.springframework.batch.retry.backoff.NoBackOffPolicy
 
NON_DEFAULT - Static variable in class org.springframework.batch.support.BinaryExceptionClassifier
The classifier result for a non-default exception.
NOOP - Static variable in class org.springframework.batch.repeat.ExitStatus
Convenient constant value representing job that did no processing (e.g.
NoStartEndDocumentStreamWriter - Class in org.springframework.batch.item.xml.stax
Delegating XMLEventWriter, which ignores start and end document events, but passes through everything else.
NoStartEndDocumentStreamWriter(XMLEventWriter) - Constructor for class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
 
NoWorkFoundException - Exception in org.springframework.batch.item
Exception indicating no work was found - e.g.
NoWorkFoundException(String) - Constructor for exception org.springframework.batch.item.NoWorkFoundException
Create a new NoWorkFoundException based on a message.
NoWorkFoundException(String, Throwable) - Constructor for exception org.springframework.batch.item.NoWorkFoundException
Create a new NoWorkFoundException based on a message and another exception.

O

ObjectWaitSleeper - Class in org.springframework.batch.retry.backoff
Simple Sleeper implementation that just waits on a local Object.
ObjectWaitSleeper() - Constructor for class org.springframework.batch.retry.backoff.ObjectWaitSleeper
 
onCommit() - Method in class org.springframework.batch.item.xml.stax.DefaultTransactionalEventReader
Deprecated. Callback on transacion commit.
onCommit() - Method in interface org.springframework.batch.item.xml.stax.TransactionalEventReader
Deprecated. Callback on transaction commit.
onError(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
onError(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
onError(RepeatContext, Throwable) - Method in interface org.springframework.batch.repeat.RepeatListener
Called when a repeat callback fails by throwing an exception.
onError(RetryContext, RetryCallback, Throwable) - Method in class org.springframework.batch.retry.listener.RetryListenerSupport
 
onError(RetryContext, RetryCallback, Throwable) - Method in interface org.springframework.batch.retry.RetryListener
Called after every unsuccessful attempt at a retry.
onRollback() - Method in class org.springframework.batch.item.xml.stax.DefaultTransactionalEventReader
Deprecated. Callback on transaction rollback.
onRollback() - Method in interface org.springframework.batch.item.xml.stax.TransactionalEventReader
Deprecated. Callback on transaction rollback.
open(ExecutionContext) - Method in class org.springframework.batch.item.database.DrivingQueryItemReader
Initialize the item reader by delegating to the subclass in order to retrieve the keys.
open(ExecutionContext) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Initialize the reader.
open(ExecutionContext) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Figure out which resource to start with in case of restart, open the delegate and restore delegate's position in the resource.
open() - Method in interface org.springframework.batch.item.file.separator.LineReader
 
open() - Method in class org.springframework.batch.item.file.separator.ResourceLineReader
Creates internal state object.
open(ExecutionContext) - Method in interface org.springframework.batch.item.ItemStream
Open the stream for the provided ExecutionContext.
open(ExecutionContext) - Method in class org.springframework.batch.item.ItemStreamSupport
No-op.
open(ExecutionContext) - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
 
open(ExecutionContext) - Method in class org.springframework.batch.item.support.CompositeItemStream
Broadcast the call to open.
open(ExecutionContext) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Open the output source
open(RepeatContext) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
open(RepeatContext) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
open(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatListener
Called once at the start of a complete batch, before any items are processed.
open(RetryContext, RetryCallback) - Method in class org.springframework.batch.retry.listener.RetryListenerSupport
 
open(RetryCallback, RetryContext) - Method in class org.springframework.batch.retry.policy.CompositeRetryPolicy
Creates a new context that copies the existing policies and keeps a list of the contexts from each one.
open(RetryCallback, RetryContext) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Create an active context that proxies a retry policy by chosing a target from the policy map.
open(RetryCallback, RetryContext) - Method in class org.springframework.batch.retry.policy.NeverRetryPolicy
Return a context that can respond to early termination requests, but does nothing else.
open(RetryCallback, RetryContext) - Method in class org.springframework.batch.retry.policy.RecoveryCallbackRetryPolicy
Create a new context for the execution of the callback, which must be an instance of RecoveryRetryCallback.
open(RetryCallback, RetryContext) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Get a status object that can be used to track the current operation according to this policy.
open(RetryCallback, RetryContext) - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
 
open(RetryContext, RetryCallback) - Method in interface org.springframework.batch.retry.RetryListener
Called before the first attempt in a retry.
open(RetryCallback, RetryContext) - Method in interface org.springframework.batch.retry.RetryPolicy
Acquire resources needed for the retry operation.
org.springframework.batch.item - package org.springframework.batch.item
Infrastructure interfaces and primary dependencies for item concerns.
org.springframework.batch.item.adapter - package org.springframework.batch.item.adapter
Adapters for Plain Old Java Objects.
org.springframework.batch.item.database - package org.springframework.batch.item.database
Infrastructure implementations of database based item readers and writers.
org.springframework.batch.item.database.support - package org.springframework.batch.item.database.support
 
org.springframework.batch.item.file - package org.springframework.batch.item.file
Infrastructure implementations of io file concerns.
org.springframework.batch.item.file.mapping - package org.springframework.batch.item.file.mapping
Infrastructure implementations of io file support mapping concerns.
org.springframework.batch.item.file.separator - package org.springframework.batch.item.file.separator
Infrastructure implementations of io file support separator concerns.
org.springframework.batch.item.file.transform - package org.springframework.batch.item.file.transform
Infrastructure implementations of io file support transform concerns.
org.springframework.batch.item.jms - package org.springframework.batch.item.jms
 
org.springframework.batch.item.support - package org.springframework.batch.item.support
Internal support package
org.springframework.batch.item.transform - package org.springframework.batch.item.transform
Writer implementation concerned with item transformation before writing.
org.springframework.batch.item.util - package org.springframework.batch.item.util
 
org.springframework.batch.item.validator - package org.springframework.batch.item.validator
Infrastructure implementations of item validator concerns.
org.springframework.batch.item.xml - package org.springframework.batch.item.xml
Infrastructure implementations of xml input and output.
org.springframework.batch.item.xml.oxm - package org.springframework.batch.item.xml.oxm
 
org.springframework.batch.item.xml.stax - package org.springframework.batch.item.xml.stax
 
org.springframework.batch.repeat - package org.springframework.batch.repeat
Infrastructure implementations of repeat concerns.
org.springframework.batch.repeat.callback - package org.springframework.batch.repeat.callback
Infrastructure implementations of repeat callback concerns.
org.springframework.batch.repeat.context - package org.springframework.batch.repeat.context
Infrastructure implementations of repeat context concerns.
org.springframework.batch.repeat.exception - package org.springframework.batch.repeat.exception
Infrastructure implementations of repeat exception handler concerns.
org.springframework.batch.repeat.interceptor - package org.springframework.batch.repeat.interceptor
Infrastructure implementations of repeat aop concerns.
org.springframework.batch.repeat.listener - package org.springframework.batch.repeat.listener
Infrastructure implementations of repeat interceptor concerns.
org.springframework.batch.repeat.policy - package org.springframework.batch.repeat.policy
Infrastructure implementations of repeat policy concerns.
org.springframework.batch.repeat.support - package org.springframework.batch.repeat.support
Infrastructure implementations of repeat support concerns.
org.springframework.batch.retry - package org.springframework.batch.retry
Infrastructure implementations of retry concerns.
org.springframework.batch.retry.backoff - package org.springframework.batch.retry.backoff
Infrastructure implementations of retry backoff concerns.
org.springframework.batch.retry.callback - package org.springframework.batch.retry.callback
Infrastructure implementations of retry callback concerns.
org.springframework.batch.retry.context - package org.springframework.batch.retry.context
Infrastructure implementations of retry context concerns.
org.springframework.batch.retry.interceptor - package org.springframework.batch.retry.interceptor
Infrastructure implementations of retry aop concerns.
org.springframework.batch.retry.listener - package org.springframework.batch.retry.listener
Infrastructure implementations of retry interceptor concerns.
org.springframework.batch.retry.policy - package org.springframework.batch.retry.policy
Infrastructure implementations of retry policy concerns.
org.springframework.batch.retry.support - package org.springframework.batch.retry.support
Infrastructure implementations of retry support concerns.
org.springframework.batch.support - package org.springframework.batch.support
Infrastructure implementations of support concerns.
org.springframework.batch.support.transaction - package org.springframework.batch.support.transaction
Infrastructure implementations of support transaction concerns.

P

ParseException - Exception in org.springframework.batch.item
Exception indicating that an error has been encountered parsing io, typically from a file.
ParseException(String, Throwable) - Constructor for exception org.springframework.batch.item.ParseException
Create a new ParseException based on a message and another exception.
ParseException(String) - Constructor for exception org.springframework.batch.item.ParseException
Create a new ParseException based on a message.
PassThroughFieldSetMapper - Class in org.springframework.batch.item.file.mapping
Pass through FieldSetMapper useful for passing a FieldSet back directly rather than a mapped object.
PassThroughFieldSetMapper() - Constructor for class org.springframework.batch.item.file.mapping.PassThroughFieldSetMapper
 
peek() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
peek() - Method in class org.springframework.batch.item.xml.stax.DefaultTransactionalEventReader
Deprecated. Check the next XMLEvent without reading it from the stream.
postProcess(String) - Method in interface org.springframework.batch.item.file.separator.RecordSeparatorPolicy
Give the policy a chance to post-process a complete record, e.g.
postProcess(String) - Method in class org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
Pass the record through.
postProcess(String) - Method in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Remove the suffix from the end of the record.
PrefixMatchingCompositeLineTokenizer - Class in org.springframework.batch.item.file.transform
 
PrefixMatchingCompositeLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.PrefixMatchingCompositeLineTokenizer
 
preProcess(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
If we are in an unterminated quote, add a line separator.
preProcess(String) - Method in interface org.springframework.batch.item.file.separator.RecordSeparatorPolicy
Pre-process a record before another line is appended, in the case of a multi-line record.
preProcess(String) - Method in class org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
Pass the line through.
PropertiesConverter - Class in org.springframework.batch.support
Utility to convert a Properties object to a String and back.
propertiesToString(Properties) - Static method in class org.springframework.batch.support.PropertiesConverter
Convert Properties object to String.
PropertyExtractingDelegatingItemWriter - Class in org.springframework.batch.item.adapter
Delegates processing to a custom method - extracts property values from item object and uses them as arguments for the delegate method.
PropertyExtractingDelegatingItemWriter() - Constructor for class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
put(String, Object) - Method in class org.springframework.batch.item.ExecutionContext
Add an Object value to the context (must be Serializable).
put(Object, RetryContext) - Method in class org.springframework.batch.retry.policy.MapRetryContextCache
 
put(Object, RetryContext) - Method in interface org.springframework.batch.retry.policy.RetryContextCache
 
putDouble(String, double) - Method in class org.springframework.batch.item.ExecutionContext
Add a Double value to the context.
putLong(String, long) - Method in class org.springframework.batch.item.ExecutionContext
Adds a Long value to the context.
putString(String, String) - Method in class org.springframework.batch.item.ExecutionContext
Adds a String value to the context.

R

Range - Class in org.springframework.batch.item.file.transform
A class to represent ranges.
Range(int) - Constructor for class org.springframework.batch.item.file.transform.Range
 
Range(int, int) - Constructor for class org.springframework.batch.item.file.transform.Range
 
RangeArrayPropertyEditor - Class in org.springframework.batch.item.file.transform
Property editor implementation which parses string and creates array of ranges.
RangeArrayPropertyEditor() - Constructor for class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
read() - Method in class org.springframework.batch.item.adapter.ItemReaderAdapter
 
read() - Method in class org.springframework.batch.item.database.DrivingQueryItemReader
Return the next key in the List.
read() - Method in class org.springframework.batch.item.database.IbatisDrivingQueryItemReader
Overridden read() that uses the returned key as arguments to the details query.
read() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Reads the next item, jumping to next resource if necessary.
read() - Method in class org.springframework.batch.item.file.separator.ResourceLineReader
Read the next line from the input resource, ignoring comments, and according to the RecordSeparatorPolicy.
read() - Method in interface org.springframework.batch.item.ItemReader
Reads a piece of input data and advance to the next one.
read() - Method in class org.springframework.batch.item.jms.JmsItemReader
 
read() - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
 
read() - Method in class org.springframework.batch.item.support.AggregateItemReader
Get the next list of records.
read() - Method in class org.springframework.batch.item.support.DelegatingItemReader
Get the next object from the input source.
read() - Method in class org.springframework.batch.item.support.ListItemReader
 
read() - Method in class org.springframework.batch.item.validator.ValidatingItemReader
 
readAndTrim(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
Read and trim the String value at 'index'.
readBigDecimal(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readBigDecimal(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readBigDecimal(int, BigDecimal) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readBigDecimal(String, BigDecimal) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readBigDecimal(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the BigDecimal value at index 'index'.
readBigDecimal(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the BigDecimal value from column with given 'name.
readBigDecimal(int, BigDecimal) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the BigDecimal value at index 'index', returning the supplied defaultValue if the trimmed string value at index 'index' is blank.
readBigDecimal(String, BigDecimal) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the BigDecimal value from column with given 'name, returning the supplied defaultValue if the trimmed string value at index 'index' is blank.
readBoolean(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readBoolean(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readBoolean(int, String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readBoolean(String, String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readBoolean(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'boolean' value at index 'index'.
readBoolean(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'boolean' value from column with given 'name'.
readBoolean(int, String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'boolean' value at index 'index'.
readBoolean(String, String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'boolean' value from column with given 'name'.
readByte(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readByte(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readByte(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'byte' value at index 'index'.
readByte(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'byte' value from column with given 'name'.
readChar(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readChar(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readChar(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'char' value at index 'index'.
readChar(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'char' value from column with given 'name'.
readDate(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readDate(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readDate(int, String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readDate(String, String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readDate(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDate(int, String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(String, String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDouble(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readDouble(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readDouble(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'double' value at index 'index'.
readDouble(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'double' value from column with given 'name.
ReaderNotOpenException - Exception in org.springframework.batch.item
Exception indicating that an ItemReader needed to be opened before read.
ReaderNotOpenException(String) - Constructor for exception org.springframework.batch.item.ReaderNotOpenException
Create a new ReaderNotOpenException based on a message.
ReaderNotOpenException(String, Throwable) - Constructor for exception org.springframework.batch.item.ReaderNotOpenException
Create a new ReaderNotOpenException based on a message and another exception.
readFloat(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readFloat(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readFloat(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'float' value at index 'index'.
readFloat(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'float' value from column with given 'name.
readInt(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readInt(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readInt(int, int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readInt(String, int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readInt(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'int' value at index 'index'.
readInt(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'int' value from column with given 'name'.
readInt(int, int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'int' value at index 'index', using the supplied defaultValue if the field value is blank.
readInt(String, int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'int' value from column with given 'name', using the supplied defaultValue if the field value is blank.
readLong(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readLong(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readLong(int, long) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readLong(String, long) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readLong(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'long' value at index 'index'.
readLong(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'long' value from column with given 'name'.
readLong(int, long) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'long' value at index 'index', using the supplied defaultValue if the field value is blank.
readLong(String, long) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'long' value from column with given 'name', using the supplied defaultValue if the field value is blank.
readRawString(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readRawString(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readRawString(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the String value at index 'index' including trailing whitespace (don't trim).
readRawString(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the String value from column with given 'name' including trailing whitespace (don't trim).
readShort(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readShort(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readShort(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'short' value at index 'index'.
readShort(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the 'short' value from column with given 'name'.
readString(int) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readString(String) - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
readString(int) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the String value at index 'index'.
readString(String) - Method in interface org.springframework.batch.item.file.mapping.FieldSet
Read the String value from column with given 'name'.
RecordSeparatorPolicy - Interface in org.springframework.batch.item.file.separator
Policy for text file-based input sources to determine the end of a record, e.g.
recover(Object, Throwable) - Method in interface org.springframework.batch.item.ItemRecoverer
Recover gracefully from an error.
recover(Object, Throwable) - Method in class org.springframework.batch.item.jms.JmsItemReader
Send the message back to the provider using the specified error destination property of this reader.
recover(RetryContext) - Method in interface org.springframework.batch.retry.RecoveryCallback
 
recoverForException(Throwable) - Method in class org.springframework.batch.retry.policy.AbstractStatefulRetryPolicy
 
RecoveryCallback - Interface in org.springframework.batch.retry
Callback for stateful retry after all tries are exhausted.
RecoveryCallbackRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that detects an RecoveryRetryCallback when it opens a new context, and uses it to make sure the item is in place for later decisions about how to retry or backoff.
RecoveryCallbackRetryPolicy(RetryPolicy) - Constructor for class org.springframework.batch.retry.policy.RecoveryCallbackRetryPolicy
Convenience constructor to set delegate on init.
RecoveryCallbackRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.RecoveryCallbackRetryPolicy
Default constructor.
RecoveryRetryCallback - Class in org.springframework.batch.retry.callback
A RetryCallback that knows about and caches an item, and attempts to process it using a delegate RetryCallback.
RecoveryRetryCallback(Object, RetryCallback) - Constructor for class org.springframework.batch.retry.callback.RecoveryRetryCallback
Constructor with mandatory properties.
RecoveryRetryCallback(Object, RetryCallback, Object) - Constructor for class org.springframework.batch.retry.callback.RecoveryRetryCallback
Constructor with mandatory properties.
RecursiveCollectionItemTransformer - Class in org.springframework.batch.item.file.transform
An implementation of ItemTransformer that treats its argument specially if it is an array or collection.
RecursiveCollectionItemTransformer() - Constructor for class org.springframework.batch.item.file.transform.RecursiveCollectionItemTransformer
 
register(ItemStream) - Method in class org.springframework.batch.item.support.CompositeItemStream
Register a ItemStream as one of the interesting providers under the provided key.
register(RepeatListener) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
Register additional listener.
register(RepeatContext) - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Method for registering a context - should only be used by RepeatOperations implementations to ensure that RepeatSynchronizationManager.getContext() always returns the correct value.
register(RetryContext) - Static method in class org.springframework.batch.retry.support.RetrySynchronizationManager
Method for registering a context - should only be used by RetryOperations implementations to ensure that RetrySynchronizationManager.getContext() always returns the correct value.
registerCustomEditors(PropertyEditorRegistry) - Method in class org.springframework.batch.support.DefaultPropertyEditorRegistrar
Register the custom editors with the given registry.
registerDestructionCallback(String, Runnable) - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
registerDestructionCallback(String, Runnable) - Method in interface org.springframework.batch.repeat.RepeatContext
Register a callback to be executed on close, associated with the attribute having the given name.
registerListener(RepeatListener) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Register an additional listener.
registerListener(RetryListener) - Method in class org.springframework.batch.retry.support.RetryTemplate
Register an additional listener.
registerThrowable(Throwable) - Method in class org.springframework.batch.retry.context.RetryContextSupport
Set the exception for the public interface RetryContext, and also increment the retry count if the throwable is non-null.
All RetryPolicy implementations should use this method when they register the throwable.
registerThrowable(RetryContext, Throwable) - Method in class org.springframework.batch.retry.policy.CompositeRetryPolicy
Delegate to the policies that were in operation when the context was created.
registerThrowable(RetryContext, Throwable) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Delegate to the policy currently activated in the context.
registerThrowable(RetryContext, Throwable) - Method in class org.springframework.batch.retry.policy.NeverRetryPolicy
Do nothing.
registerThrowable(RetryContext, Throwable) - Method in class org.springframework.batch.retry.policy.RecoveryCallbackRetryPolicy
If RecoveryCallbackRetryPolicy.canRetry(RetryContext) is false then take remedial action (if implemented by subclasses), and remove the current item from the history.
registerThrowable(RetryContext, Throwable) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Update the status with another attempted retry and the latest exception.
registerThrowable(RetryContext, Throwable) - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
 
registerThrowable(RetryContext, Throwable) - Method in interface org.springframework.batch.retry.RetryPolicy
Called once per retry attempt, after the callback fails.
remove() - Method in class org.springframework.batch.item.xml.stax.DefaultTransactionalEventReader
Deprecated. In this implementation throws UnsupportedOperationException.
remove(Object) - Method in class org.springframework.batch.retry.policy.MapRetryContextCache
 
remove(Object) - Method in interface org.springframework.batch.retry.policy.RetryContextCache
 
removeAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
RepeatCallback - Interface in org.springframework.batch.repeat
Callback interface for batch operations.
RepeatContext - Interface in org.springframework.batch.repeat
Base interface for context which controls the state and completion / termination of a batch step.
RepeatContextCounter - Class in org.springframework.batch.repeat.context
Helper class for policies that need to count the number of occurrences of some event (e.g.
RepeatContextCounter(RepeatContext, String) - Constructor for class org.springframework.batch.repeat.context.RepeatContextCounter
Convenience constructor with useParent=false.
RepeatContextCounter(RepeatContext, String, boolean) - Constructor for class org.springframework.batch.repeat.context.RepeatContextCounter
Construct a new RepeatContextCounter.
RepeatContextSupport - Class in org.springframework.batch.repeat.context
 
RepeatContextSupport(RepeatContext) - Constructor for class org.springframework.batch.repeat.context.RepeatContextSupport
Constructor for RepeatContextSupport.
RepeatException - Exception in org.springframework.batch.repeat
 
RepeatException(String) - Constructor for exception org.springframework.batch.repeat.RepeatException
 
RepeatException(String, Throwable) - Constructor for exception org.springframework.batch.repeat.RepeatException
 
RepeatInternalState - Interface in org.springframework.batch.repeat.support
 
RepeatInternalStateSupport - Class in org.springframework.batch.repeat.support
 
RepeatInternalStateSupport() - Constructor for class org.springframework.batch.repeat.support.RepeatInternalStateSupport
 
RepeatListener - Interface in org.springframework.batch.repeat
Interface for listeners to the batch process.
RepeatListenerSupport - Class in org.springframework.batch.repeat.listener
Empty method implementation of RepeatListener.
RepeatListenerSupport() - Constructor for class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
RepeatOperations - Interface in org.springframework.batch.repeat
The main interface providing access to batch operations.
RepeatOperationsInterceptor - Class in org.springframework.batch.repeat.interceptor
A MethodInterceptor that can be used to automatically repeat calls to a method on a service.
RepeatOperationsInterceptor() - Constructor for class org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
 
RepeatSynchronizationManager - Class in org.springframework.batch.repeat.support
Global variable support for repeat clients.
RepeatTemplate - Class in org.springframework.batch.repeat.support
Simple implementation and base class for batch templates implementing RepeatOperations.
RepeatTemplate() - Constructor for class org.springframework.batch.repeat.support.RepeatTemplate
 
replaceExitCode(String) - Method in class org.springframework.batch.repeat.ExitStatus
Add an exit code to an existing ExitStatus.
reset() - Method in class org.springframework.batch.item.adapter.ItemReaderAdapter
No-op.
reset() - Method in class org.springframework.batch.item.database.DrivingQueryItemReader
 
reset() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Switches to 'read from buffer' state.
reset() - Method in class org.springframework.batch.item.file.separator.ResourceLineReader
Reset the reader to the last mark.
reset() - Method in interface org.springframework.batch.item.ItemReader
Reset the stream to the last mark.
reset() - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
 
reset() - Method in class org.springframework.batch.item.support.AbstractItemReader
 
reset() - Method in class org.springframework.batch.item.support.DelegatingItemReader
 
reset() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
reset() - Method in interface org.springframework.batch.item.xml.stax.FragmentEventReader
Reset the state of the fragment reader - make it forget it assumptions about current position of cursor (e.g.
ResetFailedException - Exception in org.springframework.batch.item
An exception class thrown when an ItemReader fails to reset its state based on the previous mark.
ResetFailedException(String) - Constructor for exception org.springframework.batch.item.ResetFailedException
Create a new ResetFailedException based on a message.
ResetFailedException(String, Throwable) - Constructor for exception org.springframework.batch.item.ResetFailedException
Create a new ResetFailedException based on a message and another exception.
ResourceAwareItemReaderItemStream - Interface in org.springframework.batch.item.file
Interface for ItemReaders that implement ItemStream and read input from Resource.
ResourcelessTransactionManager - Class in org.springframework.batch.support.transaction
 
ResourcelessTransactionManager() - Constructor for class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
ResourceLineReader - Class in org.springframework.batch.item.file.separator
An input source that reads lines one by one from a resource.
ResourceLineReader(Resource) - Constructor for class org.springframework.batch.item.file.separator.ResourceLineReader
 
ResourceLineReader(Resource, String) - Constructor for class org.springframework.batch.item.file.separator.ResourceLineReader
 
RETHROW - Static variable in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Key for ExceptionClassifier signalling that the throwable should be rethrown.
RethrowOnThresholdExceptionHandler - Class in org.springframework.batch.repeat.exception
Implementation of ExceptionHandler that rethrows when exceptions of a given type reach a threshold.
RethrowOnThresholdExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Set up the exception handler.
retrieveKeys(ExecutionContext) - Method in interface org.springframework.batch.item.database.KeyCollector
Retrieve the keys to be iterated over.
retrieveKeys(ExecutionContext) - Method in class org.springframework.batch.item.database.support.IbatisKeyCollector
 
retrieveKeys(ExecutionContext) - Method in class org.springframework.batch.item.database.support.MultipleColumnJdbcKeyCollector
 
retrieveKeys(ExecutionContext) - Method in class org.springframework.batch.item.database.support.SingleColumnJdbcKeyCollector
 
RetryCacheCapacityExceededException - Exception in org.springframework.batch.retry.policy
Exception that indicates that a cache limit was exceeded.
RetryCacheCapacityExceededException(String) - Constructor for exception org.springframework.batch.retry.policy.RetryCacheCapacityExceededException
Constructs a new instance with a message.
RetryCacheCapacityExceededException(String, Throwable) - Constructor for exception org.springframework.batch.retry.policy.RetryCacheCapacityExceededException
Constructs a new instance with a message and nested exception.
RetryCallback - Interface in org.springframework.batch.retry
Callback interface for an operation that can be retried using a RetryOperations.
RetryContext - Interface in org.springframework.batch.retry
Low-level access to ongoing retry operation.
retryContextCache - Variable in class org.springframework.batch.retry.policy.AbstractStatefulRetryPolicy
 
RetryContextCache - Interface in org.springframework.batch.retry.policy
Simple map-like abstraction for stateful retry policies to use when storing and retrieving RetryContext instances.
RetryContextSupport - Class in org.springframework.batch.retry.context
 
RetryContextSupport(RetryContext) - Constructor for class org.springframework.batch.retry.context.RetryContextSupport
 
RetryException - Exception in org.springframework.batch.retry
 
RetryException(String, Throwable) - Constructor for exception org.springframework.batch.retry.RetryException
 
RetryException(String) - Constructor for exception org.springframework.batch.retry.RetryException
 
RetryListener - Interface in org.springframework.batch.retry
Interface for listener that can be used to add behaviour to a retry.
RetryListenerSupport - Class in org.springframework.batch.retry.listener
Empty method implementation of RetryListener.
RetryListenerSupport() - Constructor for class org.springframework.batch.retry.listener.RetryListenerSupport
 
RetryOperations - Interface in org.springframework.batch.retry
Defines the basic set of operations implemented by RetryOperations to execute operations with configurable retry behaviour.
RetryOperationsInterceptor - Class in org.springframework.batch.retry.interceptor
A MethodInterceptor that can be used to automatically retry calls to a method on a service if it fails.
RetryOperationsInterceptor() - Constructor for class org.springframework.batch.retry.interceptor.RetryOperationsInterceptor
 
RetryPolicy - Interface in org.springframework.batch.retry
A RetryPolicy is responsible for allocating and managing resources needed by RetryOperations.
RetryStatistics - Interface in org.springframework.batch.retry
Interface for statistics reporting of retry attempts.
RetrySynchronizationManager - Class in org.springframework.batch.retry.support
Global variable support for retry clients.
RetryTemplate - Class in org.springframework.batch.retry.support
Template class that simplifies the execution of operations with retry semantics.
RetryTemplate() - Constructor for class org.springframework.batch.retry.support.RetryTemplate
 
RIGHT - Static variable in class org.springframework.batch.item.file.transform.Alignment
 
rs - Variable in class org.springframework.batch.item.database.JdbcCursorItemReader
 

S

serializeObject(XMLEventWriter, Object) - Method in interface org.springframework.batch.item.xml.EventWriterSerializer
Serialize an Object.
serializeObject(XMLEventWriter, Object) - Method in class org.springframework.batch.item.xml.oxm.MarshallingEventWriterSerializer
 
setAggregator(LineAggregator) - Method in class org.springframework.batch.item.file.transform.LineAggregatorItemTransformer
Public setter for the LineAggregator.
setAlignment(Alignment) - Method in class org.springframework.batch.item.file.transform.FixedLengthLineAggregator
Recognized alignments are CENTER, RIGHT, LEFT.
setAncestorsCompleteOnly() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Set current session and all ancestors (via parent) to complete.,
setArguments(Object[]) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setAssertUpdates(boolean) - Method in class org.springframework.batch.item.database.BatchSqlUpdateItemWriter
Public setter for the flag that determines whether an assertion is made that all items cause at least one row to be updated.
setAsText(String) - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
setAsText(String) - Method in class org.springframework.batch.support.IntArrayPropertyEditor
 
setAttribute(String, Object) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
setAttributeIfAbsent(String, Object) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
Additional support for atomic put if absent.
setBackOffPeriod(long) - Method in class org.springframework.batch.retry.backoff.FixedBackOffPolicy
Set the back off period in milliseconds.
setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.retry.support.RetryTemplate
Setter for BackOffPolicy.
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
 
setBufferSize(int) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Sets buffer size for output template
setCapacity(int) - Method in class org.springframework.batch.retry.policy.MapRetryContextCache
Public setter for the capacity.
setChunkSize(int) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
setColumns(Range[]) - Method in class org.springframework.batch.item.file.transform.FixedLengthLineAggregator
Set column ranges.
setColumns(Range[]) - Method in class org.springframework.batch.item.file.transform.FixedLengthTokenizer
Set the column ranges.
setComments(String[]) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Setter for comment prefixes.
setComments(String[]) - Method in class org.springframework.batch.item.file.separator.ResourceLineReader
Setter for comment prefixes.
setComparator(Comparator) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
setCompleteOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
setCompleteOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Signal to the framework that the current batch should complete normally, independent of the current CompletionPolicy.
setCompleteOnly() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Convenience method to set the current repeat operation to complete if it exists.
setCompletionPolicy(CompletionPolicy) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Setter for policy to decide when the batch is complete.
setContinuation(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Public setter for the continuation.
setCurrentItemCount(int) - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
 
setCustomEditors(Map) - Method in class org.springframework.batch.support.DefaultPropertyEditorRegistrar
Specify the custom editors to register.
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Public setter for the data source for injection purposes.
setDelegate(ItemWriter) - Method in class org.springframework.batch.item.database.HibernateAwareItemWriter
Public setter for the ItemWriter property.
setDelegate(ResourceAwareItemReaderItemStream) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
setDelegate(ItemTransformer) - Method in class org.springframework.batch.item.file.transform.RecursiveCollectionItemTransformer
Public setter for the ItemTransformer to use on single items, that are not Strings.
setDelegate(ItemWriter) - Method in class org.springframework.batch.item.support.DelegatingItemWriter
Setter for ItemWriter.
setDelegate(RetryPolicy) - Method in class org.springframework.batch.retry.policy.RecoveryCallbackRetryPolicy
Setter for delegate.
setDelegates(List) - Method in class org.springframework.batch.item.support.CompositeItemWriter
 
setDelimiter(String) - Method in class org.springframework.batch.item.file.transform.DelimitedLineAggregator
Sets the character to be used as a delimiter.
setDelimiter(char) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Setter for the delimiter character.
setDetailsQueryId(String) - Method in class org.springframework.batch.item.database.IbatisDrivingQueryItemReader
 
setDriverSupportsAbsolute(boolean) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Indicate whether the JDBC driver supports setting the absolute row on a ResultSet.
setDrivingQueryId(String) - Method in class org.springframework.batch.item.database.support.IbatisKeyCollector
 
setEncoding(String) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Setter for the encoding for this input source.
setEncoding(String) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Sets encoding for output template.
setEncoding(String) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set encoding to be used for output file.
setErrorDestination(Destination) - Method in class org.springframework.batch.item.jms.JmsItemReader
Set the error destination.
setErrorDestinationName(String) - Method in class org.springframework.batch.item.jms.JmsItemReader
Set the error destination by name.
setExceptionClasses(Class[]) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Setter for the Throwable exceptionClasses that this handler counts.
setExceptionClasses(Class[]) - Method in class org.springframework.batch.support.BinaryExceptionClassifier
Set the special exceptions.
setExceptionClassifier(ExceptionClassifier) - Method in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Setter for the ExceptionClassifier used by this handler.
setExceptionClassifier(ExceptionClassifier) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Setter for the ExceptionClassifier used by this handler.
setExceptionClassifier(ExceptionClassifier) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Setter for an exception classifier.
setExceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Setter for exception handler strategy.
setExhaustedOnly() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
setExhaustedOnly() - Method in interface org.springframework.batch.retry.RetryContext
Signal to the framework that no more attempts should be made to try or retry the current RetryCallback.
setFatalExceptionClasses(Class[]) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Setter for the Throwable exceptionClasses that shouldn't be counted, but rethrown immediately.
setFatalExceptionClasses(Class[]) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Set the fatal exceptions.
setFetchSize(int) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Gives the JDBC driver a hint as to the number of rows that should be fetched from the database when more rows are needed for this ResultSet object.
setFetchSize(int) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Gives the JDBC driver a hint as to the number of rows that should be fetched from the database when more rows are needed for this ResultSet object.
setFieldSetCreator(FieldSetCreator) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Public setter for the FieldSetCreator.
setFieldSetMapper(FieldSetMapper) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Set the FieldSetMapper to be used for each line.
setFieldsUsedAsTargetMethodArguments(String[]) - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
setFirstLineIsHeader(boolean) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Indicates whether first line is a header.
setForceDisjointRanges(boolean) - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
Set force disjoint ranges.
setForceRefresh(boolean) - Method in class org.springframework.batch.retry.callback.RecoveryRetryCallback
Public setter for a flag signalling to clients of this callback that the processing is not a retry.
setFragmentDeserializer(EventReaderDeserializer) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
setFragmentRootElementName(String) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
setHandlers(ExceptionHandler[]) - Method in class org.springframework.batch.repeat.exception.CompositeExceptionHandler
 
setHeaderItems(Object[]) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Setter for the headers.
setHeaderLines(String[]) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Public setter for the header lines.
setHibernateTemplate(HibernateOperations) - Method in class org.springframework.batch.item.database.HibernateAwareItemWriter
Public setter for the HibernateOperations property.
setIgnoreWarnings(boolean) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set whether SQLWarnings should be ignored (only logged) or exception should be thrown.
setIgnoreWhitespace(boolean) - Method in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Flag to indicate that the decision to terminate a record should ignore whitespace at the end of the line.
setIncrementerColumnName(String) - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
Public setter for the column name (defaults to "ID") in the incrementer.
setInitialInterval(long) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Set the initial sleep interval value.
setItemPreparedStatementSetter(ItemPreparedStatementSetter) - Method in class org.springframework.batch.item.database.BatchSqlUpdateItemWriter
Public setter for the ItemPreparedStatementSetter.
setItemReader(ItemReader) - Method in class org.springframework.batch.item.support.DelegatingItemReader
Setter for input source.
setItemTransformer(ItemTransformer) - Method in class org.springframework.batch.item.transform.ItemTransformerItemWriter
 
setItemTransformers(List) - Method in class org.springframework.batch.item.transform.CompositeItemTransformer
 
setItemType(Class) - Method in class org.springframework.batch.item.jms.JmsItemReader
Set the expected type of incoming message payloads.
setJdbcTemplate(JdbcOperations) - Method in class org.springframework.batch.item.database.BatchSqlUpdateItemWriter
Public setter for the JdbcOperations.
setJdbcTemplate(JdbcTemplate) - Method in class org.springframework.batch.item.database.support.MultipleColumnJdbcKeyCollector
 
setJdbcTemplate(JdbcTemplate) - Method in class org.springframework.batch.item.database.support.SingleColumnJdbcKeyCollector
Set the JdbcTemplate to be used.
setJmsTemplate(JmsOperations) - Method in class org.springframework.batch.item.jms.JmsItemReader
Setter for jms template.
setKeyCollector(KeyCollector) - Method in class org.springframework.batch.item.database.DrivingQueryItemReader
Set the key generation strategy to use for this input source.
setKeyGenerator(ItemKeyGenerator) - Method in class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
 
setKeyMapper(RowMapper) - Method in class org.springframework.batch.item.database.support.MultipleColumnJdbcKeyCollector
Set the RowMapper to be used to map a result set to keys.
setKeyMapper(RowMapper) - Method in class org.springframework.batch.item.database.support.SingleColumnJdbcKeyCollector
Set the RowMapper to be used to map each key to an object.
setLimit(int) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
The limit on the given exception type within a single context before it is rethrown.
setLineAggregator(LineAggregator) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Public setter for the LineAggregator.
setLineSeparator(String) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Public setter for the line separator.
setLinesToSkip(int) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Public setter for the number of lines to skip at the start of a file.
setLineTokenizer(LineTokenizer) - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
setListeners(RepeatListener[]) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
Public setter for the listeners.
setListeners(RepeatListener[]) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Set the listeners for this template, registering them for callbacks at appropriate times in the iteration.
setListeners(RetryListener[]) - Method in class org.springframework.batch.retry.support.RetryTemplate
Setter for listeners.
setMapper(RowMapper) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set the RowMapper to be used for all calls to read().
setMax(int) - Method in class org.springframework.batch.item.file.transform.Range
 
setMaxAttempts(int) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Setter for retry attempts.
setMaxCount(int) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Setter for maximum value of count before termination.
setMaxInterval(long) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Setter for maximum back off period.
setMaxRows(int) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Sets the limit for the maximum number of rows that any ResultSet object can contain to the given number.
setMin(int) - Method in class org.springframework.batch.item.file.transform.Range
 
setMultiplier(double) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Set the multiplier value.
setName(String) - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
 
setName(String) - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
 
setNames(String[]) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
Setter for column names.
setNewItemIdentifier(NewItemIdentifier) - Method in class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
Public setter for the NewItemIdentifier.
setOverwriteOutput(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set "overwrite" flag for the output file.
setPadding(char) - Method in class org.springframework.batch.item.file.transform.FixedLengthLineAggregator
Setter for padding (default is space).
setPolicies(CompletionPolicy[]) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Setter for the policies.
setPolicies(RetryPolicy[]) - Method in class org.springframework.batch.retry.policy.CompositeRetryPolicy
Setter for policies.
setPolicyMap(Map) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Setter for policy map.
setPreparedStatementSetter(PreparedStatementSetter) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set the PreparedStatementSetter to use if any parameter values that need to be set in the supplied query.
setPreparedStatementSetter(ItemPreparedStatementSetter) - Method in class org.springframework.batch.item.database.support.MultipleColumnJdbcKeyCollector
 
setPrototypeBeanName(String) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
The bean name (id) for an object that can be populated from the field set that will be passed into BeanWrapperFieldSetMapper.mapLine(FieldSet).
setQueryString(String) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
 
setQueryTimeout(int) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Sets the number of seconds the driver will wait for a Statement object to execute to the given number of seconds.
setQuoteCharacter(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Public setter for the quoteCharacter.
setQuoteCharacter(char) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Public setter for the quoteCharacter.
setRecordSeparatorPolicy(RecordSeparatorPolicy) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Public setter for the recordSeparatorPolicy.
setRecordSeparatorPolicy(RecordSeparatorPolicy) - Method in class org.springframework.batch.item.file.separator.ResourceLineReader
Setter for the RecordSeparatorPolicy.
setRecoverableExceptionClasses(Class[]) - Method in class org.springframework.batch.retry.policy.AbstractStatefulRetryPolicy
Set the recoverable exceptions.
setRecoverer(ItemRecoverer) - Method in class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
Public setter for the ItemRecoverer to use if the retry is exhausted.
setRecoveryCallback(RecoveryCallback) - Method in class org.springframework.batch.retry.callback.RecoveryRetryCallback
Setter for injecting optional recovery handler.
setRepeatOperations(RepeatOperations) - Method in class org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
Setter for the RepeatOperations.
setResource(Resource) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Setter for resource property.
setResource(Resource) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Setter for resource.
setResource(Resource) - Method in interface org.springframework.batch.item.file.ResourceAwareItemReaderItemStream
 
setResource(Resource) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
setResource(Resource) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set output file.
setResources(Resource[]) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
setRestartQueryId(String) - Method in class org.springframework.batch.item.database.support.IbatisKeyCollector
Set the id of the restart query.
setRestartSql(String) - Method in class org.springframework.batch.item.database.support.MultipleColumnJdbcKeyCollector
Set the query to use to retrieve keys in order to restore the previous state for restart.
setRestartSql(String) - Method in class org.springframework.batch.item.database.support.SingleColumnJdbcKeyCollector
Set the SQL query to be used to return the remaining keys to be processed.
setRetryableExceptionClasses(Class[]) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Set the retryable exceptions.
setRetryContextCache(RetryContextCache) - Method in class org.springframework.batch.retry.policy.AbstractStatefulRetryPolicy
Optional setter for the retry context cache.
setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
Public setter for the retryPolicy.
setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.retry.support.RetryTemplate
Setter for RetryPolicy.
setRetryTemplate(RetryOperations) - Method in class org.springframework.batch.retry.interceptor.RetryOperationsInterceptor
 
setRootElementAttributes(Map) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set the root element attributes to be written.
setRootTagName(String) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set the tag name of the root element.
setSaveState(boolean) - Method in class org.springframework.batch.item.database.DrivingQueryItemReader
 
setSaveState(boolean) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Set the flag indicating whether or not state should be saved in the provided ExecutionContext during the ItemStream call to update.
setSaveState(boolean) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Set the boolean indicating whether or not state should be saved in the provided ExecutionContext during the ItemStream call to update.
setSaveState(boolean) - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
Set the flag that determines whether to save internal data for ExecutionContext.
setSaveState(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
 
setSerializer(EventWriterSerializer) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set Object to XML serializer.
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.HibernateAwareItemWriter
Set the Hibernate SessionFactory to be used internally.
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
 
setShouldDeleteIfExists(boolean) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
 
setSleeper(Sleeper) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Public setter for the Sleeper strategy.
setSleeper(Sleeper) - Method in class org.springframework.batch.retry.backoff.FixedBackOffPolicy
Public setter for the Sleeper strategy.
setSql(String) - Method in class org.springframework.batch.item.database.BatchSqlUpdateItemWriter
Public setter for the query string to execute on write.
setSql(String) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set the SQL statement to be used when creating the cursor.
setSql(String) - Method in class org.springframework.batch.item.database.support.MultipleColumnJdbcKeyCollector
Set the sql statement used to generate the keys list.
setSql(String) - Method in class org.springframework.batch.item.database.support.SingleColumnJdbcKeyCollector
Set the SQL statement to be used to return the keys to be processed.
setSqlMapClient(SqlMapClient) - Method in class org.springframework.batch.item.database.IbatisDrivingQueryItemReader
Set the SqlMapClientTemplate to use for this input source.
setSqlMapClient(SqlMapClient) - Method in class org.springframework.batch.item.database.support.IbatisKeyCollector
 
setStreams(ItemStream[]) - Method in class org.springframework.batch.item.support.CompositeItemStream
Public setter for the listeners.
setStrict(boolean) - Method in class org.springframework.batch.item.file.transform.FixedLengthTokenizer
Public setter for the strict flag.
setSuffix(String) - Method in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Lines ending in this terminator String signal the end of a record.
setTargetMethod(String) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setTargetObject(Object) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setTargetType(Class) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Public setter for the type of bean to create instead of using a prototype bean.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Setter for task executor to be used to run the individual item callbacks.
setTerminateOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
setTerminateOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Signal to the framework that the current batch should complete abnormally, independent of the current CompletionPolicy.
setThresholds(Map) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
A map from classifier keys to a threshold value of type Integer.
setThrottleLimit(int) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Public setter for the throttle limit.
setTimeout(long) - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
Setter for timeout.
setTokenizers(Map) - Method in class org.springframework.batch.item.file.transform.PrefixMatchingCompositeLineTokenizer
 
setTypeMap(Map) - Method in class org.springframework.batch.support.SubclassExceptionClassifier
Map of Throwable class types to keys for the classifier.
setUpOutputFile(File, boolean, boolean) - Static method in class org.springframework.batch.item.util.FileUtils
Set up output file for batch processing.
setUseParent(boolean) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Flag to indicate the the exception counters should be shared between sibling contexts in a nested batch.
setUseParent(boolean) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Flag to indicate the the exception counters should be shared between sibling contexts in a nested batch (i.e.
setUseParent(boolean) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Flag to indicate whether the count is at the level of the parent context, or just local to the context.
setUseStatelessSession(boolean) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Can be set only in uninitialized state.
setValidator(Validator) - Method in class org.springframework.batch.item.validator.SpringValidator
 
setValidator(Validator) - Method in class org.springframework.batch.item.validator.ValidatingItemReader
Set the validator used to validate each item.
setValues(Object, PreparedStatement) - Method in interface org.springframework.batch.item.database.ItemPreparedStatementSetter
Set parameter values on the given PreparedStatement as determined from the provided item.
setValues(Object, PreparedStatement) - Method in class org.springframework.batch.item.database.support.ColumnMapItemPreparedStatementSetter
 
setVerifyCursorPosition(boolean) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Allow verification of cursor position after current row is processed by RowMapper or RowCallbackHandler.
setVersion(String) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set XML version to be used for output XML.
shouldRethrow(RetryContext) - Method in class org.springframework.batch.retry.policy.AbstractStatefulRetryPolicy
For a stateful policy the default is to always rethrow.
shouldRethrow(RetryContext) - Method in class org.springframework.batch.retry.policy.AbstractStatelessRetryPolicy
Just returns the negative of RetryPolicy.canRetry(RetryContext), i.e.
shouldRethrow(RetryContext) - Method in interface org.springframework.batch.retry.RetryPolicy
 
SimpleCompletionPolicy - Class in org.springframework.batch.repeat.policy
Policy for terminating a batch after a fixed number of operations.
SimpleCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
SimpleCompletionPolicy(int) - Constructor for class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
SimpleCompletionPolicy.SimpleTerminationContext - Class in org.springframework.batch.repeat.policy
 
SimpleCompletionPolicy.SimpleTerminationContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
SimpleLimitExceptionHandler - Class in org.springframework.batch.repeat.exception
Simple implementation of exception handler which looks for given exception types.
SimpleLimitExceptionHandler(int) - Constructor for class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Convenience constructor for the SimpleLimitExceptionHandler to set the limit.
SimpleLimitExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Default constructor for the SimpleLimitExceptionHandler.
SimpleRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
Simplest possible RecordSeparatorPolicy - treats all lines as record endings.
SimpleRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
 
SimpleRetryPolicy - Class in org.springframework.batch.retry.policy
Simple retry policy that retries a fixed number of times for a set of named exceptions (and subclasses).
SimpleRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.SimpleRetryPolicy
Create a SimpleRetryPolicy with the default number of retry attempts.
SimpleRetryPolicy(int) - Constructor for class org.springframework.batch.retry.policy.SimpleRetryPolicy
Create a SimpleRetryPolicy with the specified number of retry attempts, and default exceptions to retry.
SingleColumnJdbcKeyCollector - Class in org.springframework.batch.item.database.support
Jdbc KeyCollector implementation that only works for a single column key.
SingleColumnJdbcKeyCollector() - Constructor for class org.springframework.batch.item.database.support.SingleColumnJdbcKeyCollector
 
SingleColumnJdbcKeyCollector(JdbcTemplate, String) - Constructor for class org.springframework.batch.item.database.support.SingleColumnJdbcKeyCollector
Constructs a new instance using the provided jdbcTemplate and string representing the sql statement that should be used to retrieve keys.
size() - Method in class org.springframework.batch.item.ExecutionContext
Returns number of entries in the context
sleep(long) - Method in class org.springframework.batch.retry.backoff.ObjectWaitSleeper
 
sleep(long) - Method in interface org.springframework.batch.retry.backoff.Sleeper
Pause for the specified period using whatever means available.
Sleeper - Interface in org.springframework.batch.retry.backoff
Strategy interface for backoff policies to delegate the pausing of execution.
SpringValidator - Class in org.springframework.batch.item.validator
Adapts the Validator interface to Validator.
SpringValidator() - Constructor for class org.springframework.batch.item.validator.SpringValidator
 
start(RepeatContext) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Create a new context for the execution of a batch.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
Build a new RepeatContextSupport and return it.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Create a new composite context from all the available policies.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Reset the counter.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Start the clock on the timeout.
start() - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
start(RetryContext) - Method in interface org.springframework.batch.retry.backoff.BackOffPolicy
Start a new block of back off operations.
start(RetryContext) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Returns a new instance of BackOffContext configured with the 'expSeed' and 'increment' values.
start(RetryContext) - Method in class org.springframework.batch.retry.backoff.StatelessBackOffPolicy
Returns 'null'.
StatefulRetryOperationsInterceptor - Class in org.springframework.batch.retry.interceptor
A MethodInterceptor that can be used to automatically retry calls to a method on a service if it fails.
StatefulRetryOperationsInterceptor() - Constructor for class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
 
StatelessBackOffPolicy - Class in org.springframework.batch.retry.backoff
Simple base class for BackOffPolicy implementations that maintain no state across invocations.
StatelessBackOffPolicy() - Constructor for class org.springframework.batch.retry.backoff.StatelessBackOffPolicy
 
StaxEventItemReader - Class in org.springframework.batch.item.xml
Item reader for reading XML input based on StAX.
StaxEventItemReader() - Constructor for class org.springframework.batch.item.xml.StaxEventItemReader
 
StaxEventItemWriter - Class in org.springframework.batch.item.xml
An implementation of ItemWriter which uses StAX and EventWriterSerializer for serializing object to XML.
StaxEventItemWriter() - Constructor for class org.springframework.batch.item.xml.StaxEventItemWriter
 
stringify(Object) - Method in class org.springframework.batch.item.file.transform.RecursiveCollectionItemTransformer
 
stringToProperties(String) - Static method in class org.springframework.batch.support.PropertiesConverter
Parse a String to a Properties object.
SubclassExceptionClassifier - Class in org.springframework.batch.support
 
SubclassExceptionClassifier() - Constructor for class org.springframework.batch.support.SubclassExceptionClassifier
 
SuffixRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
A RecordSeparatorPolicy that looks for an exact match for a String at the end of a line (e.g.
SuffixRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
 
SynchronizedAttributeAccessor - Class in org.springframework.batch.repeat.context
An AttributeAccessor that synchronizes on a mutex (not this) before modifying or accessing the underlying attributes.
SynchronizedAttributeAccessor() - Constructor for class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 

T

TaskExecutorRepeatTemplate - Class in org.springframework.batch.repeat.support
Provides RepeatOperations support including interceptors that can be used to modify or monitor the behaviour at run time.
This implementation is sufficient to be used to configure transactional behaviour for each item by making the RepeatCallback transactional, or for the whole batch by making the execute method transactional (but only then if the task executor is synchronous).
This class is thread safe if its collaborators are thread safe (interceptors, terminationPolicy, callback).
TaskExecutorRepeatTemplate() - Constructor for class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
 
TerminatedRetryException - Exception in org.springframework.batch.retry
 
TerminatedRetryException(String, Throwable) - Constructor for exception org.springframework.batch.retry.TerminatedRetryException
 
TerminatedRetryException(String) - Constructor for exception org.springframework.batch.retry.TerminatedRetryException
 
TimeoutRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that allows a retry only if it hasn't timed out.
TimeoutRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.TimeoutRetryPolicy
 
TimeoutTerminationPolicy - Class in org.springframework.batch.repeat.policy
Termination policy that times out after a fixed period.
TimeoutTerminationPolicy() - Constructor for class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Default constructor.
TimeoutTerminationPolicy(long) - Constructor for class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Construct a TimeoutTerminationPolicy with the specified timeout value (in milliseconds).
TimeoutTerminationPolicy.TimeoutBatchContext - Class in org.springframework.batch.repeat.policy
 
TimeoutTerminationPolicy.TimeoutBatchContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy.TimeoutBatchContext
 
tokenize(String) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
tokenize(String) - Method in interface org.springframework.batch.item.file.transform.LineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
tokenize(String) - Method in class org.springframework.batch.item.file.transform.PrefixMatchingCompositeLineTokenizer
 
toString() - Method in class org.springframework.batch.item.ExecutionContext
 
toString() - Method in class org.springframework.batch.item.file.mapping.DefaultFieldSet
 
toString() - Method in class org.springframework.batch.item.file.transform.Range
 
toString() - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
toString() - Method in class org.springframework.batch.repeat.ExitStatus
 
toString() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
toString() - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
 
TransactionalEventReader - Interface in org.springframework.batch.item.xml.stax
Deprecated. no longer used, to be removed in 2.0
TransactionAwareProxyFactory - Class in org.springframework.batch.support.transaction
Factory for transaction aware objects (like lists, sets, maps).
TransactionAwareProxyFactory(Object) - Constructor for class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
transform(Object) - Method in class org.springframework.batch.item.file.transform.LineAggregatorItemTransformer
Assume the item is an array of String (no check is made) and delegate to the aggregator.
transform(Object) - Method in class org.springframework.batch.item.file.transform.RecursiveCollectionItemTransformer
 
transform(Object) - Method in class org.springframework.batch.item.transform.CompositeItemTransformer
 
transform(Object) - Method in interface org.springframework.batch.item.transform.ItemTransformer
 

U

UnexpectedInputException - Exception in org.springframework.batch.item
Used to signal an unexpected end of an input or message stream.
UnexpectedInputException(String) - Constructor for exception org.springframework.batch.item.UnexpectedInputException
Create a new UnexpectedInputException based on a message.
UnexpectedInputException(String, Throwable) - Constructor for exception org.springframework.batch.item.UnexpectedInputException
Create a new UnexpectedInputException based on a message and another exception.
UNKNOWN - Static variable in class org.springframework.batch.repeat.ExitStatus
Convenient constant value representing unknown state - assumed not continuable.
UnmarshallingEventReaderDeserializer - Class in org.springframework.batch.item.xml.oxm
Delegates deserializing to Spring OXM Unmarshaller.
UnmarshallingEventReaderDeserializer(Unmarshaller) - Constructor for class org.springframework.batch.item.xml.oxm.UnmarshallingEventReaderDeserializer
 
update(ExecutionContext) - Method in class org.springframework.batch.item.database.DrivingQueryItemReader
 
update(ExecutionContext) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
 
update(ExecutionContext) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Store the current resource index and position in the resource.
update(ExecutionContext) - Method in interface org.springframework.batch.item.ItemStream
Indicates that the execution context provided during open is about to be saved.
update(ExecutionContext) - Method in class org.springframework.batch.item.ItemStreamSupport
Return empty ExecutionContext.
update(ExecutionContext) - Method in class org.springframework.batch.item.support.AbstractBufferedItemReaderItemStream
 
update(ExecutionContext) - Method in class org.springframework.batch.item.support.CompositeItemStream
Simple aggregate ExecutionContext provider for the contributions registered under the given key.
update(ExecutionContext) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get the restart data.
update(RepeatContext) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Give implementations the opportunity to update the state of the current batch.
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
Increment the context so the counter is up to date.
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Update all the composed contexts, and also increment the parent context.
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
update() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Increment the counter in the context.
update(RepeatContext) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
updateContext(Object, ExecutionContext) - Method in interface org.springframework.batch.item.database.KeyCollector
Given the provided key, store it in the provided ExecutionContext.
updateContext(Object, ExecutionContext) - Method in class org.springframework.batch.item.database.support.IbatisKeyCollector
 
updateContext(Object, ExecutionContext) - Method in class org.springframework.batch.item.database.support.MultipleColumnJdbcKeyCollector
 
updateContext(Object, ExecutionContext) - Method in class org.springframework.batch.item.database.support.SingleColumnJdbcKeyCollector
Get the restart data representing the last processed key.
UPPER_BORDER_NOT_DEFINED - Static variable in class org.springframework.batch.item.file.transform.Range
 

V

validate(Object) - Method in class org.springframework.batch.item.validator.SpringValidator
 
validate(Object) - Method in interface org.springframework.batch.item.validator.Validator
Method used to validate if the value is valid.
ValidatingItemReader - Class in org.springframework.batch.item.validator
Simple extension of DelegatingItemReader that provides for validation before returning input.
ValidatingItemReader() - Constructor for class org.springframework.batch.item.validator.ValidatingItemReader
 
ValidationException - Exception in org.springframework.batch.item.validator
This exception should be thrown when there are validation errors.
ValidationException(String, Throwable) - Constructor for exception org.springframework.batch.item.validator.ValidationException
Create a new ValidationException based on a message and another exception.
ValidationException(String) - Constructor for exception org.springframework.batch.item.validator.ValidationException
Create a new ValidationException based on a message.
Validator - Interface in org.springframework.batch.item.validator
Interface used to validate objects.
VALUE_NOT_SET - Static variable in class org.springframework.batch.item.database.JdbcCursorItemReader
 

W

waitForResults(RepeatInternalState) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
If necessary, wait for results to come back from remote or concurrent processes.
waitForResults(RepeatInternalState) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Wait for all the results to appear on the queue and execute the after interceptors for each one.
WARN - Static variable in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Key for ExceptionClassifier signalling that the throwable should be logged at warn level.
write(Object) - Method in class org.springframework.batch.item.adapter.ItemWriterAdapter
 
write(Object) - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
Extracts values from item's fields named in fieldsUsedAsTargetMethodArguments and passes them as arguments to the delegate method.
write(Object) - Method in class org.springframework.batch.item.database.AbstractTransactionalResourceItemWriter
Delegate to subclass to actually do the writing, but flushes aggressively if the item was previously part of a failed chunk.
write(Object) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Writes out a string followed by a "new line", where the format of the new line separator is determined by the underlying operating system.
write(Object) - Method in interface org.springframework.batch.item.ItemWriter
Process the supplied data element.
write(Object) - Method in class org.springframework.batch.item.support.CompositeItemWriter
Calls injected ItemProcessors in order.
write(Object) - Method in class org.springframework.batch.item.support.DelegatingItemWriter
Calls DelegatingItemWriter.doProcess(Object) and then writes the result to the delegate ItemWriter.
write(Object) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Write the value object to internal buffer.
WriterNotOpenException - Exception in org.springframework.batch.item
Exception indicating that an ItemWriter needed to be opened before being written to..
WriterNotOpenException(String) - Constructor for exception org.springframework.batch.item.WriterNotOpenException
Create a new WriterNotOpenException based on a message.
WriterNotOpenException(String, Throwable) - Constructor for exception org.springframework.batch.item.WriterNotOpenException
Create a new WriterNotOpenException based on a message and another exception.

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

Copyright © 2009 SpringSource. All Rights Reserved.