All Classes and Interfaces
Class
Description
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Abstract base class for any simple item reader that opens a database cursor and
continually retrieves the next row in the ResultSet.
Base class for item writers that write data to a file or stream.
Abstract superclass for
ItemReaders that supports restart by storing item count
in the ExecutionContext (therefore requires item ordering to be preserved
between runs).Base class for
ItemReader implementations.Base class for
ItemWriter implementations.Encapsulates common functionality needed by JDBC batch metadata DAOs - provides
jdbcTemplate for subclasses and handles table prefixes.
Abstract implementation of the
Job interface.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
A
FactoryBean that automates the creation of a SimpleJobRepository.
Abstract JPA Query Provider to serve as a base class for all JPA
Query
providers.Abstract class handling common concerns of various
LineTokenizer
implementations such as dealing with names and actual construction of FieldSetFactoryBean implementation that builds a listener based on the various
lifecycle methods or annotations that are provided.Superclass for delegating classes which dynamically call a custom method of an injected
object.
A base class that handles basic reading logic based on the paginated semantics of
Spring Data's paginated facilities.
Abstract
ItemStreamReader for to extend when reading database records in a
paging fashion.Base
PartitionHandler implementation providing common base features.Abstract SQL Paging Query Provider to serve as a base class for all provided SQL paging
query providers.
A
Step implementation that provides common behavior to subclasses, including
registering and calling listeners.Internal parser for the <step/> elements inside a job.
Base class for step builders that want to build a
TaskletStep.Marks a method to be called after a chunk is processed.
Marks a method to be called after a chunk has failed and been marked for rollback.
Expected signature: void afterFailedChunk(ChunkContext context)
Expected signature: void afterFailedChunk(ChunkContext context)
Marks a method to be called after a
Job has completed.Marks a method to be called after an item is passed to an
ItemProcessor.Marks a method to be called after an item is read from an
Expected signature: void afterRead(T item)
ItemReader Expected signature: void afterRead(T item)
Marks a method to be called after a
Step has completed.Marks a method to be called after an item is passed to an
ItemWriter.Implementation of the
SkipPolicy interface that will always return that an item
should be skipped.
AMQP
ItemReader implementation using an AmqpTemplate to receive and/or
convert messages.A builder implementation for the
AmqpItemReader
AMQP
ItemWriter implementation using an AmqpTemplate to send messages.A builder implementation for the
AmqpItemWriterMethodResolver implementation that finds a single Method on the given
Class that contains the specified annotation type.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
A basic array mapper, returning the values backing a fieldset.
Exception indicating that a failure or early completion condition was detected in a
remote worker.
An
ItemProcessor that delegates to a nested processor and in the background.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
An
ItemReader that deserializes data from a Resource containing
serialized Avro objects.A builder implementation for the
AvroItemReader.An
ItemWriter that serializes data to an WritableResource using Avro.A builder implementation for the
AvroItemWriter.Represents that an error has occurred in the configuration of the base batch
infrastructure (the creation of a
JobRepository, for example).Base configuration class for Spring Batch Integration factory beans.
The namespace handler for the Spring Batch Integration namespace.
Central class for batch metrics.
Bean post processor that configures observable batch artifacts (typically jobs and
steps) with a Micrometer's observation registry.
Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0 with no replacement.
ScopeSupport.
Helper class to scan a bean definition hierarchy and force the use of auto-proxy
for step scoped beans.
Enumeration representing the status of an execution.
BeanPostProcessor implementation that injects a job bean into
JobOperatorTestUtils if there is a unique job bean.ContextCustomizer implementation that adds batch test utility classes
(JobOperatorTestUtils and JobRepositoryTestUtils) as beans in the test
context.Factory for
BatchTestContextCustomizer.A
StepLocator implementation that just looks in its enclosing bean factory for
Steps by name.A convenient implementation for providing BeanPropertySqlParameterSource when the item
has JavaBean properties that correspond to names used for parameters in the SQL
statement.
A
ValidatingItemProcessor that uses the Bean Validation API (JSR-303) to
validate items.This is a field extractor for a java bean.
FieldSetMapper implementation based on bean property paths.Marks a method to be called before a chunk is executed.
Marks a method to be called before a
Job is executed, which comes after a
JobExecution is created and persisted but before the first Step is
executed.Marks a method to be called before an item is passed to an
Expected signature: void beforeProcess(T item)
ItemProcessor Expected signature: void beforeProcess(T item)
Marks a method to be called before an item is read from an
Expected signature: void beforeRead()
ItemReader Expected signature: void beforeRead()
Marks a method to be called before a
Step is executed, which comes after a
StepExecution is created and persisted but before the first item is read.Marks a method to be called before a chunk is passed to an
ItemWriter.This is an
ItemReader that reads items from a BlockingQueue.Builder for
BlockingQueueItemReader.This is an
ItemWriter that writes items to a BlockingQueue.Builder for a
BlockingQueueItemWriter.A factory strategy for custom extensions of
BufferedReader allowing
customisation of the standard behaviour of the java.io variety.Encapsulation of a list of items to be processed and possibly a list of failed items to
be skipped.
Context object for weakly typed data stored for the duration of a chunk (usually a
group of items processed together in a transaction).
Internal parser for the <chunk/> element inside a step.
Listener interface for the lifecycle of a chunk.
Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0 with no replacement.
Step implementation for the chunk-oriented processing model.
A builder for
ChunkOrientedStep.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0, use
ChunkOrientedStep instead.Interface defined for processing
Chunks.A
ChunkRequestHandler based on a ChunkProcessor.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0 with no replacement.
Encapsulation of a chunk of items to be processed remotely as part of a step execution.
Interface for a remote worker in the Remote Chunking pattern.
Encapsulates a response to processing a chunk of items, summarising the result as a
StepContribution.Similar to
ChunkMessageChannelItemWriter, this item writer submits chunk
requests to local workers from a TaskExecutor instead of sending them over a
message channel to remote workers.Calls one of a collection of ItemProcessors, based on a router pattern implemented
through the provided
Classifier.Creates a fully qualified
ClassifierCompositeItemProcessor.Calls one of a collection of ItemWriters for each item, based on a router pattern
implemented through the provided
Classifier.Creates a fully qualified ClassifierCompositeItemWriter.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Implementation of the
ItemPreparedStatementSetter interface that assumes all
keys are contained within a Map with the column name as the key.A command-line utility to operate Spring Batch jobs using the
JobOperator.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
CommandLineJobOperator.Strategy interface for executing commands.
Interface for batch completion policies, to enable batch operations to strategise
normal completion conditions.
Very simple base class for
CompletionPolicy implementations.Composite policy that loops through a list of delegate policies and answers calls by a
consensus.
Composite
ExceptionHandler that loops though a list of delegates.Composite
Note the user is responsible for injecting a chain of
ItemProcessor that passes the item through a sequence of injected
ItemTransformers (return value of previous transformation is the entry
value of the next).Note the user is responsible for injecting a chain of
ItemProcessors that
conforms to declared input and output types.Creates a fully qualified
CompositeItemProcessorBuilder.Composite reader that delegates reading to a list of
ItemStreamReaders.Simple
ItemStream that delegates to a list of other streams.Calls a collection of
The implementation is thread-safe if all delegates are thread-safe.
ItemWriters in fixed-order sequence.The implementation is thread-safe if all delegates are thread-safe.
Creates a fully qualified CompositeItemWriter.
Composite
JobParametersValidator that passes the job parameters through a
sequence of injected JobParametersValidatorsAllows a user to register one or more RepeatListeners to be notified on batch events.
Maps exit codes to
ExitStatus according to
injected map.Adapter for a
Consumer to an ItemWriter.Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0, scheduled for removal in 6.2 or later.
Post-process jobs and steps defined using the batch namespace to inject dependencies.
Utility methods used in parsing of the batch core namespace.
RuntimeHintsRegistrar for Spring Batch core module.Abstract base class for policies that need to count the number of occurrences of some
event (e.g. an exception type in the context), and terminate based on a limit for the
counter.
Enum representing a database type, such as DB2 or oracle.
Factory for creating
DataFieldMaxValueIncrementer implementations based upon a
provided string.This incrementer uses a
DataFieldMaxValueIncrementer to generate the sequence
of values to use as job instance discriminator.DB2 implementation of a
PagingQueryProvider using database specific features.Internal parser for the <decision/> elements inside a job.
State that requires a decider to make the status decision.
Base
Configuration class that provides common infrastructure beans for enabling
and using Spring Batch.Default implementation of the
DataFieldMaxValueIncrementerFactory interface.Default implementation of
ExceptionHandler - just re-throws the exception it
encounters.An implementation of the
ExecutionContextSerializer that produces/consumes
Base64 content.Default implementation of
FieldSet using Java primitive and standard types and
utilities.Default implementation of
FieldSetFactory with no special knowledge of the
FieldSet required.Default implementation of
FragmentEventReaderDeprecated, for removal: This API element is subject to removal in a future version.
Since 6.0 with no replacement.
Default implementation of the
JobKeyGenerator interface.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Converter for
JobParameters instances that uses a simple naming convention for
converting job parameters.Simple implementation of
JobParametersExtractor which pulls parameters with
named keys out of the step execution context and the job parameters of the surrounding
job.Default implementation of
JobParametersValidator.Two-phase
LineMapper implementation consisting of tokenization of the line into
FieldSet followed by mapping to item.This
MailErrorHandler implementation simply rethrows the exception it receives.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).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.Very simple
CompletionPolicy that bases its decision on the result of a batch
operation.Sorts by descending specificity of pattern, based on counting wildcards (with ?
Convenience class for aggregating a set of
StepExecution instances into a
single result.A
LineAggregator implementation that converts an object into a delimited list
of strings.A
LineTokenizer implementation that splits the input String on a configurable
delimiter.Derby implementation of a
PagingQueryProvider using database specific features.A
Poller that uses the callers thread to poll for a result as soon as it is
asked for.Checked exception that indicates a name clash when registering
Job instances.Indicates an error has been encountered while trying to dynamically invoke a method
e.g. using
MethodInvoker.Enable Spring Batch Integration features and provide a base configuration for setting
up remote chunking or partitioning infrastructure beans.
Enable Spring Batch features and provide a base configuration for setting up batch jobs
in an @Configuration class, roughly equivalent to using the
<batch:*> XML
namespace.Annotation to enable a JDBC-based infrastructure in a Spring Batch application.
* Annotation to enable a MongoDB-based job repository in a Spring Batch application.
State implementation for ending a job if it is in progress and continuing if
just starting.Batch Domain Entity class.
A
SkipPolicy that depends on an exception classifier to make its decision, and
then delegates to the classifier result.Handler to allow strategies for re-throwing exceptions.
Object representing a context for an
ItemStream.DAO interface for persisting and retrieving
ExecutionContexts.This class can be used to automatically promote items from the
Step
ExecutionContext to the Job ExecutionContext at the end of a
step.A composite interface that combines both serialization and deserialization of an
execution context into a single implementation.
Convenience class for accessing
ExecutionContext values from job and step
executions.Facilitates assigning names to objects persisting data in
ExecutionContext and
generating keys for ExecutionContext based on the name.This interface should be implemented when an environment calling the batch framework
has specific requirements regarding the operating system process return status.
Value object used to carry information about the status of a job or step execution.
Implementation of
SmartDataSource that is capable of keeping a single JDBC
Connection which is NOT closed after each use even if Connection.close() is
called.An abstract
LineAggregator implementation that utilizes a
FieldExtractor to convert the incoming object to an array of its parts.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0, use
ChunkOrientedStep instead.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0, use
ChunkOrientedStep instead.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0, use
ChunkOrientedStepBuilder instead.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0 with no replacement.
This class will convert an object to an array of its parts.
Interface used by flat file input sources to encapsulate concerns of converting an
array of Strings to Java native types.
Factory interface for creating
FieldSet instances.Interface that is used to map data obtained from a
FieldSet into an object.Utility methods for files used in batch processing.
Tokenizer used to process data obtained from files with fixed-length format.
Callback interface for writing a footer to a file.
Exception indicating that some type of error has occurred while attempting to parse a
line of input into tokens.
Callback interface for writing a header to a file.
Restartable
ItemReader that reads lines from input
FlatFileItemReader.setResource(Resource).A builder implementation for the
FlatFileItemReader.A builder for constructing a
DelimitedLineTokenizerA specification for configuring a delimited file tokenizer.
A builder for constructing a
FixedLengthTokenizerA specification for configuring a fixed length file tokenizer.
This class is an item writer that writes data to a file or stream.
A builder implementation for the
FlatFileItemWriterA builder for constructing a
DelimitedLineAggregatorSpecification for configuring a delimited line aggregator.
A builder for constructing a
FormatterLineAggregator.Specification for configuring a formatted line aggregator.
Exception thrown when errors are encountered parsing flat files.
A builder for a flow of steps that can be executed as a job or as part of a job.
A builder for building a split state.
A builder for transitions within a flow.
A builder for continuing a flow from a decision state.
Internal parser for the <flow/> elements inside a job.
Strategy interface for aggregating
FlowExecution instances into a single exit
status.Represents the status of
FlowExecution.Context and execution strategy for
FlowJob to allow it to delegate its
execution step by step.Convenient interface for components that contain nested flows.
Implementation of the
Job interface that allows for complex flows of steps,
rather than requiring sequential execution.A job builder for
FlowJob instances.State that delegates to a Flow
A step builder for
FlowStep instances.Unchecked exception indicating that an error has occurred while trying to flush a
buffer.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
A
LineAggregator implementation which produces a String by aggregating the
provided item via the Formatter syntax.Interface for event readers which support treating XML fragments as standalone XML
documents by wrapping the fragments with StartDocument and EndDocument events.
An
ItemProcessor implementation that delegates to a FunctionDeprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
A
Job that can optionally prepend a group name to another job's name, to make
it fit a naming convention for type or origin.A json object marshaller that uses Google
Gson to marshal an object into a json representation.
Implementation of
JsonObjectReader based on
Google Gson.H2 implementation of a
PagingQueryProvider using database specific features.SAP HANA implementation of a
PagingQueryProvider using database specific
features.A
MethodInvoker that is a bit relaxed about its arguments.HSQLDB implementation of a
PagingQueryProvider using database specific
features.Exception indicating that the line size expected is different from what is expected.
Exception indicating that an incorrect number of tokens have been found while parsing a
file.
RuntimeHintsRegistrar for Spring Batch infrastructure module.Internal parser for the <step/> elements inside a job.
AOT hints for Spring Batch integration module.
Exception for
Job to signal that some JobParameters are invalid.Marker interface indicating that an item should have the item count set on it.
Basic no-op implementation of the
ItemReadListener,
ItemProcessListener, and ItemWriteListener interfaces.A convenient strategy for SQL updates, acting effectively as the inverse of
RowMapper.Listener interface for the processing of an item.
Interface for item transformation.
Invokes a custom method on a delegate plain old Java object which itself processes an
item.
Strategy interface for providing the data.
Invokes a custom method on a delegate plain old Java object which itself provides an
item.
A base exception class that all exceptions thrown from an
ItemReader extend.Listener interface around the reading of an item.
A convenient strategy for providing SqlParameterSource for named parameter SQL updates.
Marker interface defining a contract for periodically storing state and restoring from
that state should an error occur.
Exception representing any errors encountered while processing a stream.
Convenience interface that combines
ItemStream and ItemReader .Support class for
ItemStreams.Convenience interface that combines
ItemStream and ItemWriter .
Listener interface for the writing of items.
Basic interface for generic output operations.
Delegates item processing to a custom method - passes the item as an argument for the
delegate method.
A base exception class that all exceptions thrown from an
ItemWriter extend.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0 in favor of
JacksonExecutionContextStringSerializer.An
ExecutionContextSerializer that uses Jackson 3 to serialize/deserialize the
execution context as JSON.A json object marshaller that uses Jackson 3 to marshal an object into a json
representation.
Implementation of
JsonObjectReader based on Jackson 3.ItemWriter that uses the batching features from
NamedParameterJdbcTemplate to execute a batch of statements for all items
provided.A builder implementation for the
JdbcBatchItemWriter.
Simple item reader implementation that opens a JDBC cursor and continually retrieves
the next row in the ResultSet.
Builder for the
JdbcCursorItemReaderBase
Configuration class that provides common JDBC-based infrastructure beans
for enabling and using Spring Batch.JDBC DAO for
ExecutionContext.JDBC implementation of
JobExecutionDao.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
JdbcJobRepositoryFactoryBean.JDBC implementation of
JobInstanceDao.A
FactoryBean that automates the creation of a SimpleJobRepository
using JDBC DAO implementations which persist batch metadata in a relational database.ItemReader for reading database records using JDBC in a paging fashion.This is a builder for the
JdbcPagingItemReader.Helper methods for SQL statement parameter parsing.
JDBC implementation of
Allows customization of the tables names used by Spring Batch for step meta data via a prefix property.
Uses sequences or tables (via Spring's
StepExecutionDao.Allows customization of the tables names used by Spring Batch for step meta data via a prefix property.
Uses sequences or tables (via Spring's
DataFieldMaxValueIncrementer
abstraction) to create all primary keys before inserting a new row.An
ItemReader for JMS using a JmsTemplate.Creates a fully qualified JmsItemReader.
An
ItemWriter for JMS using a JmsTemplate.Creates a fully qualified JmsItemWriter.
A
MethodArgumentsKeyGenerator for JMSA
NewMethodArgumentsIdentifier for JMS that looks for a message in the
arguments and checks its delivery status.Batch domain object representing a job.
Convenience for building jobs of various kinds.
A base class and utility for other job builders providing access to common properties
like job repository.
A context object that can be used to interrogate the current
JobExecution and
some of its associated properties using expressions based on bean paths.Batch domain object representing the execution of a job.
Data Access Object for job executions.
Interface allowing for programmatic access to the decision on what the status of a flow
should be.
Root of exception hierarchy for checked exceptions in job and step execution.
Provide callbacks at specific points in the lifecycle of a
Job.Parser for a step listener element.
Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 in favor of
JobRestartException with a specific message.Checked exception indicating that a JobExecution that is not currently running has been
requested to stop.
Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 in favor of
JobExecutionAlreadyRunningException.A shutdown hook that attempts to gracefully stop a running job execution when the JVM
is exiting.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
JobRepository.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
JdbcJobRepositoryFactoryBean.Deprecated, for removal: This API element is subject to removal in a future version.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Implementation of
FlowExecutor for use in components that need to execute a
flow related to a JobExecution.Batch domain object representing a uniquely identifiable job run.
An exception indicating an illegal attempt to restart a job that was already completed
successfully.
Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 with no replacement.
Data Access Object for job instances.
Exception to indicate the job has been interrupted.
Strategy interface for the generation of the key used in identifying unique
JobInstance objects.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
JobOperator.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0 in favor of
JobOperatorTestUtils.The
JobLaunchingGateway is used to launch Batch Jobs.The parser for the Job-Launching Gateway, which will instantiate a
JobLaunchingGatewayParser.Message handler which uses strategies to convert a Message into a job and a set of job
parameters
Encapsulation of a
Job and its JobParameters forming a request for a
job to be launched.Interface for handling a
JobLaunchRequest and returning a JobExecution.This
AbstractListenerFactoryBean implementation is used to create a
JobExecutionListener.Enumeration for
JobExecutionListener meta data, which ties together the names
of methods, their interfaces, annotation, and expected arguments.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
JobRegistry.High level interface for operating batch jobs.
Convenient factory bean that creates a transactional proxy around a
JobOperator.
Utility class for testing batch jobs.
Domain representation of a parameter to a batch job.
This class can be used to automatically copy items from the
JobParameters to
the Step ExecutionContext.Value object representing runtime parameters of a batch job.
Helper class for creating
JobParameters.Exception to report an error when converting job parameters.
A factory for
JobParameters instances.Strategy interface for translating a
StepExecution into JobParameters.Interface for obtaining the next
JobParameters object in a sequence.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with not replacement.
Strategy interface for a
Job to use in validating its parameters for an
execution.Parser for the <job/> element in the Batch namespace.
This
FactoryBean is used by the batch namespace parser to create
FlowJob objects.A runtime service registry interface for registering job configurations by
name.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Repository responsible for persistence of batch meta-data entities.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
JdbcJobRepositoryFactoryBean.Parser for the <job-repository/> element in the Batch namespace.
Convenience class for creating and removing
JobExecution instances from a
database.An exception indicating an illegal attempt to restart a job.
Convenient annotation for job-scoped beans that defaults the proxy mode, so that it
does not have to be specified explicitly on every bean definition.
Scope for job context.
Convenient aspect to wrap a single threaded job execution, where the implementation of
the
Job is not job scope aware (i.e. not the ones provided by the framework).A
TestExecutionListener that sets up job-scope context for dependency injection
into unit tests.Utility class for creating and manipulating
JobScope in unit tests.A step builder for
JobStep instances.Central convenience class for framework use in managing the job scope context.
ItemStreamReader implementation based on JPA Query.getResultStream().Builder for
JpaCursorItemReader.ItemWriter that is using a JPA EntityManagerFactory to merge any Entities that
aren't part of the persistence context.A builder for the
JpaItemWriter.This query provider creates JPA named
Querys.This query provider creates JPA
queries from injected native SQL queries.ItemReader for reading database records built on top of JPA.Creates a fully qualified JpaPagingItemReader.
Interface defining the functionality to be provided for generating queries for use with
JPA
ItemReaders or other custom-built artifacts.Item writer that writes data in json format to an output file.
Builder for
JsonFileItemWriter.ItemStreamReader implementation that reads Json objects from a Resource
having the following format:A builder for
JsonItemReader.Converter for
JobParameters instances based on Jackson 3 and that uses a JSON
naming convention for converting job parameters.Interpret a line as a JSON object and parse it up to a Map.
Strategy interface to marshal an object into a json representation.
Strategy interface for Json readers.
JSON-based record separator.
Implementation of the
CommandRunner interface that calls the standard
Runtime.exec(String) method.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
An
ItemReader implementation for Apache Kafka.A builder implementation for the
KafkaItemReader.
An
ItemWriter implementation for Apache Kafka using a KafkaTemplate
with default topic configured.A builder implementation for the
KafkaItemWriterDeprecated, for removal: This API element is subject to removal in a future version.
Since 6.0 in favor of equals/hashcode in a wrapper type if needed.
A base class to implement any
ItemWriter that writes to a key value store using
a Converter to derive a key from an item.Comparator to sort resources by the file last modified time.
Creates a fully qualified LdifReader.
A composite
SkipPolicy that checks if the exception is assignable from one of
the given skippable exceptions, and counts the number of skips to not exceed a given
limit.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0, use
LimitCheckingExceptionHierarchySkipPolicy instead.Interface used to create string representing object.
Callback interface for handling a line from file.
Interface for mapping lines (strings) to domain objects typically used to map lines
read from a file to domain objects on a per line basis.
Interface that is used by framework to split string obtained typically from a file into
tokens.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0, scheduled for removal in 6.2 or later.
Interface for listing
Steps by name.A common interface for listener meta data enumerations.
An
ItemReader that pulls data from a list.Item writer that writes items to a
List.Implementation of
ExceptionHandler based on an Classifier.Logging levels for the handler.
This class is used to handle errors that occur when email messages are unable to be
sent.
Simple, thread-safe, map-based implementation of
JobRegistry.Adapts an
ItemWriter accepting items of type U to one accepting items
of type T by applying a mapping function to each item before writing.Creates a fully qualified MappingLdifReader.
Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 with no replacement.
MariaDB implementation of a
PagingQueryProvider using database specific
features.Implementation of the
FlowExecutionAggregator interface that aggregates
FlowExecutionStatus', using the status with the high precedence as the
aggregate status.An
ItemReader implementation that receives items as messages from a message
channel using a MessagingTemplate.An
ItemWriter implementation that sends items as messages to a message channel
using a MessagingTemplate.A
PartitionHandler that uses MessageChannel instances to send
instructions to remote workers and receive their responses.A
ChannelInterceptor that turns a pollable channel into a "pass-thru channel":
if a client calls receive() on the channel it will delegate to a
MessageSource to pull the message directly from an external source.A strategy interface for invoking a method.
MethodInterceptor that, given a map of method names and MethodInvokers,
will execute all methods tied to a particular method name, with the provided arguments.Utility methods for create MethodInvoker instances.
A
Tasklet that wraps a method in a POJO.Strategy interface for detecting a single Method on a Class.
Central class for Micrometer metrics.
A simple
ItemWriter that can send mail messages.Cursor-based
ItemReader implementation for MongoDB.Base
Configuration class that provides common MongoDB-based infrastructure
beans for enabling and using Spring Batch.
A
ItemWriter implementation that writes to a MongoDB store using an
implementation of Spring Data's MongoOperations.Operation mode of the item writer.
A builder implementation for the
MongoItemWriterDeprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
MongoJobRepositoryFactoryBean.This factory bean creates a job repository backed by MongoDB.
Restartable
ItemReader that reads documents from MongoDB via a paging
technique.Builder for
MongoPagingItemReader.Reads items from multiple resources sequentially - resource list is given by
MultiResourceItemReader.setResources(Resource[]), the actual reading is delegated to
MultiResourceItemReader.setDelegate(ResourceAwareItemReaderItemStream).A builder implementation for the
MultiResourceItemReader.Wraps a
ResourceAwareItemWriterItemStream and creates a new output resource
when the count of items written in current resource exceeds
MultiResourceItemWriter.setItemCountLimitPerResource(int).A builder implementation for the
MultiResourceItemWriter.Implementation of
Partitioner that locates multiple resources and associates
their file names with execution context keys.MySQL implementation of a
PagingQueryProvider using database specific features.Callback that delegates to another callback, via a
RepeatOperations instance.SkipPolicy implementation that always returns false, indicating that an item
should not be skipped.Fatal exception to be thrown when a process operation could not be skipped.
Fatal exception to be thrown when a read operation could not be skipped.
Fatal exception to be thrown when a process operation could not be skipped.
Exception thrown when errors are encountered with the underlying resource.
Exception indicating that an error has been encountered doing I/O from a reader, and
the exception should be considered fatal.
Delegating XMLEventWriter, which ignores start and end document events, but passes
through everything else.
Checked exception to indicate that a required
Job is not available.Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 with no replacement.
Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 with no replacement.
Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 with no replacement.
Exception to signal that a step was requested that is unknown or does not exist.
Fails the step if no items have been processed ( item count is 0).
Marks a method to be called after a chunk has failed.
Marks a method to be called if an exception is thrown by an
ItemProcessor.Marks a method to be called if an exception is thrown by an
ItemReader.Marks a method to be called when an item is skipped due to an exception thrown in the
Expected signature: void onSkipInProcess(T item,
ItemProcessor.Expected signature: void onSkipInProcess(T item,
Throwable t)Marks a method to be called when an item is skipped due to an exception thrown in the
ItemReader.Marks a method to be called when an item is skipped due to an exception thrown in the
Expected signature: void onSkipInWrite(S item,
ItemWriter.Expected signature: void onSkipInWrite(S item,
Throwable t)Marks a method to be called if an exception is thrown by an
ItemWriter.Oracle implementation of a
PagingQueryProvider using database specific
features.The direction of the sort in an ORDER BY clause.
Interface defining the functionality to be provided for generating paging queries for
use with Paging Item Readers.
Exception indicating that an error has been encountered parsing IO, typically from a
file.
Central strategy interface for creating input parameters for a partitioned step in the
form of
ExecutionContext instances.Interface defining the responsibilities of controlling the execution of a partitioned
StepExecution.
Optional interface for
Partitioner implementations that need to use a custom
naming scheme for partitions.Implementation of
Step which partitions the execution and spreads the load
using a PartitionHandler.Step builder for
PartitionStep instances.FieldExtractor that just returns the original item.Pass through
FieldSetMapper useful for passing a FieldSet back directly
rather than a mapped object.Simple
ItemProcessor that does nothing - simply passes its argument through to
the caller.A
LineAggregator implementation that simply calls Object.toString() on
the given objectPass through
LineMapper useful for passing the original String back
directly rather than a mapped object.
A
LineMapper implementation that stores a mapping of String patterns to
delegate LineTokenizers as well as a mapping of String patterns to delegate
FieldSetMappers.A
LineTokenizer implementation that stores a mapping of String patterns to
delegate LineTokenizers.
A specialisation of
ItemReader that allows the user to look ahead into the
stream of items.Interface for polling a
Callable instance provided by the user.Postgres implementation of a
PagingQueryProvider using database specific
features.A filtering
ItemProcessor that is based on a Predicate.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Delegates processing to a custom method - extracts property values from item object and
uses them as arguments for the delegate method.
A class to represent ranges.
Property editor implementation which parses string and creates array of ranges.
Exception indicating that an
ItemReader needed to be opened before read.This interface can be used to operate on skipped records during open in the
LdifReader and the MappingLdifReader.This is a field extractor for a Java record.
This is a
FieldSetMapper that supports Java records mapping (requires JKD 14 or
higher).This interface should be implemented to map
LdapAttributes
objects to POJOs.Policy for text file-based input sources to determine the end of a record, e.g. a
record might be a single line, or it might be multiple lines terminated by a semicolon.
An implementation of
LineAggregator that concatenates a collection of items of
a common type with a line separator.Item reader for Redis based on Spring Data Redis.
Builder for
RedisItemReader.
An
ItemWriter implementation for Redis using a RedisTemplate .Builder for
RedisItemWriter.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Provides reflection based utilities for Spring Batch that are not available in Spring
Framework.
Line-tokenizer using a regular expression to filter out data (by using matching and
non-matching groups).
Convenient factory bean for a chunk handler that also converts an existing
chunk-oriented step into a remote chunk manager.
Parser for the remote-chunking-manager namespace element.
Builder for a manager step in a remote chunking setup.
Convenient factory for a
RemoteChunkingManagerStepBuilder which sets the
JobRepository and PlatformTransactionManager automatically.Builder for a worker in a remote chunking setup.
Parser for the remote-chunking-worker namespace element.
Builder for a manager step in a remote partitioning setup.
Convenient factory for a
RemotePartitioningManagerStepBuilder which sets the
JobRepository and BeanFactory automatically.Builder for a worker step in a remote partitioning setup.
Convenient factory for a
RemotePartitioningWorkerStepBuilder which sets the
JobRepository and BeanFactory automatically.A
Step implementation that delegates the
execution to a remote worker step through messaging.Convenience class for aggregating a set of
StepExecution instances when the
input comes from remote steps, so the data need to be refreshed from the repository.Callback interface for batch operations.
Base interface for context which controls the state and completion / termination of a
batch step.
Helper class for policies that need to count the number of occurrences of some event
(e.g. an exception type in the context) in the scope of a batch.
Internal interface for extensions of
RepeatTemplate.Interface for listeners to the batch process.
The main interface providing access to batch operations.
A
MethodInterceptor that can be used to automatically repeat calls to a method
on a service.Global variable support for repeat clients.
Simple implementation and base class for batch templates implementing
RepeatOperations.
A
ItemReader that reads records utilizing a PagingAndSortingRepository.A builder implementation for the
RepositoryItemReader.
A
ItemWriter wrapper for a
CrudRepository from Spring Data.A builder implementation for the
RepositoryItemWriter.Establishes a proxy that will capture the Repository and the associated methodName
that will be used by the writer.
Marker interface indicating that an item should have the Spring
Resource in
which it was read from, set on it.A
JobRepository implementation that does not use or store batch meta-data.ItemReader which produces Resource instances from an array.Strategy interface for translating resource index into unique filename suffix.
Deprecated, for removal: This API element is subject to removal in a future version.
since 5.0 with no replacement.
Implementation of
ExceptionHandler that rethrows when exceptions of a given
type reach a threshold.This incrementer increments a "run.id" parameter of type
Long from the given
job parameters.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement, for removal in 6.2 or later.
ItemProcessor implementation that passes the current item to process to the
provided script.Creates a fully qualified ScriptItemProcessor.
A
BufferedReaderFactory useful for reading simple binary (or text) files with
no line endings, such as those produced by mainframe copy books.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0, use
ChunkOrientedStep instead.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0, use
ChunkOrientedStep instead.Policy for terminating a batch after a fixed number of operations.
Convenience factory for
SimpleFlow instances for use in the XML namespace.A State that proxies a delegate and changes its name but leaves its behavior
unchanged.
Simple implementation of
Job interface providing the ability to run a
JobExecution.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
SimpleJobRepository.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
TaskExecutorJobOperator.
Implementation of
JobRepository that stores job instances, job executions, and
step executions using the injected DAOs.An implementation of
ExitCodeMapper that can be configured through a map from
batch exit codes (String) to integer results.Simple implementation of exception handler which looks for given exception types.
A simple
ItemWriter that can send mail messages.Creates a fully qualified SimpleMailMessageItemWriter.
Simple implementation of the
MethodInvoker interface that invokes a method on
an object.Simplest possible implementation of
Partitioner.Simplest possible
RecordSeparatorPolicy - treats all lines as record endings.Trivial implementation of
ResourceSuffixCreator that uses the index itself as
suffix, separated by dot.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0, use
ChunkOrientedStep instead.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0 in favor of
ChunkOrientedStepBuilder.Generic implementation of
StepExecutionSplitter that delegates to a
Partitioner to generate ExecutionContext instances.Deprecated, for removal: This API element is subject to removal in a future version.
Since 6.0 with no replacement.
Implementation of
StepHandler that manages repository and restart concerns.Simple
SystemProcessExitCodeMapper implementation that performs following
mapping:
A
PeekableItemReader that allows the user to peek one item ahead.Creates a fully qualified SingleItemPeekeableItemReader.
Base exception indicating that the skip has failed or caused a failure.
Exception indicating that the skip limit for a particular
Step has been
exceeded.Interface for listener to skipped items.
Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 with no replacement.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Policy for determining whether or not some processing should be skipped.
Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 with no replacement.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
An implementation of
Converter that uses SpEL to map a Value to a keyInternal parser for the <split/> elements inside a job.
Annotation that can be specified on a test class that runs Spring Batch based tests.
Class that exposes the Spring Batch version.
Adapts the
Validator interface to
Validator.SQLite implementation of a
PagingQueryProvider using database specific
features.Factory bean for
PagingQueryProvider interface.Utility class that generates the actual SQL statements used by query providers.
SQL Server implementation of a
PagingQueryProvider using database specific
features.Internal parser for the <step/> elements for a job.
Indicates the step's start limit has been exceeded.
Value object representing a potential transition from one
State to another.Item reader for reading XML input based on StAX.
A fluent builder for the
StaxEventItemReaderAn implementation of
ItemWriter which uses StAX and Marshaller for
serializing object to XML.A builder for the
StaxEventItemWriter.Callback interface for writing to an XML file - useful e.g. for handling headers and
footers.
Batch domain interface representing the configuration of a step.
Convenient entry point for building all kinds of steps.
Utility exception thrown by builders when they encounter unexpected checked exceptions.
A base class and utility for other step builders providing access to common properties
like job repository and listeners.
A context object that can be used to interrogate the current
StepExecution and
some of its associated properties using expressions based on bean paths.Convenient base class for clients who need to do something in a repeat callback inside
a
Step.Represents a contribution to a
StepExecution, buffering changes until they can
be applied at a chunk boundary.A source of
StepContribution instances that can be aggregated and used to
update an ongoing StepExecution.Batch domain object representation for the execution of a step.
Strategy for aggregating step executions, usually when they are the result of
partitioned or remote execution.
A
ChannelInterceptor that adds the current StepExecution (if there is
one) as a header to the message.Listener interface for the lifecycle of a
Step.Class encapsulating information required to request a step execution in a remote
partitioning setup.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Strategy interface for generating input contexts for a partitioned step execution
independent from the fabric they are going to run on.
Interface for holders of a
Step as a convenience for callers who need access to
the underlying instance.Strategy interface for an interruption policy.
Marker interface that acts as a parent to all step domain listeners, such as:
StepExecutionListener, ChunkListener, ItemReadListener, and
ItemWriteListenerThis
AbstractListenerFactoryBean implementation is used to create a
StepListener.Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 with no replacement.
Enumeration for
StepListener meta data, which ties together the names of
methods, their interfaces, annotation, and expected arguments.Parser for a step listener element.
Basic no-op implementations of all
StepListener interfaces.Interface for locating a
Step instance by name.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
This
FactoryBean is used by the batch namespace parser to create Step
objects.Deprecated, for removal: This API element is subject to removal in a future version.
as of 6.0 with no replacement.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
JobOperatorTestUtils.startStep(String, JobParameters, ExecutionContext).
Convenient annotation for step-scoped beans.
Scope for step context.
Convenient aspect to wrap a single threaded step execution, where the implementation of
the
Step is not step scope aware (i.e. not the ones provided by the framework).A
TestExecutionListener that sets up step-scope context for dependency
injection into unit tests.Utility class for creating and manipulating
StepScope in unit tests.Central convenience class for framework use in managing the step scope context.
Extension of the
Step interface to be implemented by steps that support being
stopped.An extension to the
Tasklet interface to allow users to add logic for stopping
a tasklet.
Item reader implementation that executes a stored procedure and then reads the returned
cursor and continually retrieves the next row in the
ResultSet.A fluent builder API for the configuration of a
StoredProcedureItemReader.A
RecordSeparatorPolicy that looks for an exact match for a String at the end
of a line (e.g. a semicolon).Adapter for a
Supplier to an ItemReader.Sybase implementation of a
PagingQueryProvider using database specific
features.Central convenience class for framework use in managing the scope context.
An
AttributeAccessor that synchronizes on a mutex (not this) before modifying
or accessing the underlying attributes.This is an
ItemReader decorator with a synchronized ItemReader.read()
method.Builder for
SynchronizedItemReader.This is a simple ItemStreamReader decorator with a synchronized ItemReader.read()
method - which makes a non-thread-safe ItemReader thread-safe.
Creates a fully qualified SynchronizedItemStreamReader.
An
ItemStreamWriter decorator with a synchronized
write() method.Creates a fully qualified
SynchronizedItemStreamWriter.This is an
ItemWriter decorator with a synchronized ItemWriter.write(Chunk)
method.Builder for
SynchronizedItemWriter.Exception indicating failed execution of system command.
Tasklet that executes a system command.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Maps the exit code of a system process to ExitStatus value returned by a system
command.
Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 in favor of
TaskExecutorJobOperator.A
TaskExecutor-based implementation of the
JobOperator interface.A
PartitionHandler that uses a TaskExecutor to execute the partitioned
Step locally in multiple threads.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement, scheduled for removal in 7.0.
Strategy for processing in a step.
Parse a tasklet element for a step.
Simple implementation of executing the step as a call to a
Tasklet, possibly
repeated, and each call surrounded by a transaction.Builder for tasklet step based on a custom tasklet (not item oriented).
Policy that checks the current thread to see if it has been interrupted.
Deprecated, for removal: This API element is subject to removal in a future version.
since 5.0 with no replacement.
Termination policy that times out after a fixed period.
Parse <job-listener/> elements in the batch namespace.
Parse <step-listener/> elements in the batch namespace.
Parser for the <step/> top level element in the Batch namespace.
Wrapper for a
FileChannel that delays actually writing to or closing the buffer
if a transaction is active.Deprecated, for removal: This API element is subject to removal in a future version.
since 6.0 with no replacement.
Convenience wrapper for a checked exception so that it can cause a rollback and be
extracted afterwards.
Delegating XMLEventWriter, which collects the QNames of elements that were opened but
not closed.
Used to signal an unexpected end of an input or message stream.
Indicates to the framework that a critical error has occurred and processing should
immediately stop.
Delegating XMLEventWriter, which writes EndElement events that match a given collection
of QNames directly to the underlying java.io.Writer instead of to the delegate
XMLEventWriter.
Simple implementation of
ItemProcessor that validates input and returns it
without modifications.This exception should be thrown when there are validation errors.
Interface used to validate objects.
Unchecked exception indicating that an error has occurred while trying to clear a
buffer on a rollback.
Exception indicating that an
ItemWriter needed to be opened before being
written to.