| Name | Description | Type | Package | Framework |
| AbstractApplicationContextFactory | ApplicationContextFactory implementation that takes a parent context and a path to the context to create. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| AbstractBatchConfiguration | Base Configuration class providing common structure for enabling and using Spring Batch. | Class | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| AbstractCursorItemReader | Abstract base class for any simple item reader that opens a database cursor and continually retrievesthe next row in the ResultSet. | Class | org.springframework.batch.item.database | Spring Batch |
|
| AbstractFlowParser | | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| AbstractHibernateQueryProvider | Abstract Hibernate Query Provider to serve as a base class for allHibernate Query providers. | Class | org.springframework.batch.item.database.orm | Spring Batch |
|
| AbstractItemCountingItemStreamItemReader | Abstract superclass for ItemReaders that supports restart by storingitem count in the ExecutionContext (therefore requires item ordering | Class | org.springframework.batch.item.support | Spring Batch |
|
| AbstractItemStreamItemReader | Base class for ItemReader implementations. | Class | org.springframework.batch.item.support | Spring Batch |
|
| AbstractItemStreamItemWriter | Base class for ItemWriter implementations. | Class | org.springframework.batch.item.support | Spring Batch |
|
| AbstractJdbcBatchMetadataDao | Encapsulates common functionality needed by JDBC batch metadata DAOs -provides jdbcTemplate for subclasses and handles table prefixes. | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| AbstractJob | Abstract implementation of the Job interface. | Class | org.springframework.batch.core.job | Spring Batch |
|
| AbstractJobExplorerFactoryBean | A FactoryBean that automates the creation of aSimpleJobExplorer. | Class | org.springframework.batch.core.explore.support | Spring Batch |
|
| AbstractJobRepositoryFactoryBean | A FactoryBean that automates the creation of aSimpleJobRepository. | Class | org.springframework.batch.core.repository.support | Spring Batch |
|
| AbstractJobTests | Base class for testing batch jobs. | Class | org.springframework.batch.test | Spring Batch |
|
| AbstractJpaQueryProvider | Abstract JPA Query Provider to serve as a base class for all JPASince:2. | Class | org.springframework.batch.item.database.orm | Spring Batch |
|
| AbstractLineTokenizer | Abstract class handling common concerns of various LineTokenizerAuthor:Dave Syer, Robert Kasanicky, Lucas Ward, Michael Minella | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| AbstractListenerFactoryBean | FactoryBean implementation that builds a listener based on thevarious lifecycle methods or annotations that are provided. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| AbstractListenerParser | | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| AbstractMethodInvokingDelegator | Superclass for delegating classes which dynamically call a custom method ofinjected object. | Class | org.springframework.batch.item.adapter | Spring Batch |
|
| AbstractPaginatedDataItemReader | A base class that handles basic reading logic based on the paginatedsemantics of Spring Data's paginated facilities. | Class | org.springframework.batch.item.data | Spring Batch |
|
| AbstractPagingItemReader | Abstract ItemStreamReader for to extend whenreading database records in a paging fashion. | Class | org.springframework.batch.item.database | Spring Batch |
|
| AbstractPartitionHandler | Base PartitionHandler implementation providing common basefeatures. | Class | org.springframework.batch.core.partition.support | Spring Batch |
|
| AbstractSqlPagingQueryProvider | Abstract SQL Paging Query Provider to serve as a base class for all providedSQL paging query providers. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| AbstractState | | Class | org.springframework.batch.core.job.flow.support.state | Spring Batch |
|
| AbstractStep | A Step implementation that provides common behavior to subclasses, including registering and callingAuthor:Dave Syer, Ben Hale, Robert Kasanicky, Michael Minella, Chris Schaefer | Class | org.springframework.batch.core.step | Spring Batch |
|
| AbstractStepParser | Internal parser for the elements inside a job. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| AbstractTaskletStepBuilder | Base class for step builders that want to build a TaskletStep. | Class | org.springframework.batch.core.step.builder | Spring Batch |
|
| Address | | Class | org.springframework.batch.sample.domain.order | Spring Batch |
|
| AddressFieldExtractor | | Class | org.springframework.batch.sample.domain.order.internal.extractor | Spring Batch |
|
| AddressFieldSetMapper | | Class | org.springframework.batch.sample.domain.order.internal.mapper | Spring Batch |
|
| AggregateItem | A wrapper type for an item that is used by AggregateItemReader toidentify the start and end of an aggregate record. | Class | org.springframework.batch.sample.domain.multiline | Spring Batch |
|
| AggregateItemFieldSetMapper | Delegating mapper to convert form a vanilla FieldSetMapper to onethat returns AggregateItem instances for consumption by the | Class | org.springframework.batch.sample.domain.multiline | Spring Batch |
|
| AggregateItemReader | An ItemReader that delivers a list as its item, storing up objectsfrom the injected ItemReader until they are ready to be packed out as | Class | org.springframework.batch.sample.domain.multiline | Spring Batch |
|
| Alignment | | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| AlwaysSkipItemSkipPolicy | will always return that an item should be skipped. | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| AmqpItemReader | AMQP ItemReader implementation using an AmqpTemplate toreceive and/or convert messages. | Class | org.springframework.batch.item.amqp | Spring Batch |
|
| AmqpItemWriter | AMQP ItemWriter implementation using an AmqpTemplate tosend messages. | Class | org.springframework.batch.item.amqp | Spring Batch |
|
| AmqpMessageProducer | Simple producer class that sends String messages to the configured queue to be processed. | Class | org.springframework.batch.sample.rabbitmq.amqp | Spring Batch |
|
| AnnotationMethodResolver | MethodResolver implementation that finds a single Method on thegiven Class that contains the specified annotation type. | Class | org.springframework.batch.support | Spring Batch |
|
| ApplicationContextFactory | Factory for the creation of ApplicationContexts. | Interface | org.springframework.batch.core.configuration.support | Spring Batch |
|
| ApplicationContextJobFactory | A JobFactory that creates its own ApplicationContext andpulls a bean out when asked to create a Job. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| ArrayFieldSetMapper | A basic array mapper, returning the values backing a fieldset. | Class | org.springframework.batch.item.file.mapping | Spring Batch |
|
| AssertFile | This class can be used to assert that two files are the same. | Class | org.springframework.batch.test | Spring Batch |
|
| AsynchronousFailureException | Exception indicating that a failure or early completion condition wasdetected in a remote worker. | Class | org.springframework.batch.integration.chunk | Spring Batch |
|
| AsyncItemProcessor | An ItemProcessor that delegates to a nested processor and in thebackground. | Class | org.springframework.batch.integration.async | Spring Batch |
|
| AsyncItemWriter | | Class | org.springframework.batch.integration.async | Spring Batch |
|
| AutomaticJobRegistrar | Loads and unloads Jobs when the application context is created and destroyed. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| BaseContextListFactoryBean | A simple factory bean that consolidates the list of locations to look for the base context for the JSR-352Since:3. | Class | org.springframework.batch.core.jsr.configuration.support | Spring Batch |
|
| BatchArtifactType | enum BatchArtifactTypeEnum to identify batch artifact types. | Class | org.springframework.batch.core.jsr.configuration.support | Spring Batch |
|
| BatchConfigurationException | Represents an error has occured in the configuration of base batchinfrastructure (creation of a JobRepository | Class | org.springframework.batch.core.configuration | Spring Batch |
|
| BatchConfigurationSelector | Base Configuration class providing common structure for enabling and using Spring Batch. | Class | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| BatchConfigurer | Strategy interface for users to provide as a factory for custom components needed by a Batch system. | Interface | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| BatchIntegrationNamespaceHandler | The namespace handler for the Spring Batch Integration namespace. | Class | org.springframework.batch.integration.config.xml | Spring Batch |
|
| BatchletAdapter | | Class | org.springframework.batch.core.jsr.step.batchlet | Spring Batch |
|
| BatchletParser | Parser for the tag defined in JSR-352. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| BatchletStep | Special sub class of the TaskletStep for use with JSR-352 jobs. | Class | org.springframework.batch.core.jsr.step | Spring Batch |
|
| BatchMessageListenerContainer | Message listener container adapted for intercepting the message receptionwith advice provided through configuration. | Class | org.springframework.batch.container.jms | Spring Batch |
|
| BatchParser | Parser used to parse the batch. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| BatchPropertyBeanPostProcessor | BeanPostProcessor implementation used to inject JSR-352 String properties into batch artifact fieldsthat are marked with the BatchProperty annotation. | Class | org.springframework.batch.core.jsr.launch.support | Spring Batch |
|
| BatchPropertyContext | Context object to hold parsed JSR-352 batch properties, mapping properties to beans /batch artifacts. | Class | org.springframework.batch.core.jsr.configuration.support | Spring Batch |
|
| BatchRetryTemplate | A special purpose retry template that deals specifically with multi-valuedstateful retry. | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| BatchScopeSupport | | Class | org.springframework.batch.core.scope | Spring Batch |
|
| BatchStatus | Enumeration representing the status of a an Execution. | Class | org.springframework.batch.core | Spring Batch |
|
| BeanDefinitionUtils | | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| BeanFactoryStepLocator | A StepLocator implementation that just looks in its enclosing beanfactory for components of type Step. | Class | org.springframework.batch.integration.partition | Spring Batch |
|
| BeanPropertyItemSqlParameterSourceProvider | A convenient implementation for providing BeanPropertySqlParameterSource when the item has JavaBean propertiesthat correspond to names used for parameters in the SQL statement. | Class | org.springframework.batch.item.database | Spring Batch |
|
| BeanWrapperFieldExtractor | This is a field extractor for a java bean. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| BeanWrapperFieldSetMapper | FieldSetMapper implementation based on bean property paths. | Class | org.springframework.batch.item.file.mapping | Spring Batch |
|
| BeforeJob | Marks a method to be called before a Job is executed, which comesafter a JobExecution is created and persisted, but before the first | Class | org.springframework.batch.core.annotation | Spring Batch |
|
| BeforeStep | Marks a method to be called before a Step is executed, which comesafter a StepExecution is created and persisted, but before the first | Class | org.springframework.batch.core.annotation | Spring Batch |
|
| BillingFieldSetMapper | | Class | org.springframework.batch.sample.domain.order.internal.mapper | Spring Batch |
|
| BillingInfo | | Class | org.springframework.batch.sample.domain.order | Spring Batch |
|
| BillingInfoFieldExtractor | | Class | org.springframework.batch.sample.domain.order.internal.extractor | Spring Batch |
|
| BufferedReaderFactory | A factory strategy for custom extensions of BufferedReader allowingcustomisation of the standard behaviour of the java. | Interface | org.springframework.batch.item.file | Spring Batch |
|
| CallableTaskletAdapter | | Class | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| CheckpointAlgorithmAdapter | Wrapper for the CheckpointAlgorithm to be used via the restAuthor:Michael MinellaSee Also:CheckpointAlgorithm, | Class | org.springframework.batch.jsr.repeat | Spring Batch |
|
| CheckpointSupport | Provides support for JSR-352 checkpointing. | Class | org.springframework.batch.jsr.item | Spring Batch |
|
| Child | | Class | org.springframework.batch.sample.domain.person | Spring Batch |
|
| Chunk | Encapsulation of a list of items to be processed and possibly a list offailed items to be skipped. | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| ChunkContext | Context object for weakly typed data stored for the duration of a chunk(usually a group of items processed together in a transaction). | Class | org.springframework.batch.core.scope.context | Spring Batch |
|
| ChunkElementParser | Internal parser for the element inside a step. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| ChunkHandler | Interface for a remote worker in the Remote Chunking pattern. | Interface | org.springframework.batch.integration.chunk | Spring Batch |
|
| ChunkListener | Listener interface for the lifecycle of a chunk. | Interface | org.springframework.batch.core | Spring Batch |
|
| ChunkListenerAdapter | Wrapper class to adapt the ChunkListener toSince:3. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| ChunkListenerSupport | Basic support implementation of ChunkListenerAuthor:Lucas Ward, Michael Minella | Class | org.springframework.batch.core.listener | Spring Batch |
|
| ChunkMessageChannelItemWriter | | Class | org.springframework.batch.integration.chunk | Spring Batch |
|
| ChunkMonitor | Manage the offset data between the last successful commit and updates made toan input chunk. | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| ChunkOrientedTasklet | | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| ChunkParser | Parser for the element as specified in JSR-352. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| ChunkProcessor | Interface defined for processing Chunks. | Interface | org.springframework.batch.core.step.item | Spring Batch |
|
| ChunkProcessorChunkHandler | A ChunkHandler based on a ChunkProcessor. | Class | org.springframework.batch.integration.chunk | Spring Batch |
|
| ChunkProvider | Interface for providing Chunks to be processed, used by theChunkOrientedTasklet | Interface | org.springframework.batch.core.step.item | Spring Batch |
|
| ChunkRequest | Encapsulation of a chunk of items to be processed remotely as part of a stepAuthor:Dave SyerSee Also:Serialized Form | Class | org.springframework.batch.integration.chunk | Spring Batch |
|
| ChunkResponse | Encapsulates a response to processing a chunk of items, summarising the result as a StepContribution. | Class | org.springframework.batch.integration.chunk | Spring Batch |
|
| ClassifierCompositeItemProcessor | Calls one of a collection of ItemProcessors, based on a routerpattern implemented through the provided Classifier. | Class | org.springframework.batch.item.support | Spring Batch |
|
| ClassifierCompositeItemWriter | Calls one of a collection of ItemWriters for each item, based on a routerpattern implemented through the provided Classifier. | Class | org.springframework.batch.item.support | Spring Batch |
|
| ClassPathXmlApplicationContextFactory | ApplicationContextFactory implementation that takes a parent contextand a path to the context to create. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| ClasspathXmlApplicationContextsFactoryBean | A convenient factory for creating a set of ApplicationContextFactorycomponents from a set of resources. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| ClassPathXmlJobRegistry | Placeholder for deprecation warning. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| ColumnMapItemPreparedStatementSetter | keys are contained within a Map with the column name as the key. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| ColumnRangePartitioner | Simple minded partitioner for a range of values of a column in a databasetable. | Class | org.springframework.batch.sample.common | Spring Batch |
|
| CommandLineJobRunner | Basic launcher for starting jobs from the command line. | Class | org.springframework.batch.core.launch.support | Spring Batch |
|
| CommonsLoggingInvalidCustomerLogger | | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| CompletionPolicy | Interface for batch completion policies, to enable batch operations tostrategise normal completion conditions. | Interface | org.springframework.batch.repeat | Spring Batch |
|
| CompletionPolicySupport | Very simple base class for CompletionPolicy implementations. | Class | org.springframework.batch.repeat.policy | Spring Batch |
|
| CompositeChunkListener | | Class | org.springframework.batch.core.listener | Spring Batch |
|
| CompositeCompletionPolicy | Composite policy that loops through a list of delegate policies and answerscalls by a consensus. | Class | org.springframework.batch.repeat.policy | Spring Batch |
|
| CompositeCustomerUpdateLineTokenizer | Composite LineTokenizer that delegates the tokenization of a line to one of two potentialtokenizers. | Class | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CompositeExceptionHandler | Composiste ExceptionHandler that loops though a list of delegates. | Class | org.springframework.batch.repeat.exception | Spring Batch |
|
| CompositeItemProcessListener | | Class | org.springframework.batch.core.listener | Spring Batch |
|
| CompositeItemProcessor | Composite ItemProcessor that passes the item through a sequence ofinjected ItemTransformers (return value of previous | Class | org.springframework.batch.item.support | Spring Batch |
|
| CompositeItemReadListener | | Class | org.springframework.batch.core.listener | Spring Batch |
|
| CompositeItemStream | Simple ItemStream that delegates to a list of other streams. | Class | org.springframework.batch.item.support | Spring Batch |
|
| CompositeItemWriteListener | | Class | org.springframework.batch.core.listener | Spring Batch |
|
| CompositeItemWriter | Calls a collection of ItemWriters in fixed-order sequence. | Class | org.springframework.batch.item.support | Spring Batch |
|
| CompositeJobExecutionListener | | Class | org.springframework.batch.core.listener | Spring Batch |
|
| CompositeJobParametersValidator | Composite JobParametersValidator that passes the job parameters through a sequence ofinjected JobParametersValidators | Class | org.springframework.batch.core.job | Spring Batch |
|
| CompositeRepeatListener | | Class | org.springframework.batch.repeat.listener | Spring Batch |
|
| CompositeRetryProcessListener | Composite class holding RetryProcessListener's. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| CompositeRetryReadListener | Composite class holding RetryReadListener's. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| CompositeRetryWriteListener | Composite class holding RetryWriteListener's. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| CompositeSkipListener | | Class | org.springframework.batch.core.listener | Spring Batch |
|
| CompositeSkipPolicy | | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| CompositeStepExecutionListener | | Class | org.springframework.batch.core.listener | Spring Batch |
|
| ConfigurableSystemProcessExitCodeMapper | Maps exit codes to ExitStatusaccording to injected map. | Class | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| ConversionException | | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| CoreNamespaceHandler | | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| CoreNamespacePostProcessor | Post-process jobs and steps defined using the batch namespace to injectSince:2. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| CoreNamespaceUtils | Utility methods used in parsing of the batch core namespaceAuthor:Thomas Risberg, Michael Minella | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| CountingCompletionPolicy | Abstract base class for policies that need to count the number of occurrencesof some event (e. | Class | org.springframework.batch.repeat.policy | Spring Batch |
|
| Customer | | Class | org.springframework.batch.sample.domain.order | Spring Batch |
|
| Customer | This is a complex type. | Class | org.springframework.batch.sample.domain.order.internal.xml | Spring Batch |
|
| CustomerCredit | | Class | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CustomerCreditDao | Interface for writing customer's credit information to output. | Interface | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CustomerCreditFieldSetMapper | | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| CustomerCreditIncreaseProcessor | Increases customer's credit by a fixed amount. | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| CustomerCreditItemWriter | Delegates actual writing to a custom DAO. | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| CustomerCreditRepository | org. | Interface | org.springframework.batch.sample.data | Spring Batch |
|
| CustomerCreditRowMapper | | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| CustomerCreditUpdatePreparedStatementSetter | | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| CustomerCreditUpdateWriter | | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| CustomerDao | java. | Interface | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CustomerDebit | | Class | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CustomerDebitDao | Interface for writing CustomerDebitDao object to arbitrary output. | Interface | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CustomerDebitRowMapper | | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| CustomerFieldExtractor | | Class | org.springframework.batch.sample.domain.order.internal.extractor | Spring Batch |
|
| CustomerFieldSetMapper | | Class | org.springframework.batch.sample.domain.order.internal.mapper | Spring Batch |
|
| CustomerOperation | enum CustomerOperationEnum representing on of 3 possible actions on a customer update: | Class | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CustomerUpdate | Immutable Value Object representing an update to the customer as stored in the database. | Class | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CustomerUpdateFieldSetMapper | FieldSetMapper for mapping to a CustomerUpdate. | Class | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CustomerUpdateProcessor | | Class | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CustomerUpdateWriter | | Class | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| CustomerUpdateWriter | Transforms Trade to a CustomerDebit and asks DAO delegate to write theAuthor:Robert Kasanicky | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| DatabaseType | Enum representing a database type, such as DB2 or oracle. | Class | org.springframework.batch.support | Spring Batch |
|
| DataFieldMaxValueIncrementerFactory | Factory for creating DataFieldMaxValueIncrementer implementationsbased upon a provided string. | Interface | org.springframework.batch.item.database.support | Spring Batch |
|
| DataSourceConfiguration | | Class | org.springframework.batch.sample.config | Spring Batch |
|
| DataSourceInitializer | Wrapper for a DataSource that can run scripts on start up and shutdown. | Class | org.springframework.batch.test | Spring Batch |
|
| Db2PagingQueryProvider | DB2 implementation of a PagingQueryProvider usingdatabase specific features. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| DecisionParser | Internal parser for the elements inside a job. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| DecisionState | State that requires a decider to make the status decision. | Class | org.springframework.batch.core.job.flow.support.state | Spring Batch |
|
| DecisionStep | as defined by JSR-352. | Class | org.springframework.batch.core.jsr.step | Spring Batch |
|
| DecisionStepFactoryBean | FactoryBean for creating a DecisionStep. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| DefaultBatchConfigurer | | Class | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| DefaultBufferedReaderFactory | | Class | org.springframework.batch.item.file | Spring Batch |
|
| DefaultDataFieldMaxValueIncrementerFactory | Default implementation of the DataFieldMaxValueIncrementerFactoryinterface. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| DefaultExceptionHandler | Default implementation of ExceptionHandler - just re-throws the exception it encounters. | Class | org.springframework.batch.repeat.exception | Spring Batch |
|
| DefaultExecutionContextSerializer | An implementation of the ExecutionContextSerializer using the defaultserialization implementations from Spring (DefaultSerializer and | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| DefaultFieldSet | Default implementation of FieldSet using Java using Java primitiveand standard types and utilities. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| DefaultFieldSetFactory | Default implementation of FieldSetFactory with no special knowledgeof the FieldSet required. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| DefaultFragmentEventReader | Default implementation of FragmentEventReaderAuthor:Robert Kasanicky | Class | org.springframework.batch.item.xml.stax | Spring Batch |
|
| DefaultItemFailureHandler | Default implementation of the ItemListenerSupport class thatwrites all exceptions via commons logging. | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| DefaultJobKeyGenerator | Default implementation of the JobKeyGenerator interface. | Class | org.springframework.batch.core | Spring Batch |
|
| DefaultJobLoader | Default implementation of JobLoader. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| DefaultJobLoader | | Class | org.springframework.batch.sample.launch | Spring Batch |
|
| DefaultJobParametersConverter | Converter for JobParameters instances using a simple namingconvention for property keys. | Class | org.springframework.batch.core.converter | Spring Batch |
|
| DefaultJobParametersExtractor | Simple implementation of JobParametersExtractor which pullsparameters with named keys out of the step execution context and the job | Class | org.springframework.batch.core.step.job | Spring Batch |
|
| DefaultJobParametersValidator | Default implementation of JobParametersValidator. | Class | org.springframework.batch.core.job | Spring Batch |
|
| DefaultLineMapper | Two-phase LineMapper implementation consisting of tokenization of the line into FieldSet followed bymapping to item. | Class | org.springframework.batch.item.file.mapping | Spring Batch |
|
| DefaultMailErrorHandler | This MailErrorHandler implementation simply rethrows the exception itSince:2. | Class | org.springframework.batch.item.mail | Spring Batch |
|
| DefaultPropertyEditorRegistrar | A re-usable PropertyEditorRegistrar that can be used wherever oneneeds to register custom PropertyEditor instances with a | Class | org.springframework.batch.support | Spring Batch |
|
| DefaultRecordSeparatorPolicy | A RecordSeparatorPolicy that treats all lines as record endings, aslong as they do not have unterminated quotes, and do not end in a | Class | org.springframework.batch.item.file.separator | Spring Batch |
|
| DefaultResultCompletionPolicy | Very simple CompletionPolicy that bases its decision on the result ofa batch operation. | Class | org.springframework.batch.repeat.policy | Spring Batch |
|
| DefaultStateTransitionComparator | Sorts by decreasing specificity of pattern, based on just countingwildcards (with * taking precedence over ?). | Class | org.springframework.batch.core.job.flow.support | Spring Batch |
|
| DefaultStepExecutionAggregator | Convenience class for aggregating a set of StepExecution instancesinto a single result. | Class | org.springframework.batch.core.partition.support | Spring Batch |
|
| DelegateStep | Provides a wrapper for an existing Step, delegating execution to it,but serving all other operations locally. | Class | org.springframework.batch.integration.step | Spring Batch |
|
| DelimitedLineAggregator | A LineAggregator implementation that converts an object into adelimited list of strings. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| DelimitedLineTokenizer | A LineTokenizer implementation that splits the input String on aconfigurable delimiter. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| DerbyPagingQueryProvider | Derby implementation of a PagingQueryProvider using standard SQL:2003 windowing functions. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| DirectPoller | A Poller that uses the callers thread to poll for a result as soon asit is asked for. | Class | org.springframework.batch.poller | Spring Batch |
|
| DummyItemWriter | | Class | org.springframework.batch.sample.support | Spring Batch |
|
| DuplicateJobException | Checked exception that indicates a name clash when registeringAuthor:Dave SyerSee Also:Serialized Form | Class | org.springframework.batch.core.configuration | Spring Batch |
|
| DynamicMethodInvocationException | Indicates an error has been encountered while trying to dynamically invoke amethod e. | Class | org.springframework.batch.item.adapter | Spring Batch |
|
| EnableBatchProcessing | Enable Spring Batch features and provide a base configuration for setting up batch jobs in an @Configurationclass, roughly equivalent to using the XML namespace. | Class | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| EndState | State implementation for ending a job if it is in progress andcontinuing if just starting. | Class | org.springframework.batch.core.job.flow.support.state | Spring Batch |
|
| Entity | Batch Domain Entity class. | Class | org.springframework.batch.core | Spring Batch |
|
| ExceptionClassifierSkipPolicy | A SkipPolicy that depends on an exception classifier to make itsdecision, and then delegates to the classifier result. | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| ExceptionElementParser | | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| ExceptionHandler | Handler to allow strategies for re-throwing exceptions. | Interface | org.springframework.batch.repeat.exception | Spring Batch |
|
| ExceptionThrowingItemReaderProxy | Hacked ItemReader that throws exception on a given record number(useful for testing restart). | Class | org.springframework.batch.sample.support | Spring Batch |
|
| ExecutionContext | Object representing a context for an ItemStream. | Class | org.springframework.batch.item | Spring Batch |
|
| ExecutionContextDao | DAO interface for persisting and retrieving ExecutionContexts. | Interface | org.springframework.batch.core.repository.dao | Spring Batch |
|
| ExecutionContextPromotionListener | This class can be used to automatically promote items from the StepExecutionContext to the Job ExecutionContext at the | Class | org.springframework.batch.core.listener | Spring Batch |
|
| ExecutionContextSerializer | A composite interface that combines both serialization and deserializationof an execution context into a single implementation. | Interface | org.springframework.batch.core.repository | Spring Batch |
|
| ExecutionContextTestUtils | Convenience class for accessing ExecutionContext values from job andSince:2. | Class | org.springframework.batch.test | Spring Batch |
|
| ExecutionContextUserSupport | Facilitates assigning names to objects persisting data in ExecutionContext and generating keys forExecutionContext based on the name. | Class | org.springframework.batch.item.util | Spring Batch |
|
| ExitCodeMapper | This interface should be implemented when an environment calling the batchframework has specific requirements regarding the operating system process | Interface | org.springframework.batch.core.launch.support | Spring Batch |
|
| ExitStatus | Value object used to carry information about the status of ajob or step execution. | Class | org.springframework.batch.core | Spring Batch |
|
| ExtendedConnectionDataSourceProxy | JDBC Connection which is NOT closed after each use even ifConnection. | Class | org.springframework.batch.item.database | Spring Batch |
|
| ExtractorLineAggregator | An abstract LineAggregator implementation that utilizes aFieldExtractor to convert the incoming object to an array of its | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| FatalStepExecutionException | | Class | org.springframework.batch.core.step | Spring Batch |
|
| FaultTolerantChunkProcessor | FaultTolerant implementation of the ChunkProcessor interface, thatallows for skipping or retry of items that cause exceptions during writing. | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| FaultTolerantChunkProvider | FaultTolerant implementation of the ChunkProcessor interface, thatallows for skipping or retry of items that cause exceptions during reading or | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| FaultTolerantStepBuilder | A step builder for fully fault tolerant chunk-oriented item processing steps. | Class | org.springframework.batch.core.step.builder | Spring Batch |
|
| FaultTolerantStepFactoryBean | Factory bean for step that provides options for configuring skip behavior. | Class | org.springframework.batch.core.step.factory | Spring Batch |
|
| FieldExtractor | This class will convert an object to an array of its parts. | Interface | org.springframework.batch.item.file.transform | Spring Batch |
|
| FieldSet | Interface used by flat file input sources to encapsulate concerns ofconverting an array of Strings to Java native types. | Interface | org.springframework.batch.item.file.transform | Spring Batch |
|
| FieldSetFactory | Factory interface for creating FieldSet instances. | Interface | org.springframework.batch.item.file.transform | Spring Batch |
|
| FieldSetMapper | Interface that is used to map data obtained from a FieldSet into anAuthor:Tomas Slanina, Dave Syer | Interface | org.springframework.batch.item.file.mapping | Spring Batch |
|
| FileUtils | Utility methods for files used in batch processing. | Class | org.springframework.batch.item.util | Spring Batch |
|
| FixedLengthTokenizer | Tokenizer used to process data obtained from files with fixed-length format. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| FlatFileCustomerCreditDao | Writes customer's credit information in a file. | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| FlatFileFooterCallback | Callback interface for writing a footer to a file. | Interface | org.springframework.batch.item.file | Spring Batch |
|
| FlatFileFormatException | Exception indicating that some type of error has occurred whileattempting to parse a line of input into tokens. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| FlatFileHeaderCallback | Callback interface for writing to a header to a file. | Interface | org.springframework.batch.item.file | Spring Batch |
|
| FlatFileItemReader | Restartable ItemReader that reads lines from input setResource(Resource). | Class | org.springframework.batch.item.file | Spring Batch |
|
| FlatFileItemWriter | This class is an item writer that writes data to a file or stream. | Class | org.springframework.batch.item.file | Spring Batch |
|
| FlatFileParseException | Exception thrown when errors are encounteredparsing flat files. | Class | org.springframework.batch.item.file | Spring Batch |
|
| Flow | | Interface | org.springframework.batch.core.job.flow | Spring Batch |
|
| FlowBuilder | A builder for a flow of steps that can be executed as a job or as part of a job. | Class | org.springframework.batch.core.job.builder | Spring Batch |
|
| FlowBuilderException | | Class | org.springframework.batch.core.job.builder | Spring Batch |
|
| FlowElementParser | Internal parser for the elements inside a job. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| FlowExecution | | Class | org.springframework.batch.core.job.flow | Spring Batch |
|
| FlowExecutionAggregator | Strategy interface for aggregating FlowExecution instances into aSince:2. | Interface | org.springframework.batch.core.job.flow.support.state | Spring Batch |
|
| FlowExecutionException | | Class | org.springframework.batch.core.job.flow | Spring Batch |
|
| FlowExecutionStatus | Represents the status of FlowExecution. | Class | org.springframework.batch.core.job.flow | Spring Batch |
|
| FlowExecutor | Context and execution strategy for FlowJob to allow it to delegateits execution step by step. | Interface | org.springframework.batch.core.job.flow | Spring Batch |
|
| FlowHolder | Convenient interface for components that contain nested flows. | Interface | org.springframework.batch.core.job.flow | Spring Batch |
|
| FlowJob | steps, rather than requiring sequential execution. | Class | org.springframework.batch.core.job.flow | Spring Batch |
|
| FlowJobBuilder | A job builder for FlowJob instances. | Class | org.springframework.batch.core.job.builder | Spring Batch |
|
| FlowParser | Parses flows as defined in JSR-352. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| FlowState | State that delegates to a FlowSince:2. | Class | org.springframework.batch.core.job.flow.support.state | Spring Batch |
|
| FlowStep | A Step implementation that delegates to a Flow. | Class | org.springframework.batch.core.job.flow | Spring Batch |
|
| FlowStepBuilder | A step builder for FlowStep instances. | Class | org.springframework.batch.core.step.builder | Spring Batch |
|
| FlushFailedException | Unchecked exception indicating that an error has occurred while trying to flush a buffer. | Class | org.springframework.batch.support.transaction | Spring Batch |
|
| FooterFieldExtractor | | Class | org.springframework.batch.sample.domain.order.internal.extractor | Spring Batch |
|
| ForceRollbackForWriteSkipException | Fatal exception to be thrown when a rollback must be forced, typically aftercatching an exception that otherwise would not cause a rollback. | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| FormatterLineAggregator | A LineAggregator implementation which produces a String byaggregating the provided item via the Formatter syntax. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| FragmentEventReader | Interface for event readers which support treating XML fragments as standalone XML documentsby wrapping the fragments with StartDocument and EndDocument events. | Interface | org.springframework.batch.item.xml.stax | Spring Batch |
|
| Game | | Class | org.springframework.batch.core.test.football | Spring Batch |
|
| Game | | Class | org.springframework.batch.sample.domain.football | Spring Batch |
|
| GameFieldSetMapper | | Class | org.springframework.batch.sample.domain.football.internal | Spring Batch |
|
| GemfireItemWriter | An ItemWriter that stores items in GemFireSince:2. | Class | org.springframework.batch.item.data | Spring Batch |
|
| GeneratingTradeItemReader | Generates configurable number of Trade items. | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| GeneratingTradeResettingListener | This listener resets the count of its GeneratingTradeItemReader after theSince:2. | Class | org.springframework.batch.sample.loop | Spring Batch |
|
| GenericApplicationContextFactory | ApplicationContextFactory implementation that takes a parent context and a path to the context to create. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| GroupAwareJob | 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. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| H2PagingQueryProvider | H2 implementation of a PagingQueryProvider using database specific features. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| HeaderCopyCallback | Designed to be registered with both FlatFileItemReaderand FlatFileItemWriter and copy header line from input | Class | org.springframework.batch.sample.support | Spring Batch |
|
| HeaderFieldExtractor | | Class | org.springframework.batch.sample.domain.order.internal.extractor | Spring Batch |
|
| HeaderFieldSetMapper | | Class | org.springframework.batch.sample.domain.order.internal.mapper | Spring Batch |
|
| HibernateAwareCustomerCreditItemWriter | Delegates writing to a custom DAO and flushes + clears hibernate session tofulfill the ItemWriter contract. | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| HibernateCreditDao | | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| HibernateCursorItemReader | ItemStreamReader for reading database records built on top of Hibernate. | Class | org.springframework.batch.item.database | Spring Batch |
|
| HibernateItemReaderHelper | | Class | org.springframework.batch.item.database | Spring Batch |
|
| HibernateItemWriter | ItemWriter that uses a Hibernate session to save or update entitiesthat are not part of the current Hibernate session. | Class | org.springframework.batch.item.database | Spring Batch |
|
| HibernateNativeQueryProvider | This query provider creates Hibernate Querys from injected native SQLqueries. | Class | org.springframework.batch.item.database.orm | Spring Batch |
|
| HibernatePagingItemReader | ItemReader for reading database records built on top of Hibernate andreading only up to a fixed number of items at a time. | Class | org.springframework.batch.item.database | Spring Batch |
|
| HibernateQueryProvider | Interface defining the functionality to be provided for generating queriesfor use with Hibernate ItemReaders or other custom built artifacts. | Interface | org.springframework.batch.item.database.orm | Spring Batch |
|
| HippyMethodInvoker | A MethodInvoker that is a bit relaxed about its arguments. | Class | org.springframework.batch.item.adapter | Spring Batch |
|
| HsqlPagingQueryProvider | HSQLDB implementation of a PagingQueryProvider using database specific features. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| IbatisBatchItemWriter | ItemWriter that uses the batching features fromSqlMapClient to execute a batch of statements for all items | Class | org.springframework.batch.item.database | Spring Batch |
|
| IbatisPagingItemReader | ItemReader for reading databaserecords using iBATIS in a paging fashion. | Class | org.springframework.batch.item.database | Spring Batch |
|
| IncorrectLineLengthException | Exception indicating that the line size expected is different from whatSince:1. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| IncorrectTokenCountException | Exception indicating that an incorrect number of tokens have been foundwhile parsing a file. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| InfiniteLoopReader | ItemReader implementation that will continually return a new object. | Class | org.springframework.batch.sample.common | Spring Batch |
|
| InfiniteLoopWriter | Simple module implementation that will always return true to indicate thatprocessing should continue. | Class | org.springframework.batch.sample.common | Spring Batch |
|
| InlineFlowParser | | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| InlineStepParser | Internal parser for the elements inside a job. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| IntArrayPropertyEditor | | Class | org.springframework.batch.support | Spring Batch |
|
| InvalidCustomerLogger | Interface for logging invalid customers. | Interface | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| ItemCountAware | Marker interface indicating that an item should have the item count set on it. | Interface | org.springframework.batch.item | Spring Batch |
|
| ItemListenerSupport | Basic no-op implementation of the ItemReadListener,ItemProcessListener, and ItemWriteListener interfaces. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| ItemPreparedStatementSetter | A convenient strategy for SQL updates, acting effectively as the inverse ofjava. | Interface | org.springframework.batch.item.database | Spring Batch |
|
| ItemProcessListener | Listener interface for the processing of an item. | Interface | org.springframework.batch.core | Spring Batch |
|
| ItemProcessListenerAdapter | Wrapper class for ItemProcessListenerSince:3. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| ItemProcessor | Interface for item transformation. | Interface | org.springframework.batch.item | Spring Batch |
|
| ItemProcessorAdapter | | Class | org.springframework.batch.item.adapter | Spring Batch |
|
| ItemProcessorAdapter | | Class | org.springframework.batch.jsr.item | Spring Batch |
|
| ItemReader | Strategy interface for providing the data. | Interface | org.springframework.batch.item | Spring Batch |
|
| ItemReaderAdapter | Invokes a custom method on a delegate plain old Java object which itselfAuthor:Robert Kasanicky | Class | org.springframework.batch.item.adapter | Spring Batch |
|
| ItemReaderAdapter | Adapter that wraps an ItemReader for use by Spring Batch. | Class | org.springframework.batch.jsr.item | Spring Batch |
|
| ItemReaderException | A base exception class that all exceptions thrown from an ItemReader extend. | Class | org.springframework.batch.item | Spring Batch |
|
| ItemReadListener | Listener interface around the reading of an item. | Interface | org.springframework.batch.core | Spring Batch |
|
| ItemReadListenerAdapter | Wrapper class to adapt the ItemReadListener toSince:3. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| ItemSqlParameterSourceProvider | A convenient strategy for providing SqlParameterSource for named parameter SQL updates. | Interface | org.springframework.batch.item.database | Spring Batch |
|
| ItemStream | Marker interface defining a contract for periodically storing state and restoring from that state should an errorAuthor:Dave Syer, Lucas Ward | Interface | org.springframework.batch.item | Spring Batch |
|
| ItemStreamException | Exception representing any errors encountered while processing a stream. | Class | org.springframework.batch.item | Spring Batch |
|
| ItemStreamReader | | Interface | org.springframework.batch.item | Spring Batch |
|
| ItemStreamSupport | Empty method implementation of ItemStream. | Class | org.springframework.batch.item | Spring Batch |
|
| ItemStreamWriter | | Interface | org.springframework.batch.item | Spring Batch |
|
| ItemWriteListener | Listener interface for the writing of items. | Interface | org.springframework.batch.core | Spring Batch |
|
| ItemWriteListenerAdapter | Wrapper class to adapt the ItemWriteListener toa ItemWriteListener. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| ItemWriter | Basic interface for generic output operations. | Interface | org.springframework.batch.item | Spring Batch |
|
| ItemWriterAdapter | Delegates item processing to a custom method -passes the item as an argument for the delegate method. | Class | org.springframework.batch.item.adapter | Spring Batch |
|
| ItemWriterAdapter | Adapter that wraps an ItemWriter for use by Spring Batch. | Class | org.springframework.batch.jsr.item | Spring Batch |
|
| ItemWriterException | A base exception class that all exceptions thrown from an ItemWriter extend. | Class | org.springframework.batch.item | Spring Batch |
|
| IteratorItemReader | An ItemReader that pulls data from a Iterator orIterable using the constructors. | Class | org.springframework.batch.item.support | Spring Batch |
|
| JdbcBatchItemWriter | ItemWriter that uses the batching features fromNamedParameterJdbcTemplate to execute a batch of statements for all items | Class | org.springframework.batch.item.database | Spring Batch |
|
| JdbcCursorItemReader | Simple item reader implementation that opens a JDBC cursor and continually retrieves thenext row in the ResultSet. | Class | org.springframework.batch.item.database | Spring Batch |
|
| JdbcCustomerDao | | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| JdbcCustomerDebitDao | Reduces customer's credit by the provided amount. | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| JdbcExecutionContextDao | JDBC DAO for ExecutionContext. | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| JdbcGameDao | | Class | org.springframework.batch.sample.domain.football.internal | Spring Batch |
|
| JdbcJobExecutionDao | JDBC implementation of JobExecutionDao. | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| JdbcJobInstanceDao | JDBC implementation of JobInstanceDao. | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| JdbcPagingItemReader | ItemReader for reading databaserecords using JDBC in a paging fashion. | Class | org.springframework.batch.item.database | Spring Batch |
|
| JdbcParameterUtils | Helper methods for SQL statement parameter parsing. | Class | org.springframework.batch.item.database | Spring Batch |
|
| JdbcPlayerDao | | Class | org.springframework.batch.sample.domain.football.internal | Spring Batch |
|
| JdbcPlayerSummaryDao | | Class | org.springframework.batch.sample.domain.football.internal | Spring Batch |
|
| JdbcStepExecutionDao | JDBC implementation of StepExecutionDao. | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| JdbcTradeDao | Writes a Trade object to a databaseAuthor:Robert Kasanicky | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| JmsItemReader | An ItemReader for JMS using a JmsTemplate. | Class | org.springframework.batch.item.jms | Spring Batch |
|
| JmsItemWriter | An ItemWriter for JMS using a JmsTemplate. | Class | org.springframework.batch.item.jms | Spring Batch |
|
| JmsMethodArgumentsKeyGenerator | | Class | org.springframework.batch.item.jms | Spring Batch |
|
| JmsMethodInvocationRecoverer | | Class | org.springframework.batch.item.jms | Spring Batch |
|
| JmsNewMethodArgumentsIdentifier | A NewMethodArgumentsIdentifier for JMS that looks for a message inthe arguments and checks its delivery status. | Class | org.springframework.batch.item.jms | Spring Batch |
|
| JmsRedeliveredExtractor | | Class | org.springframework.batch.integration.chunk | Spring Batch |
|
| Job | Batch domain object representing a job. | Interface | org.springframework.batch.core | Spring Batch |
|
| JobBuilder | Convenience for building jobs of various kinds. | Class | org.springframework.batch.core.job.builder | Spring Batch |
|
| JobBuilderException | | Class | org.springframework.batch.core.job.builder | Spring Batch |
|
| JobBuilderFactory | Convenient factory for a JobBuilder which sets the JobRepository automatically. | Class | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| JobBuilderHelper | A base class and utility for other job builders providing access to common properties like job repository. | Class | org.springframework.batch.core.job.builder | Spring Batch |
|
| JobContext | A context object that can be used to interrogate the current JobExecution and some of its associatedproperties using expressions | Class | org.springframework.batch.core.scope.context | Spring Batch |
|
| JobExecution | Batch domain object representing the execution of a job. | Class | org.springframework.batch.core | Spring Batch |
|
| JobExecutionAlreadyRunningException | | Class | org.springframework.batch.core.repository | Spring Batch |
|
| JobExecutionDao | Data Access Object for job executions. | Interface | org.springframework.batch.core.repository.dao | Spring Batch |
|
| JobExecutionDecider | Interface allowing for programmatic access to the decision on what the statusof a flow should be. | Interface | org.springframework.batch.core.job.flow | Spring Batch |
|
| JobExecutionException | Root of exception hierarchy for checked exceptions in job and step execution. | Class | org.springframework.batch.core | Spring Batch |
|
| JobExecutionListener | Provide callbacks at specific points in the lifecycle of a Job. | Interface | org.springframework.batch.core | Spring Batch |
|
| JobExecutionListenerParser | Parser for a step listener element. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| JobExecutionListenerSupport | | Class | org.springframework.batch.core.listener | Spring Batch |
|
| JobExecutionNotFailedException | Checked exception to indicate that user asked for a job execution to beresumed when actually it didn't fail. | Class | org.springframework.batch.core.launch | Spring Batch |
|
| JobExecutionNotificationPublisher | JMX notification broadcasterSince:1. | Class | org.springframework.batch.sample.jmx | Spring Batch |
|
| JobExecutionNotRunningException | Execution indicating that a JobExecution that is not currently running hasbeen requested to stop. | Class | org.springframework.batch.core.launch | Spring Batch |
|
| JobExecutionNotStoppedException | Checked exception to indicate that user asked for a job execution to beaborted when hasn't been stopped. | Class | org.springframework.batch.core.launch | Spring Batch |
|
| JobExplorer | Entry point for browsing executions of running or historical jobs and steps. | Interface | org.springframework.batch.core.explore | Spring Batch |
|
| JobExplorerFactoryBean | A FactoryBean that automates the creation of aSimpleJobExplorer using JDBC DAO implementations. | Class | org.springframework.batch.core.explore.support | Spring Batch |
|
| JobFactory | Strategy for creating a single job. | Interface | org.springframework.batch.core.configuration | Spring Batch |
|
| JobFactoryBean | This FactoryBean is used by the JSR-352 namespace parser to createFlowJob objects. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JobFactoryRegistrationListener | | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| JobFlowBuilder | | Class | org.springframework.batch.core.job.builder | Spring Batch |
|
| JobFlowExecutor | execute a flow related to a JobExecution. | Class | org.springframework.batch.core.job.flow | Spring Batch |
|
| JobInstance | Batch domain object representing a uniquely identifiable job run. | Class | org.springframework.batch.core | Spring Batch |
|
| JobInstanceAlreadyCompleteException | An exception indicating an illegal attempt to restart a job that was alreadycompleted successfully. | Class | org.springframework.batch.core.repository | Spring Batch |
|
| JobInstanceAlreadyExistsException | Checked exception to indicate that a required Job is notAuthor:Dave SyerSee Also:Serialized Form | Class | org.springframework.batch.core.launch | Spring Batch |
|
| JobInstanceDao | Data Access Object for job instances. | Interface | org.springframework.batch.core.repository.dao | Spring Batch |
|
| JobInterruptedException | Exception to indicate the the job has been interrupted. | Class | org.springframework.batch.core | Spring Batch |
|
| JobKeyGenerator | Strategy interface for the generation of the key used in identifyingSince:2. | Interface | org.springframework.batch.core | Spring Batch |
|
| JobLauncher | Simple interface for controlling jobs, including possible ad-hoc executions,based on different runtime identifiers. | Interface | org.springframework.batch.core.launch | Spring Batch |
|
| JobLauncherDetails | | Class | org.springframework.batch.sample.quartz | Spring Batch |
|
| JobLauncherTestUtils | Utility class for testing batch jobs. | Class | org.springframework.batch.test | Spring Batch |
|
| JobLaunchingGateway | The JobLaunchingGateway is used to launch Batch Jobs. | Class | org.springframework.batch.integration.launch | Spring Batch |
|
| JobLaunchingGatewayParser | The parser for the Job-Launching Gateway, which will instantiate aJobLaunchingGatewayParser. | Class | org.springframework.batch.integration.config.xml | Spring Batch |
|
| JobLaunchingMessageHandler | Message handler which uses strategies to convert a Message into a job and a set of job parametersAuthor:Jonas Partner, Dave Syer, Gunnar Hillert | Class | org.springframework.batch.integration.launch | Spring Batch |
|
| JobLaunchRequest | Encapsulation of a Job and its JobParameters forming a request for a job to be launched. | Class | org.springframework.batch.integration.launch | Spring Batch |
|
| JobLaunchRequestHandler | Interface for handling a JobLaunchRequest and returning a JobExecution. | Interface | org.springframework.batch.integration.launch | Spring Batch |
|
| JobListenerAdapter | Wrapper class to adapt the JobListener toa JobExecutionListener. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| JobListenerFactoryBean | This AbstractListenerFactoryBean implementation is used to create aJobExecutionListener. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| JobListenerMetaData | enum JobListenerMetaDataEnumeration for JobExecutionListener meta data, which ties together the names | Class | org.springframework.batch.core.listener | Spring Batch |
|
| JobLoader | | Interface | org.springframework.batch.core.configuration.support | Spring Batch |
|
| JobLoader | java. | Interface | org.springframework.batch.sample.launch | Spring Batch |
|
| JobLocator | A runtime service locator interface for retrieving job configurations byLocates a Job at runtime. | Interface | org.springframework.batch.core.configuration | Spring Batch |
|
| JobOperator | Low level interface for inspecting and controlling jobs with access only toprimitive and collection types. | Interface | org.springframework.batch.core.launch | Spring Batch |
|
| JobParameter | Domain representation of a parameter to a batch job. | Class | org.springframework.batch.core | Spring Batch |
|
| JobParameterExecutionContextCopyListener | This class can be used to automatically copy items from theJobParameters to the Step ExecutionContext. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| JobParameters | Value object representing runtime parameters to a batch job. | Class | org.springframework.batch.core | Spring Batch |
|
| JobParametersBuilder | Helper class for creating JobParameters. | Class | org.springframework.batch.core | Spring Batch |
|
| JobParametersConverter | A factory for JobParameters instances. | Interface | org.springframework.batch.core.converter | Spring Batch |
|
| JobParametersExtractor | | Interface | org.springframework.batch.core.step.job | Spring Batch |
|
| JobParametersIncrementer | Interface for obtaining the next JobParameters in a sequence. | Interface | org.springframework.batch.core | Spring Batch |
|
| JobParametersInvalidException | Exception for Job to signal that some JobParameters areAuthor:Dave SyerSee Also:Serialized Form | Class | org.springframework.batch.core | Spring Batch |
|
| JobParametersNotFoundException | Checked exception to indicate that a required JobParametersIncrementer is notAuthor:Dave SyerSee Also:Serialized Form | Class | org.springframework.batch.core.launch | Spring Batch |
|
| JobParametersValidator | Strategy interface for a Job to use in validating its parameters forCheck the parameters meet whatever requirements are appropriate, and | Interface | org.springframework.batch.core | Spring Batch |
|
| JobParser | Parser for the element in the Batch namespace. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| JobParserJobFactoryBean | This FactoryBean is used by the batch namespace parser to createFlowJob objects. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| JobRegistry | A runtime service registry interface for registering job configurations byRegisters a Job at runtime. | Interface | org.springframework.batch.core.configuration | Spring Batch |
|
| JobRegistryBackgroundJobRunner | Command line launcher for registering jobs with a JobRegistry. | Class | org.springframework.batch.core.launch.support | Spring Batch |
|
| JobRegistryBeanPostProcessor | A BeanPostProcessor that registers Job beans with aJobRegistry. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| JobRepository | Repository responsible for persistence of batch meta-data entities. | Interface | org.springframework.batch.core.repository | Spring Batch |
|
| JobRepositoryFactoryBean | A FactoryBean that automates the creation of aSimpleJobRepository using JDBC DAO implementations which persist | Class | org.springframework.batch.core.repository.support | Spring Batch |
|
| JobRepositoryParser | Parser for the element in the Batch namespace. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| JobRepositoryTestUtils | Convenience class for creating and removing JobExecution instancesfrom a database. | Class | org.springframework.batch.test | Spring Batch |
|
| JobRestartException | An exception indicating an illegal attempt to restart a job. | Class | org.springframework.batch.core.repository | Spring Batch |
|
| JobScope | Convenient annotation for job scoped beans that defaults the proxy mode, so that it doesn't have to be specifiedexplicitly on every bean definition. | Class | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| JobScope | Scope for job context. | Class | org.springframework.batch.core.scope | Spring Batch |
|
| JobScopeManager | Convenient aspect to wrap a single threaded job execution, where theprovided by the framework). | Class | org.springframework.batch.core.scope.context | Spring Batch |
|
| JobScopeTestExecutionListener | A TestExecutionListener that sets up job-scope context fordependency injection into unit tests. | Class | org.springframework.batch.test | Spring Batch |
|
| JobScopeTestUtils | Utility class for creating and manipulating JobScope in unit tests. | Class | org.springframework.batch.test | Spring Batch |
|
| JobStep | A Step that delegates to a Job to do its work. | Class | org.springframework.batch.core.step.job | Spring Batch |
|
| JobStepBuilder | A step builder for JobStep instances. | Class | org.springframework.batch.core.step.builder | Spring Batch |
|
| JobSynchronizationManager | Central convenience class for framework use in managing the job scopecontext. | Class | org.springframework.batch.core.scope.context | Spring Batch |
|
| JpaItemWriter | ItemWriter that is using a JPAEntityManagerFactory to merge any Entities that aren't part of the | Class | org.springframework.batch.item.database | Spring Batch |
|
| JpaNativeQueryProvider | This query provider creates JPA Querys from injected native SQLqueries. | Class | org.springframework.batch.item.database.orm | Spring Batch |
|
| JpaPagingItemReader | ItemReader for reading databaserecords built on top of JPA. | Class | org.springframework.batch.item.database | Spring Batch |
|
| JpaQueryProvider | Interface defining the functionality to be provided for generating queriesfor use with JPA ItemReaders or other custom built artifacts. | Interface | org.springframework.batch.item.database.orm | Spring Batch |
|
| JsonLineMapper | Interpret a line as a JSON object and parse it up to a Map. | Class | org.springframework.batch.item.file.mapping | Spring Batch |
|
| JsonRecordSeparatorPolicy | JSON-based record separator. | Class | org.springframework.batch.item.file.separator | Spring Batch |
|
| JsrAutowiredAnnotationBeanPostProcessor | This class overrides methods in the copied SpringAutowiredAnnotationBeanPostProcessor classto check for the BatchProperty annotation before processing injection annotations. | Class | org.springframework.batch.core.jsr.configuration.support | Spring Batch |
|
| JsrBatchletStepBuilder | Extension of the TaskletStepBuilder that uses a BatchletStep insteadSince:3. | Class | org.springframework.batch.core.jsr.step.builder | Spring Batch |
|
| JsrBeanDefinitionDocumentReader | DefaultBeanDefinitionDocumentReader extension to hook into the pre processing of the providedXML document, ensuring any references to property operators such as jobParameters and jobProperties are | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JsrBeanScopeBeanFactoryPostProcessor | In order for property resolution to occur correctly within the scope of a JSR-352batch job, initialization of job level artifacts must occur on the same thread that | Class | org.springframework.batch.core.jsr.partition.support | Spring Batch |
|
| JsrChunkProcessor | ChunkProcessor implementation that implements JSR-352's chunking pattern(read and process in a loop until the chunk is complete then write). | Class | org.springframework.batch.core.jsr.step.item | Spring Batch |
|
| JsrChunkProvider | A no-op ChunkProvider. | Class | org.springframework.batch.core.jsr.step.item | Spring Batch |
|
| JsrDecisionParser | Parser for the element as specified in JSR-352. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JsrEndState | State implementation for ending a job per JSR-352 rules if it isin progress and continuing if just starting. | Class | org.springframework.batch.core.jsr.job.flow.support.state | Spring Batch |
|
| JsrExpressionParser | Support class for parsing JSR-352 expressions. | Class | org.springframework.batch.core.jsr.configuration.support | Spring Batch |
|
| JsrFaultTolerantChunkProcessor | Extension of the JsrChunkProcessor that adds skip and retry functionality. | Class | org.springframework.batch.core.jsr.step.item | Spring Batch |
|
| JsrFaultTolerantStepBuilder | A step builder that extends the FaultTolerantStepBuilder to create JSR-352specific ChunkProvider and ChunkProcessor supporting both the chunking | Class | org.springframework.batch.core.jsr.step.builder | Spring Batch |
|
| JsrFlow | Flow implementation will attempt to find the next state based on the providedexit status. | Class | org.springframework.batch.core.jsr.job.flow.support | Spring Batch |
|
| JsrFlowExecutor | JSR-352 specific JobFlowExecutor. | Class | org.springframework.batch.core.jsr.job.flow | Spring Batch |
|
| JsrFlowFactoryBean | Extension to the SimpleFlowFactoryBean that provides JsrStepStateSince:3. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JsrFlowJob | JSR-352 specific extension of the FlowJob. | Class | org.springframework.batch.core.jsr.job.flow | Spring Batch |
|
| JsrJobContext | Wrapper class to provide the JobContext functionalityas specified in JSR-352. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| JsrJobContextFactoryBean | Provides a single JobContext for each thread in a running job. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| JsrJobExecution | Wrapper class to adapt the JobExecution toSince:3. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| JsrJobListenerFactoryBean | This FactoryBean is used by the JSR-352 namespace parser to createJobExecutionListener objects. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JsrJobListenerMetaData | enum JsrJobListenerMetaDataEnumeration for JobListener meta data, which ties together the names | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| JsrJobOperator | The entrance for executing batch jobs as defined by JSR-352. | Class | org.springframework.batch.core.jsr.launch | Spring Batch |
|
| JsrJobParametersConverter | Provides default conversion methodology for JSR-352's implementation. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| JsrJobParser | Parses a tag as defined in JSR-352. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JsrNamespaceHandler | | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JsrNamespacePostProcessor | | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JsrPartitionHandler | Executes a step instance per thread using a ThreadPoolTaskExecutor inaccordance with JSR-352. | Class | org.springframework.batch.core.jsr.partition | Spring Batch |
|
| JsrPartitionStepBuilder | An extension of the PartitionStepBuilder that uses PartitionStepso that JSR-352 specific semantics are honored. | Class | org.springframework.batch.core.jsr.step.builder | Spring Batch |
|
| JsrSampleBatchlet | Sample Batchlet implementation. | Class | org.springframework.batch.sample.jsr352 | Spring Batch |
|
| JsrSampleItemProcessor | Sample ItemProcessor implementation. | Class | org.springframework.batch.sample.jsr352 | Spring Batch |
|
| JsrSampleItemReader | Sample ItemReader implementation. | Class | org.springframework.batch.sample.jsr352 | Spring Batch |
|
| JsrSampleItemWriter | Sample ItemWriter implementation. | Class | org.springframework.batch.sample.jsr352 | Spring Batch |
|
| JsrSampleTasklet | Sample Tasklet implementation. | Class | org.springframework.batch.sample.jsr352 | Spring Batch |
|
| JsrSimpleStepBuilder | A step builder that extends the FaultTolerantStepBuilder to create JSR-352specific ChunkProvider and ChunkProcessor supporting the chunking | Class | org.springframework.batch.core.jsr.step.builder | Spring Batch |
|
| JsrSplitParser | Parses a element as defined in JSR-352. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JsrSplitState | JSR-352 states that artifacts cannot set the ExitStatus from within a split for a job. | Class | org.springframework.batch.core.jsr.job.flow.support.state | Spring Batch |
|
| JsrStepContext | Wrapper class to provide the StepContext functionalityas specified in JSR-352. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| JsrStepContextFactoryBean | FactoryBean implementation used to create StepContextinstances within the step scope. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| JsrStepExecution | wraps a StepExecution as it's source ofSince:3. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| JsrStepExecutionAggregator | Aggregates StepExecutions based on the rules outlined in JSR-352. | Class | org.springframework.batch.core.jsr.partition.support | Spring Batch |
|
| JsrStepExecutionSplitter | Provides JSR-352 specific behavior for the splitting of StepExecutions. | Class | org.springframework.batch.core.jsr.partition | Spring Batch |
|
| JsrStepHandler | | Class | org.springframework.batch.core.jsr.job | Spring Batch |
|
| JsrStepListenerFactoryBean | | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JsrStepListenerMetaData | enum JsrStepListenerMetaDataEnumeration for the JSR specific StepListener meta data, which | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| JsrStepState | last step that was executed was (used in Decisions and restarts). | Class | org.springframework.batch.core.jsr.job.flow.support.state | Spring Batch |
|
| JsrTestUtils | Provides testing utilities to execute JSR-352 jobs and block until they are complete (since all JSR-352 based jobsare executed asynchronously). | Class | org.springframework.batch.test | Spring Batch |
|
| JsrXmlApplicationContext | GenericApplicationContext implementation providing JSR-352 related context operations. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| JvmSystemExiter | System. | Class | org.springframework.batch.core.launch.support | Spring Batch |
|
| KeyGenerator | Interface for defining keys to uniquely identify items. | Interface | org.springframework.batch.core.step.item | Spring Batch |
|
| KeyValueItemWriter | A base class to implement any ItemWriter that writes to a key value storeusing a Converter to derive a key from an item | Class | org.springframework.batch.item | Spring Batch |
|
| LastModifiedResourceComparator | Comparator to sort resources by the file last modified time. | Class | org.springframework.batch.support | Spring Batch |
|
| LdifReader | The LdifReader is an adaptation of the FlatFileItemReaderbuilt around an LdifParser. | Class | org.springframework.batch.item.ldif | Spring Batch |
|
| LimitCheckingItemSkipPolicy | SkipPolicy that determines whether or not reading should continuebased upon how many items have been skipped. | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| LimitDecider | This decider will return CONTINUE until the limit it reached, at whichpoint it will return COMPLETE. | Class | org.springframework.batch.sample.loop | Spring Batch |
|
| LineAggregator | Interface used to create string representing object. | Interface | org.springframework.batch.item.file.transform | Spring Batch |
|
| LineCallbackHandler | Callback interface for handling a line from file. | Interface | org.springframework.batch.item.file | Spring Batch |
|
| LineItem | This is a complex type. | Class | org.springframework.batch.sample.domain.order.internal.xml | Spring Batch |
|
| LineItem | | Class | org.springframework.batch.sample.domain.order | Spring Batch |
|
| LineItemFieldExtractor | | Class | org.springframework.batch.sample.domain.order.internal.extractor | Spring Batch |
|
| LineMapper | Interface for mapping lines (strings) to domain objects typically used to map lines read from a file to domain objectson a per line basis. | Interface | org.springframework.batch.item.file | Spring Batch |
|
| LineTokenizer | Interface that is used by framework to split string obtained typically from aAuthor:tomas. | Interface | org.springframework.batch.item.file.transform | Spring Batch |
|
| ListableJobLocator | A listable extension of JobLocator. | Interface | org.springframework.batch.core.configuration | Spring Batch |
|
| ListenerMetaData | A common interface for listener meta data enumerations. | Interface | org.springframework.batch.core.listener | Spring Batch |
|
| ListenerParser | Parses the various listeners defined in JSR-352. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| ListItemReader | An ItemReader that pulls data from a list. | Class | org.springframework.batch.item.support | Spring Batch |
|
| ListItemWriter | | Class | org.springframework.batch.item.support | Spring Batch |
|
| ListPreparedStatementSetter | a list of values to be set on a PreparedStatement. | Class | org.springframework.batch.core.resource | Spring Batch |
|
| LogAdvice | Wraps calls for 'Processing' methods which output a single Object to writethe string representation of the object to the log. | Class | org.springframework.batch.sample.common | Spring Batch |
|
| LoggingItemWriter | | Class | org.springframework.batch.core.test.timeout | Spring Batch |
|
| LogOrRethrowExceptionHandler | The classifier determines whether to log the exception or rethrow it. | Class | org.springframework.batch.repeat.exception | Spring Batch |
|
| MailErrorHandler | This class is used to handle errors that occur when email messages are unableSince:2. | Interface | org.springframework.batch.item.mail | Spring Batch |
|
| MapExecutionContextDao | In-memory implementation of ExecutionContextDao backed by maps. | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| MapJobExecutionDao | In-memory implementation of JobExecutionDao. | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| MapJobExplorerFactoryBean | A FactoryBean that automates the creation of aSimpleJobExplorer using in-memory DAO implementations. | Class | org.springframework.batch.core.explore.support | Spring Batch |
|
| MapJobInstanceDao | In-memory implementation of JobInstanceDao. | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| MapJobRegistry | Simple, thread-safe, map-based implementation of JobRegistry. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| MapJobRepositoryFactoryBean | A FactoryBean that automates the creation of aSimpleJobRepository using non-persistent in-memory DAO | Class | org.springframework.batch.core.repository.support | Spring Batch |
|
| MappingLdifReader | The MappingLdifReader is an adaptation of the FlatFileItemReaderbuilt around an LdifParser. | Class | org.springframework.batch.item.ldif | Spring Batch |
|
| MapStepExecutionDao | In-memory implementation of StepExecutionDao. | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| MapStepRegistry | Simple map-based implementation of StepRegistry. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| MaxValueFlowExecutionAggregator | FlowExecutionStatus', using the status with the high precedence as theaggregate status. | Class | org.springframework.batch.core.job.flow.support.state | Spring Batch |
|
| MessageChannelPartitionHandler | A PartitionHandler that uses MessageChannel instances to send instructions to remote workers andreceive their responses. | Class | org.springframework.batch.integration.partition | Spring Batch |
|
| MessageProcessor | Simple ItemProcessor implementation to append a processed on Date to a received message. | Class | org.springframework.batch.sample.rabbitmq.processor | Spring Batch |
|
| MessageSourcePollerInterceptor | A ChannelInterceptor that turns a pollable channel into a pass-thru channel: if a client callsreceive() on the channel it will delegate to a MessageSource to pull the message directly from | Class | org.springframework.batch.integration.chunk | Spring Batch |
|
| MetaDataInstanceFactory | Convenience methods for creating test instances of JobExecution,JobInstance and StepExecution. | Class | org.springframework.batch.test | Spring Batch |
|
| MethodInvoker | A strategy interface for invoking a method. | Interface | org.springframework.batch.support | Spring Batch |
|
| MethodInvokerMethodInterceptor | MethodInterceptor that, given a map of method names andMethodInvokers, will execute all methods tied to a particular method | Class | org.springframework.batch.core.listener | Spring Batch |
|
| MethodInvokerUtils | Utility methods for create MethodInvoker instances. | Class | org.springframework.batch.support | Spring Batch |
|
| MethodInvokingTaskletAdapter | A Tasklet that wraps a method in a POJO. | Class | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| MethodResolver | Strategy interface for detecting a single Method on a Class. | Interface | org.springframework.batch.support | Spring Batch |
|
| MimeMessageItemWriter | A simple ItemWriter that can send mail messages. | Class | org.springframework.batch.item.mail.javamail | Spring Batch |
|
| ModularBatchConfiguration | Base Configuration class providing common structure for enabling and using Spring Batch. | Class | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| MongoItemReader | Restartable ItemReader that reads documents from MongoDBvia a paging technique. | Class | org.springframework.batch.item.data | Spring Batch |
|
| MongoItemWriter | A ItemWriter implementation that writes to a MongoDB store using an implementation of Spring Data'sMongoOperations. | Class | org.springframework.batch.item.data | Spring Batch |
|
| MulticasterBatchListener | | Class | org.springframework.batch.core.listener | Spring Batch |
|
| MultiResourceItemReader | Reads items from multiple resources sequentially - resource list is given by setResources(Resource[]), theactual reading is delegated to setDelegate(ResourceAwareItemReaderItemStream). | Class | org.springframework.batch.item.file | Spring Batch |
|
| MultiResourceItemWriter | Wraps a ResourceAwareItemWriterItemStream and creates a new outputresource when the count of items written in current resource exceeds | Class | org.springframework.batch.item.file | Spring Batch |
|
| MultiResourcePartitioner | associates their file names with execution context keys. | Class | org.springframework.batch.core.partition.support | Spring Batch |
|
| MySqlPagingQueryProvider | MySQL implementation of a PagingQueryProvider using database specific features. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| Neo4jItemReader | Restartable ItemReader that reads objects from the graph database Neo4jvia a paging technique. | Class | org.springframework.batch.item.data | Spring Batch |
|
| Neo4jItemWriter | A ItemWriter implementation that writes to a Neo4j database using anThis writer is thread-safe once all properties are set (normal singleton | Class | org.springframework.batch.item.data | Spring Batch |
|
| NestedRepeatCallback | Callback that delegates to another callback, via a RepeatOperationsinstance. | Class | org.springframework.batch.repeat.callback | Spring Batch |
|
| NeverSkipItemSkipPolicy | SkipPolicy implementation that always returns false,indicating that an item should not be skipped. | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| NonSkippableProcessException | Fatal exception to be thrown when a process operation could not be skipped. | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| NonSkippableReadException | Fatal exception to be thrown when a read operation could not be skipped. | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| NonSkippableWriteException | Fatal exception to be thrown when a process operation could not be skipped. | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| NonTransientFlatFileException | Exception thrown when errors are encountered with the underlying resource. | Class | org.springframework.batch.item.file | Spring Batch |
|
| NonTransientResourceException | Exception indicating that an error has been encountered doing I/O from areader, and the exception should be considered fatal. | Class | org.springframework.batch.item | Spring Batch |
|
| NoStartEndDocumentStreamWriter | Delegating XMLEventWriter, which ignores start and end document events,but passes through everything else. | Class | org.springframework.batch.item.xml.stax | Spring Batch |
|
| NoSuchJobException | Checked exception to indicate that a required Job is notAuthor:Dave SyerSee Also:Serialized Form | Class | org.springframework.batch.core.launch | Spring Batch |
|
| NoSuchJobExecutionException | Checked exception to indicate that a required JobExecution is notAuthor:Dave SyerSee Also:Serialized Form | Class | org.springframework.batch.core.launch | Spring Batch |
|
| NoSuchJobInstanceException | Exception that signals that the user requested an operation on a non-existentAuthor:Dave SyerSee Also:Serialized Form | Class | org.springframework.batch.core.launch | Spring Batch |
|
| NoSuchObjectException | This exception identifies that a batch domain object is invalid, whichis generally caused by an invalid ID. | Class | org.springframework.batch.core.repository.dao | Spring Batch |
|
| NoSuchStepException | Exception to signal that a step was requested that is unknown or does notAuthor:Dave SyerSee Also:Serialized Form | Class | org.springframework.batch.core.step | Spring Batch |
|
| NoWorkFoundStepExecutionListener | Fails the step if no items have been processed ( item count is 0). | Class | org.springframework.batch.core.step | Spring Batch |
|
| OraclePagingQueryProvider | Oracle implementation of aPagingQueryProvider using | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| Order | The direction of the sort in an ORDER BY clause. | Class | org.springframework.batch.item.database | Spring Batch |
|
| Order | This is a complex type. | Class | org.springframework.batch.sample.domain.order.internal.xml | Spring Batch |
|
| Order | | Class | org.springframework.batch.sample.domain.order | Spring Batch |
|
| OrderItemFieldSetMapper | | Class | org.springframework.batch.sample.domain.order.internal.mapper | Spring Batch |
|
| OrderItemReader | | Class | org.springframework.batch.sample.domain.order.internal | Spring Batch |
|
| OrderLineAggregator | Converts Order object to a list of strings. | Class | org.springframework.batch.sample.domain.order.internal | Spring Batch |
|
| OrderValidator | | Class | org.springframework.batch.sample.domain.order.internal.validator | Spring Batch |
|
| OutputFileListener | | Class | org.springframework.batch.sample.common | Spring Batch |
|
| OutputFileNameListener | | Class | org.springframework.batch.sample.common | Spring Batch |
|
| PagingQueryProvider | Interface defining the functionality to be provided for generating paging queries for use with PagingSince:2. | Interface | org.springframework.batch.item.database | Spring Batch |
|
| ParseException | Exception indicating that an error has been encountered parsing IO, typically from a file. | Class | org.springframework.batch.item | Spring Batch |
|
| PartitionCollectorAdapter | Adapter class used to wrap a PartitionCollector so that it can be consumedas a ChunkListener. | Class | org.springframework.batch.core.jsr.partition | Spring Batch |
|
| Partitioner | Central strategy interface for creating input parameters for a partitionedstep in the form of ExecutionContext instances. | Interface | org.springframework.batch.core.partition.support | Spring Batch |
|
| PartitionHandler | Interface defining the responsibilities of controlling the execution of apartitioned StepExecution. | Interface | org.springframework.batch.core.partition | Spring Batch |
|
| PartitionNameProvider | Optional interface for Partitioner implementations that need to use acustom naming scheme for partitions. | Interface | org.springframework.batch.core.partition.support | Spring Batch |
|
| PartitionParser | Parser for the element as defined by JSR-352. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| PartitionStep | An extension of the PartitionStep that provides additional semanticsrequired by JSR-352. | Class | org.springframework.batch.core.jsr.step | Spring Batch |
|
| PartitionStep | load using a PartitionHandler. | Class | org.springframework.batch.core.partition.support | Spring Batch |
|
| PartitionStepBuilder | Step builder for PartitionStep instances. | Class | org.springframework.batch.core.step.builder | Spring Batch |
|
| PassThroughFieldExtractor | FieldExtractor that just returns the original item. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| PassThroughFieldSetMapper | Pass through FieldSetMapper useful for passing a FieldSetback directly rather than a mapped object. | Class | org.springframework.batch.item.file.mapping | Spring Batch |
|
| PassThroughItemProcessor | Simple ItemProcessor that does nothing - simply passes its argumentthrough to the caller. | Class | org.springframework.batch.item.support | Spring Batch |
|
| PassThroughLineAggregator | A LineAggregator implementation that simply callsObject. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| PassThroughLineMapper | Pass through LineMapper useful for passing the originalString back directly rather than a mapped object. | Class | org.springframework.batch.item.file.mapping | Spring Batch |
|
| PatternMatcher | | Class | org.springframework.batch.support | Spring Batch |
|
| PatternMatchingCompositeLineMapper | A LineMapper implementation that stores a mapping of String patternsto delegate LineTokenizers as well as a mapping of String patterns to | Class | org.springframework.batch.item.file.mapping | Spring Batch |
|
| PatternMatchingCompositeLineTokenizer | A LineTokenizer implementation that stores a mapping of Stringpatterns to delegate LineTokenizers. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| PeekableItemReader | A specialisation of ItemReader that allows the user to look aheadinto the stream of items. | Interface | org.springframework.batch.item | Spring Batch |
|
| Person | | Class | org.springframework.batch.sample.domain.person | Spring Batch |
|
| PersonService | Custom class that contains logic that would normally be be contained inAuthor:tomas. | Class | org.springframework.batch.sample.domain.person | Spring Batch |
|
| PersonWriter | | Class | org.springframework.batch.sample.domain.person.internal | Spring Batch |
|
| Player | | Class | org.springframework.batch.core.test.football | Spring Batch |
|
| Player | | Class | org.springframework.batch.sample.domain.football | Spring Batch |
|
| PlayerDao | Interface for writing Player objects to arbitrary output. | Interface | org.springframework.batch.core.test.football | Spring Batch |
|
| PlayerDao | Interface for writing Player objects to arbitrary output. | Interface | org.springframework.batch.sample.domain.football | Spring Batch |
|
| PlayerItemWriter | | Class | org.springframework.batch.sample.domain.football.internal | Spring Batch |
|
| PlayerSummary | | Class | org.springframework.batch.core.test.football | Spring Batch |
|
| PlayerSummary | | Class | org.springframework.batch.sample.domain.football | Spring Batch |
|
| PlayerSummaryMapper | RowMapper used to map a ResultSet to a PlayerSummaryAuthor:Lucas WardSee Also:Serialized Form | Class | org.springframework.batch.sample.domain.football.internal | Spring Batch |
|
| PlayerSummaryRowMapper | RowMapper used to map a ResultSet to a PlayerSummaryAuthor:Lucas WardSee Also:Serialized Form | Class | org.springframework.batch.sample.domain.football.internal | Spring Batch |
|
| Poller | Interface for polling a Callable instance provided by the user. | Interface | org.springframework.batch.poller | Spring Batch |
|
| PostgresPagingQueryProvider | Postgres implementation of a PagingQueryProvider using database specific features. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| ProcessIndicatorItemWrapper | Item wrapper useful in process indicator usecase, where input is marked asprocessed by the processor/writer. | Class | org.springframework.batch.sample.common | Spring Batch |
|
| PropertiesConverter | Utility to convert a Properties object to a String and back. | Class | org.springframework.batch.support | Spring Batch |
|
| PropertyExtractingDelegatingItemWriter | Delegates processing to a custom method - extracts property values from itemobject and uses them as arguments for the delegate method. | Class | org.springframework.batch.item.adapter | Spring Batch |
|
| PropertyParser | Parser for the element defined by JSR-352. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| Range | A class to represent ranges. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| RangeArrayPropertyEditor | Property editor implementation which parses string and creates array ofranges. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| ReaderNotOpenException | Exception indicating that an ItemReader needed to be opened before read. | Class | org.springframework.batch.item | Spring Batch |
|
| RecordCallbackHandler | This interface can be used to operate on skipped records during open in the LdifReader and theExecute operations on the supplied record. | Interface | org.springframework.batch.item.ldif | Spring Batch |
|
| RecordMapper | This interface should be implemented to map LdapAttributes objects to POJOs. | Interface | org.springframework.batch.item.ldif | Spring Batch |
|
| RecordSeparatorPolicy | Policy for text file-based input sources to determine the end of a record,e. | Interface | org.springframework.batch.item.file.separator | Spring Batch |
|
| RecursiveCollectionLineAggregator | An implementation of LineAggregator that concatenates a collection ofitems of a common type with the system line separator. | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| ReferenceJobFactory | A JobFactory that just keeps a reference to a Job. | Class | org.springframework.batch.core.configuration.support | Spring Batch |
|
| ReflectionUtils | Provides reflection based utilities for Spring Batch that are not availableSince:2. | Class | org.springframework.batch.support | Spring Batch |
|
| RegexLineTokenizer | Line-tokenizer using a regular expression to filter out data (by using matching and non-matching groups). | Class | org.springframework.batch.item.file.transform | Spring Batch |
|
| RemoteChunkHandlerFactoryBean | Convenient factory bean for a chunk handler that also converts an existing chunk-oriented step into a remote chunkmaster. | Class | org.springframework.batch.integration.chunk | Spring Batch |
|
| RemoteStepExecutionAggregator | Convenience class for aggregating a set of StepExecution instanceswhen the input comes from remote steps, so the data need to be refreshed from | Class | org.springframework.batch.core.partition.support | Spring Batch |
|
| RepeatCallback | Callback interface for batch operations. | Interface | org.springframework.batch.repeat | Spring Batch |
|
| RepeatContext | Base interface for context which controls the state and completion /termination of a batch step. | Interface | org.springframework.batch.repeat | Spring Batch |
|
| RepeatContextCounter | Helper class for policies that need to count the number of occurrences ofsome event (e. | Class | org.springframework.batch.repeat.context | Spring Batch |
|
| RepeatContextSupport | | Class | org.springframework.batch.repeat.context | Spring Batch |
|
| RepeatException | | Class | org.springframework.batch.repeat | Spring Batch |
|
| RepeatInternalState | Internal interface for extensions of RepeatTemplate. | Interface | org.springframework.batch.repeat.support | Spring Batch |
|
| RepeatInternalStateSupport | | Class | org.springframework.batch.repeat.support | Spring Batch |
|
| RepeatListener | Interface for listeners to the batch process. | Interface | org.springframework.batch.repeat | Spring Batch |
|
| RepeatListenerSupport | Empty method implementation of RepeatListener. | Class | org.springframework.batch.repeat.listener | Spring Batch |
|
| RepeatOperations | The main interface providing access to batch operations. | Interface | org.springframework.batch.repeat | Spring Batch |
|
| RepeatOperationsInterceptor | A MethodInterceptor that can be used to automatically repeat calls toa method on a service. | Class | org.springframework.batch.repeat.interceptor | Spring Batch |
|
| RepeatStatus | | Class | org.springframework.batch.repeat | Spring Batch |
|
| RepeatSynchronizationManager | Global variable support for repeat clients. | Class | org.springframework.batch.repeat.support | Spring Batch |
|
| RepeatTemplate | Simple implementation and base class for batch templates implementingRepeatOperations. | Class | org.springframework.batch.repeat.support | Spring Batch |
|
| RepositoryItemReader | A ItemReader that reads records utilizinga PagingAndSortingRepository. | Class | org.springframework.batch.item.data | Spring Batch |
|
| RepositoryItemWriter | A ItemReader wrapper for aCrudRepository from Spring Data. | Class | org.springframework.batch.item.data | Spring Batch |
|
| ResourceAware | Marker interface indicating that an item should have the Spring Resource in which it was read from, set on it. | Interface | org.springframework.batch.item | Spring Batch |
|
| ResourceAwareItemReaderItemStream | Interface for ItemReaders that implement ItemStream and readinput from Resource. | Interface | org.springframework.batch.item.file | Spring Batch |
|
| ResourceAwareItemWriterItemStream | Interface for ItemWriters that implement ItemStream and writeAuthor:Robert Kasanicky | Interface | org.springframework.batch.item.file | Spring Batch |
|
| ResourcelessTransactionManager | | Class | org.springframework.batch.support.transaction | Spring Batch |
|
| ResourcesItemReader | ItemReader which produces Resource instances from an array. | Class | org.springframework.batch.item.file | Spring Batch |
|
| ResourceSuffixCreator | Strategy interface for translating resource index into unique filenameAuthor:Robert KasanickySee Also:MultiResourceItemWriter, | Interface | org.springframework.batch.item.file | Spring Batch |
|
| ResultHolderResultQueue | An implementation of the ResultQueue that throttles the number ofexpected results, limiting it to a maximum at any given time. | Class | org.springframework.batch.repeat.support | Spring Batch |
|
| RethrowOnThresholdExceptionHandler | given type reach a threshold. | Class | org.springframework.batch.repeat.exception | Spring Batch |
|
| RetryProcessListenerAdapter | Wrapper class to adapt a RetryProcessListener to a RetryListener. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| RetryReadListenerAdapter | Wrapper class to adapt a RetryReadListener to a RetryListener. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| RetrySampleConfiguration | | Class | org.springframework.batch.sample.config | Spring Batch |
|
| RetrySampleItemWriter | Simulates temporary output trouble - requires to retry 3 times to passAuthor:Robert Kasanicky | Class | org.springframework.batch.sample.support | Spring Batch |
|
| RetryWriteListenerAdapter | Wrapper class to adapt a RetryWriteListener to a RetryListener. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| RunIdIncrementer | | Class | org.springframework.batch.core.launch.support | Spring Batch |
|
| RuntimeExceptionTranslator | | Class | org.springframework.batch.core.launch.support | Spring Batch |
|
| ScheduledJobParametersFactory | | Class | org.springframework.batch.core.launch.support | Spring Batch |
|
| ScriptItemProcessor | ItemProcessor implementation that passes the currentitem to process to the provided script. | Class | org.springframework.batch.item.support | Spring Batch |
|
| Shipper | This is a complex type. | Class | org.springframework.batch.sample.domain.order.internal.xml | Spring Batch |
|
| ShippingFieldSetMapper | | Class | org.springframework.batch.sample.domain.order.internal.mapper | Spring Batch |
|
| ShippingInfo | | Class | org.springframework.batch.sample.domain.order | Spring Batch |
|
| SimpleBatchConfiguration | Base Configuration class providing common structure for enabling and using Spring Batch. | Class | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| SimpleBinaryBufferedReaderFactory | A BufferedReaderFactory useful for reading simple binary (or text)files with no line endings, such as those produced by mainframe copy books. | Class | org.springframework.batch.item.file | Spring Batch |
|
| SimpleChunkProcessor | Simple implementation of the ChunkProcessor interface that handlesbasic item writing and processing. | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| SimpleChunkProvider | Simple implementation of the ChunkProvider interface that does basic chunkproviding from an ItemReader. | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| SimpleCompletionPolicy | Policy for terminating a batch after a fixed number of operations. | Class | org.springframework.batch.repeat.policy | Spring Batch |
|
| SimpleFlow | A Flow that branches conditionally depending on the exit status ofthe last State. | Class | org.springframework.batch.core.job.flow.support | Spring Batch |
|
| SimpleFlowFactoryBean | Convenience factory for SimpleFlow instances for use in XML namespace. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| SimpleJob | Simple implementation of Job interface providing the ability to run aJobExecution. | Class | org.springframework.batch.core.job | Spring Batch |
|
| SimpleJobBuilder | | Class | org.springframework.batch.core.job.builder | Spring Batch |
|
| SimpleJobExplorer | | Class | org.springframework.batch.core.explore.support | Spring Batch |
|
| SimpleJobLauncher | Simple implementation of the JobLauncher interface. | Class | org.springframework.batch.core.launch.support | Spring Batch |
|
| SimpleJobOperator | Simple implementation of the JobOperator interface. | Class | org.springframework.batch.core.launch.support | Spring Batch |
|
| SimpleJobRepository | JobExecutions, and StepExecutions using the injected DAOs. | Class | org.springframework.batch.core.repository.support | Spring Batch |
|
| SimpleJvmExitCodeMapper | An implementation of ExitCodeMapper that can be configured through amap from batch exit codes (String) to integer results. | Class | org.springframework.batch.core.launch.support | Spring Batch |
|
| SimpleLimitExceptionHandler | Simple implementation of exception handler which looks for given exceptiontypes. | Class | org.springframework.batch.repeat.exception | Spring Batch |
|
| SimpleMailMessageItemWriter | A simple ItemWriter that can send mail messages. | Class | org.springframework.batch.item.mail | Spring Batch |
|
| SimpleMessageApplicationEvent | | Class | org.springframework.batch.sample.jmx | Spring Batch |
|
| SimpleMethodInvoker | Simple implementation of the MethodInvoker interface that invokes amethod on an object. | Class | org.springframework.batch.support | Spring Batch |
|
| SimpleMetric | Simple implementation of the Metric interface as required by JSR-352. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| SimplePartitioner | Simplest possible implementation of Partitioner. | Class | org.springframework.batch.core.partition.support | Spring Batch |
|
| SimpleRecordSeparatorPolicy | | Class | org.springframework.batch.item.file.separator | Spring Batch |
|
| SimpleResourceSuffixCreator | Trivial implementation of ResourceSuffixCreator that uses the indexitself as suffix, separated by dot. | Class | org.springframework.batch.item.file | Spring Batch |
|
| SimpleRetryExceptionHandler | An ExceptionHandler that is aware of the retry context so that it candistinguish between a fatal exception and one that can be retried. | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| SimpleStepBuilder | Step builder for simple item processing (chunk oriented) steps. | Class | org.springframework.batch.core.step.builder | Spring Batch |
|
| SimpleStepExecutionSplitter | Generic implementation of StepExecutionSplitter that delegates to aPartitioner to generate ExecutionContext instances. | Class | org.springframework.batch.core.partition.support | Spring Batch |
|
| SimpleStepFactoryBean | Most common configuration options for simple steps should be found here. | Class | org.springframework.batch.core.step.factory | Spring Batch |
|
| SimpleStepHandler | | Class | org.springframework.batch.core.job | Spring Batch |
|
| SimpleSystemProcessExitCodeMapper | Simple SystemProcessExitCodeMapper implementation that performs following mapping:0 -> ExitStatus. | Class | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| SingleItemPeekableItemReader | A PeekableItemReader that allows the user to peek one item ahead. | Class | org.springframework.batch.item.support | Spring Batch |
|
| SkipException | Base exception indicating that the skip has failed or caused a failure. | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| SkipLimitExceededException | Exception indicating that the skip limit for a particular Step hasAuthor:Ben Hale, Lucas Ward, Dave SyerSee Also:Serialized Form | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| SkipListener | Interface for listener to skipped items. | Interface | org.springframework.batch.core | Spring Batch |
|
| SkipListenerAdapter | | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| SkipListenerFailedException | Special exception to indicate a failure in a skip listener. | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| SkipListenerSupport | Basic no-op implementations of all SkipListener implementations. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| SkipOverflowException | | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| SkipPolicy | Policy for determining whether or not some processing should be skipped. | Interface | org.springframework.batch.core.step.skip | Spring Batch |
|
| SkipPolicyFailedException | Special exception to indicate a failure in a skip policy. | Class | org.springframework.batch.core.step.skip | Spring Batch |
|
| SkipWrapper | Wrapper for an item and its exception if it failed processing. | Class | org.springframework.batch.core.step.item | Spring Batch |
|
| SleepingItemProcessor | | Class | org.springframework.batch.core.test.timeout | Spring Batch |
|
| SleepingTasklet | | Class | org.springframework.batch.core.test.timeout | Spring Batch |
|
| SpELItemKeyMapper | An implementation of Converter that uses SpEL to map a Value to a keySince:2. | Class | org.springframework.batch.item | Spring Batch |
|
| SpELMappingGemfireItemWriter | A convenient GemfireItemWriter implementation that uses a SpELItemKeyMapperSince:2. | Class | org.springframework.batch.item.data | Spring Batch |
|
| SplitParser | Internal parser for the elements inside a job. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| SplitState | A State implementation that splits a Flow into multipleSince:2. | Class | org.springframework.batch.core.job.flow.support.state | Spring Batch |
|
| SpringValidator | Adapts the Validator interface toAuthor:Tomas Slanina, Robert Kasanicky | Class | org.springframework.batch.item.validator | Spring Batch |
|
| SqlitePagingQueryProvider | SQLite implementation of a PagingQueryProvider using database specificSince:3. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| SqlPagingQueryProviderFactoryBean | Factory bean for PagingQueryProvider interface. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| SqlPagingQueryUtils | Utility class that generates the actual SQL statements used by querySince:2. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| SqlServerPagingQueryProvider | SQL Server implementation of aPagingQueryProvider using | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| SqlWindowingPagingQueryProvider | Generic Paging Query Provider using standard SQL:2003 windowing functions. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| StagingItemListener | | Class | org.springframework.batch.sample.common | Spring Batch |
|
| StagingItemProcessor | Marks the input row as 'processed'. | Class | org.springframework.batch.sample.common | Spring Batch |
|
| StagingItemReader | Thread-safe database ItemReader implementing the process indicatorTo achieve restartability use together with StagingItemProcessor. | Class | org.springframework.batch.sample.common | Spring Batch |
|
| StagingItemWriter | Database ItemWriter implementing the process indicator pattern. | Class | org.springframework.batch.sample.common | Spring Batch |
|
| StandaloneStepParser | Internal parser for the elements for a job. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| StartLimitExceededException | Indicates the step's start limit has been exceeded. | Class | org.springframework.batch.core | Spring Batch |
|
| State | | Interface | org.springframework.batch.core.job.flow | Spring Batch |
|
| StateTransition | Value object representing a potential transition from one State toanother. | Class | org.springframework.batch.core.job.flow.support | Spring Batch |
|
| StaxEventItemReader | Item reader for reading XML input based on StAX. | Class | org.springframework.batch.item.xml | Spring Batch |
|
| StaxEventItemWriter | An implementation of ItemWriter which uses StAX andMarshaller for serializing object to XML. | Class | org.springframework.batch.item.xml | Spring Batch |
|
| StaxUtils | This class provides a little bit of indirection to avoid ugly conditional object creation. | Class | org.springframework.batch.item.xml | Spring Batch |
|
| StaxWriterCallback | Callback interface for writing to an XML file - useful e. | Interface | org.springframework.batch.item.xml | Spring Batch |
|
| Step | Batch domain interface representing the configuration of a step. | Interface | org.springframework.batch.core | Spring Batch |
|
| StepBuilder | Convenient entry point for building all kinds of steps. | Class | org.springframework.batch.core.step.builder | Spring Batch |
|
| StepBuilderException | Utility exception thrown by builders when they encounter unexpected checked exceptions. | Class | org.springframework.batch.core.step.builder | Spring Batch |
|
| StepBuilderFactory | Convenient factory for a StepBuilder which sets the JobRepository andPlatformTransactionManager automatically. | Class | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| StepBuilderHelper | A base class and utility for other step builders providing access to common properties like job repository andtransaction manager. | Class | org.springframework.batch.core.step.builder | Spring Batch |
|
| StepContext | A context object that can be used to interrogate the currentStepExecution and some of its associated properties using expressions | Class | org.springframework.batch.core.scope.context | Spring Batch |
|
| StepContextRepeatCallback | Convenient base class for clients who need to do something in a repeatcallback inside a Step. | Class | org.springframework.batch.core.scope.context | Spring Batch |
|
| StepContribution | Represents a contribution to a StepExecution, buffering changes untilthey can be applied at a chunk boundary. | Class | org.springframework.batch.core | Spring Batch |
|
| StepContributionSource | A source of StepContribution instances that can be aggregated and used to update an ongoingGet the currently available contributions and drain the source. | Interface | org.springframework.batch.integration.chunk | Spring Batch |
|
| StepExecution | Batch domain object representation the execution of a step. | Class | org.springframework.batch.core | Spring Batch |
|
| StepExecutionAggregator | Strategy for a aggregating step executions, usually when they are the resultof partitioned or remote execution. | Interface | org.springframework.batch.core.partition.support | Spring Batch |
|
| StepExecutionApplicationEventAdvice | Wraps calls for methods taking StepExecution as an argument andpublishes notifications in the form of ApplicationEvent. | Class | org.springframework.batch.sample.jmx | Spring Batch |
|
| StepExecutionDao | Retrieve all the StepExecution for the parent JobExecution. | Interface | org.springframework.batch.core.repository.dao | Spring Batch |
|
| StepExecutionInterceptor | A ChannelInterceptor that adds the current StepExecution (ifthere is one) as a header to the message. | Class | org.springframework.batch.integration.async | Spring Batch |
|
| StepExecutionListener | Listener interface for the lifecycle of a Step. | Interface | org.springframework.batch.core | Spring Batch |
|
| StepExecutionListenerSupport | | Class | org.springframework.batch.core.listener | Spring Batch |
|
| StepExecutionRequest | | Class | org.springframework.batch.integration.partition | Spring Batch |
|
| StepExecutionRequestHandler | A MessageEndpoint that can handle a StepExecutionRequest andreturn a StepExecution as the result. | Class | org.springframework.batch.integration.partition | Spring Batch |
|
| StepExecutionSimpleCompletionPolicy | A CompletionPolicy that picks up a commit interval fromJobParameters by listening to the start of a step. | Class | org.springframework.batch.core.resource | Spring Batch |
|
| StepExecutionSplitter | Strategy interface for generating input contexts for a partitioned stepexecution independent from the fabric they are going to run on. | Interface | org.springframework.batch.core.partition | Spring Batch |
|
| StepFactoryBean | This FactoryBean is used by the JSR-352 namespace parser to createStep objects. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| StepHandler | Strategy interface for handling a Step on behalf of a Job. | Interface | org.springframework.batch.core.job | Spring Batch |
|
| StepHolder | Interface for holders of a Step as a convenience for callers who needaccess to the underlying instance. | Interface | org.springframework.batch.core.step | Spring Batch |
|
| StepInterruptionPolicy | Strategy interface for an interruption policy. | Interface | org.springframework.batch.core.step | Spring Batch |
|
| StepListenerAdapter | Wrapper class to adapt the StepListener toa StepExecutionListener. | Class | org.springframework.batch.core.jsr | Spring Batch |
|
| StepListenerFactoryBean | This AbstractListenerFactoryBean implementation is used to create aSince:2. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| StepListenerFailedException | Exception to indicate a problem in a step listener. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| StepListenerMetaData | enum StepListenerMetaDataEnumeration for StepListener meta data, which ties together the names | Class | org.springframework.batch.core.listener | Spring Batch |
|
| StepListenerParser | Parser for a step listener element. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| StepListenerSupport | Basic no-op implementations of all StepListener interfaces. | Class | org.springframework.batch.core.listener | Spring Batch |
|
| StepLocator | Interface for locating a Step instance by name. | Interface | org.springframework.batch.core.step | Spring Batch |
|
| StepLocatorStepFactoryBean | Convenience factory for Step instances given a StepLocator. | Class | org.springframework.batch.core.step | Spring Batch |
|
| StepParser | Parser for the element defined by JSR-352. | Class | org.springframework.batch.core.jsr.configuration.xml | Spring Batch |
|
| StepParserStepFactoryBean | This FactoryBean is used by the batch namespace parser to create Step objects. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| StepRegistry | Registry keeping track of all the Step defined in aAuthor:Sebastien Gerard, Stephane Nicoll | Interface | org.springframework.batch.core.configuration | Spring Batch |
|
| StepRunner | Utility class for executing steps outside of a Job. | Class | org.springframework.batch.test | Spring Batch |
|
| StepScope | Convenient annotation for step scoped beans that defaults the proxy mode, so that it doesn't have to be specifiedexplicitly on every bean definition. | Class | org.springframework.batch.core.configuration.annotation | Spring Batch |
|
| StepScope | Scope for step context. | Class | org.springframework.batch.core.scope | Spring Batch |
|
| StepScopeManager | Convenient aspect to wrap a single threaded step execution, where theprovided by the framework). | Class | org.springframework.batch.core.scope.context | Spring Batch |
|
| StepScopeTestExecutionListener | A TestExecutionListener that sets up step-scope context fordependency injection into unit tests. | Class | org.springframework.batch.test | Spring Batch |
|
| StepScopeTestUtils | Utility class for creating and manipulating StepScope in unit tests. | Class | org.springframework.batch.test | Spring Batch |
|
| StepState | State implementation that delegates to a FlowExecutor toexecute the specified Step. | Class | org.springframework.batch.core.job.flow.support.state | Spring Batch |
|
| StepSynchronizationManager | Central convenience class for framework use in managing the step scopecontext. | Class | org.springframework.batch.core.scope.context | Spring Batch |
|
| StoppableTasklet | An extension to the Tasklet interface to allow users toadd logic for stopping a tasklet. | Interface | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| StoredProcedureItemReader | Item reader implementation that executes a stored procedure and then reads the returned cursorand continually retrieves the next row in the ResultSet. | Class | org.springframework.batch.item.database | Spring Batch |
|
| SuffixRecordSeparatorPolicy | A RecordSeparatorPolicy that looks for an exact match for a String atthe end of a line (e. | Class | org.springframework.batch.item.file.separator | Spring Batch |
|
| SummaryFooterCallback | Writes summary info in the footer of a file. | Class | org.springframework.batch.sample.support | Spring Batch |
|
| SybasePagingQueryProvider | Sybase implementation of a PagingQueryProvider usingdatabase specific features. | Class | org.springframework.batch.item.database.support | Spring Batch |
|
| SynchronizationManagerSupport | Central convenience class for framework use in managing the scopeSince:3. | Class | org.springframework.batch.core.scope.context | Spring Batch |
|
| SynchronizedAttributeAccessor | An AttributeAccessor that synchronizes on a mutex (not this) beforemodifying or accessing the underlying attributes. | Class | org.springframework.batch.repeat.context | Spring Batch |
|
| SynchronizedItemStreamReader | This is a simple ItemStreamReader decorator with a synchronized ItemReader. | Class | org.springframework.batch.item.support | Spring Batch |
|
| SystemCommandException | Exception indicating failed execution of system command. | Class | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| SystemCommandTasklet | Tasklet that executes a system command. | Class | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| SystemExiter | Interface for exiting the JVM. | Interface | org.springframework.batch.core.launch.support | Spring Batch |
|
| SystemProcessExitCodeMapper | Maps the exit code of a system process to ExitStatus valuereturned by a system command. | Interface | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| SystemPropertyInitializer | Helper class that sets up a System property with a default value. | Class | org.springframework.batch.support | Spring Batch |
|
| TaskExecutorPartitionHandler | A PartitionHandler that uses a TaskExecutor to execute thepartitioned Step locally in multiple threads. | Class | org.springframework.batch.core.partition.support | Spring Batch |
|
| TaskExecutorRepeatTemplate | Provides RepeatOperations support including interceptors that can beused to modify or monitor the behaviour at run time. | Class | org.springframework.batch.repeat.support | Spring Batch |
|
| Tasklet | Strategy for processing in a step. | Interface | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| TaskletParser | Parse a tasklet element for a step. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| TaskletStep | Simple implementation of executing the step as a call to a Tasklet,possibly repeated, and each call surrounded by a transaction. | Class | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| TaskletStepBuilder | Builder for tasklet step based on a custom tasklet (not item oriented). | Class | org.springframework.batch.core.step.builder | Spring Batch |
|
| TestMailErrorHandler | This handler prints out failed messages with their exceptions. | Class | org.springframework.batch.sample.domain.mail.internal | Spring Batch |
|
| TestMailSender | | Class | org.springframework.batch.sample.domain.mail.internal | Spring Batch |
|
| ThreadLocalClassloaderBeanPostProcessor | After the BeanFactory is created, this post processor will evaluate to seeif any of the beans referenced from a job definition (as defined by JSR-352) point | Class | org.springframework.batch.core.jsr.configuration.support | Spring Batch |
|
| ThreadStepInterruptionPolicy | Policy that checks the current thread to see if it has been interrupted. | Class | org.springframework.batch.core.step | Spring Batch |
|
| ThrottleLimitResultQueue | An implementation of the ResultQueue that throttles the number ofexpected results, limiting it to a maximum at any given time. | Class | org.springframework.batch.repeat.support | Spring Batch |
|
| TimeoutTerminationPolicy | Termination policy that times out after a fixed period. | Class | org.springframework.batch.repeat.policy | Spring Batch |
|
| TopLevelFlowParser | | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| TopLevelJobListenerParser | Parse elements in the batch namespace. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| TopLevelStepListenerParser | Parse elements in the batch namespace. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| TopLevelStepParser | Parser for the top level element in the Batch namespace. | Class | org.springframework.batch.core.configuration.xml | Spring Batch |
|
| Trade | | Class | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| TradeDao | Interface for writing a Trade object to an arbitrary output. | Interface | org.springframework.batch.sample.domain.trade | Spring Batch |
|
| TradeFieldSetMapper | | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| TradeProcessor | Processes the Trade - throwing validation errors if necessary. | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| TradeRowMapper | | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| TradeValidator | | Class | org.springframework.batch.sample.domain.trade.internal.validator | Spring Batch |
|
| TradeWriter | Delegates the actual writing to custom DAO delegate. | Class | org.springframework.batch.sample.domain.trade.internal | Spring Batch |
|
| TransactionAwareBufferedWriter | Wrapper for a FileChannel that delays actually writing to or closing thebuffer if a transaction is active. | Class | org.springframework.batch.support.transaction | Spring Batch |
|
| TransactionAwareProxyFactory | Factory for transaction aware objects (like lists, sets, maps). | Class | org.springframework.batch.support.transaction | Spring Batch |
|
| UncheckedTransactionException | Convenience wrapper for a checked exception so that it can cause arollback and be extracted afterwards. | Class | org.springframework.batch.core.step.tasklet | Spring Batch |
|
| UnclosedElementCollectingEventWriter | Delegating XMLEventWriter, which collects the QNames of elements that were opened but not closed. | Class | org.springframework.batch.item.xml.stax | Spring Batch |
|
| UnexpectedInputException | Used to signal an unexpected end of an input or message stream. | Class | org.springframework.batch.item | Spring Batch |
|
| UnexpectedJobExecutionException | Indicates to the framework that a critical error has occurred and processingshould immediately stop. | Class | org.springframework.batch.core | Spring Batch |
|
| UnopenedElementClosingEventWriter | Delegating XMLEventWriter, which writes EndElement events that match a given collection of QNames directlyto the underlying java. | Class | org.springframework.batch.item.xml.stax | Spring Batch |
|
| User | | Class | org.springframework.batch.sample.domain.mail | Spring Batch |
|
| UserMailItemProcessor | | Class | org.springframework.batch.sample.domain.mail.internal | Spring Batch |
|
| ValidatingItemProcessor | Simple implementation of ItemProcessor that validates input andreturns it without modifications. | Class | org.springframework.batch.item.validator | Spring Batch |
|
| ValidationException | This exception should be thrown when there are validation errors. | Class | org.springframework.batch.item.validator | Spring Batch |
|
| Validator | Interface used to validate objects. | Interface | org.springframework.batch.item.validator | Spring Batch |
|
| WriteFailedException | Unchecked exception indicating that an error has occurred while trying toclear a buffer on a rollback. | Class | org.springframework.batch.item | Spring Batch |
|
| WriterNotOpenException | Exception indicating that an ItemWriter needed to be opened before beingAuthor:Lucas WardSee Also:Serialized Form | Class | org.springframework.batch.item | Spring Batch |
|
| XStreamExecutionContextStringSerializer | | Class | org.springframework.batch.core.repository.dao | Spring Batch |