- abandon(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
- abandon(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- abandonStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
Handle any status changes that might be needed at the start of a state.
- abandonStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- AbstractApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
-
- AbstractApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Create a factory instance with the resource specified.
- AbstractBatchConfiguration - Class in org.springframework.batch.core.configuration.annotation
-
Base Configuration
class providing common structure for enabling and using Spring Batch.
- AbstractBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
-
- AbstractFlowParser - Class in org.springframework.batch.core.configuration.xml
-
- AbstractFlowParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- AbstractJdbcBatchMetadataDao - Class in org.springframework.batch.core.repository.dao
-
Encapsulates common functionality needed by JDBC batch metadata DAOs -
provides jdbcTemplate for subclasses and handles table prefixes.
- AbstractJdbcBatchMetadataDao() - Constructor for class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- AbstractJob - Class in org.springframework.batch.core.job
-
Abstract implementation of the
Job
interface.
- AbstractJob() - Constructor for class org.springframework.batch.core.job.AbstractJob
-
Default constructor.
- AbstractJob(String) - Constructor for class org.springframework.batch.core.job.AbstractJob
-
Convenience constructor to immediately add name (which is mandatory but
not final).
- AbstractJobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
-
- AbstractJobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
- AbstractJobRepositoryFactoryBean - Class in org.springframework.batch.core.repository.support
-
- AbstractJobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- AbstractListenerFactoryBean - Class in org.springframework.batch.core.listener
-
FactoryBean
implementation that builds a listener based on the
various lifecycle methods or annotations that are provided.
- AbstractListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- AbstractListenerParser - Class in org.springframework.batch.core.configuration.xml
-
- AbstractListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractListenerParser
-
- AbstractPartitionHandler - Class in org.springframework.batch.core.partition.support
-
- AbstractPartitionHandler() - Constructor for class org.springframework.batch.core.partition.support.AbstractPartitionHandler
-
- AbstractState - Class in org.springframework.batch.core.job.flow.support.state
-
- AbstractState(String) - Constructor for class org.springframework.batch.core.job.flow.support.state.AbstractState
-
- AbstractStep - Class in org.springframework.batch.core.step
-
A
Step
implementation that provides common behavior to subclasses, including registering and calling
listeners.
- AbstractStep() - Constructor for class org.springframework.batch.core.step.AbstractStep
-
Default constructor.
- AbstractStep(String) - Constructor for class org.springframework.batch.core.step.AbstractStep
-
Convenient constructor for setting only the name property.
- AbstractStepParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <step/> elements inside a job.
- AbstractStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractStepParser
-
- AbstractTaskletStepBuilder<B extends AbstractTaskletStepBuilder<B>> - Class in org.springframework.batch.core.step.builder
-
Base class for step builders that want to build a
TaskletStep
.
- AbstractTaskletStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
- add(Flow...) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.SplitBuilder
-
Add flows to the split, in addition to the current state already present in the parent builder.
- add(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- add(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- add(W) - Method in class org.springframework.batch.core.step.item.Chunk
-
Add the item to the chunk.
- addAll(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- addAll(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- addApplicationContextFactory(ApplicationContextFactory) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
Add some factories to the set that will be used to load contexts and jobs.
- addDate(String, Date) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying
Date
parameter for the given key.
- addDate(String, Date, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new
Date
parameter for the given key.
- addDouble(String, Double) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying Double parameter for the given key.
- addDouble(String, Double, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new Double parameter for the given key.
- addExitDescription(String) - Method in class org.springframework.batch.core.ExitStatus
-
Add an exit description to an existing
ExitStatus
.
- addExitDescription(Throwable) - Method in class org.springframework.batch.core.ExitStatus
-
Extract the stack trace from the throwable provided and append it to
the exist description.
- addExitStatus(String) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
- addExitStatus(String) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- addFailureException(Throwable) - Method in class org.springframework.batch.core.JobExecution
-
Add the provided throwable to the failure exception list.
- addFailureException(Throwable) - Method in class org.springframework.batch.core.StepExecution
-
- addJobExecutionListener(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- addLong(String, Long) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying Long parameter for the given key.
- addLong(String, Long, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new Long parameter for the given key.
- addParameter(String, JobParameter) - Method in class org.springframework.batch.core.JobParametersBuilder
-
- addStep(Step) - Method in class org.springframework.batch.core.job.SimpleJob
-
Convenience method for adding a single step to the job.
- addStepExecutionListener(StepExecutionListener) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- addStepExecutionListeners(List<JobExecutionListener>) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- addStepExecutionListeners(List<StepExecutionListener>) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- addStepExecutions(List<StepExecution>) - Method in class org.springframework.batch.core.JobExecution
-
Add some step executions.
- addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
- addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
-
- addStepExecutions(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
- addString(String, String) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying String parameter for the given key.
- addString(String, String, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new String parameter for the given key.
- AfterChunk - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after a chunk is executed.
Expected signature: void afterChunk(ChunkContext context)
- afterChunk(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
-
Callback after the chunk is executed, outside the transaction.
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
-
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
-
Call the registered listeners in order, respecting and prioritizing those
that implement Ordered
.
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- AfterChunkError - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after a has failed and been
marked for rollback.
Expected signature: void afterFailedChunk(ChunkContext context)
- afterChunkError(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
-
Callback after a chunk has been marked for rollback.
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
-
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
-
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- AfterJob - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after a
Job
has completed.
- afterJob(JobExecution) - Method in interface org.springframework.batch.core.JobExecutionListener
-
Callback after completion of a job.
- afterJob(JobExecution) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
-
Call the registered listeners in reverse order, respecting and
prioritising those that implement Ordered
.
- afterJob(JobExecution) - Method in class org.springframework.batch.core.listener.JobExecutionListenerSupport
-
- AfterProcess - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after an item is passed to an
ItemProcessor
Expected signature: void afterProcess(T item, S result)
- afterProcess(T, S) - Method in interface org.springframework.batch.core.ItemProcessListener
-
- afterProcess(T, S) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
-
Call the registered listeners in reverse order, respecting and
prioritising those that implement Ordered
.
- afterProcess(I, O) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
-
- afterProcess(T, S) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterProcess(T, S) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
Make sure the registry is set before use.
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
Check mandatory properties (name).
- afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.AbstractJob
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.CompositeJobParametersValidator
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
-
Check that there are no overlaps between required and optional keys.
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.FlowStep
-
Ensure that the flow is set.
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Locate start state and pre-populate data structures needed for execution.
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.SimpleStepHandler
-
Check mandatory properties (jobRepository).
- afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
-
Ensure the required dependencies of a
JobRepository
have been
set.
- afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.PartitionStep
-
Assert that mandatory properties are set (stepExecutionSplitter,
partitionHandler) and delegate top superclass.
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
Check mandatory properties (step name, job repository and partitioner).
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.AbstractStep
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.job.JobStep
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
-
Assert that the callable is set.
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
- AfterRead - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after an item is read from an
ItemReader
Expected signature: void afterRead(T item)
- afterRead(T) - Method in interface org.springframework.batch.core.ItemReadListener
-
- afterRead(T) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
-
Call the registered listeners in reverse order, respecting and
prioritising those that implement Ordered
.
- afterRead(I) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
-
- afterRead(T) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterRead(T) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- AfterStep - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after a
Step
has completed.
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
-
Call the registered listeners in reverse order, respecting and
prioritizing those that implement Ordered
.
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
-
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepExecutionListenerSupport
-
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- afterStep(StepExecution) - Method in class org.springframework.batch.core.step.NoWorkFoundStepExecutionListener
-
- afterStep(StepExecution) - Method in interface org.springframework.batch.core.StepExecutionListener
-
Give a listener a chance to modify the exit status from a step.
- AfterWrite - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after an item is passed to an
ItemWriter
Expected signature: void afterWrite(
List
<? extends S> items)
- afterWrite(List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
-
- afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
-
Call the registered listeners in reverse order, respecting and
prioritising those that implement Ordered
.
- afterWrite(List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
-
- afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- aggregate(Collection<FlowExecution>) - Method in interface org.springframework.batch.core.job.flow.support.state.FlowExecutionAggregator
-
- aggregate(Collection<FlowExecution>) - Method in class org.springframework.batch.core.job.flow.support.state.MaxValueFlowExecutionAggregator
-
- aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.partition.support.DefaultStepExecutionAggregator
-
- aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
-
Aggregates the input executions into the result
StepExecution
delegating to the delegate aggregator once the input has been refreshed
from the
JobExplorer
.
- aggregate(StepExecution, Collection<StepExecution>) - Method in interface org.springframework.batch.core.partition.support.StepExecutionAggregator
-
Take the inputs and aggregate, putting the aggregates into the result.
- aggregator(StepExecutionAggregator) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
Provide a step execution aggregator for aggregating partitioned step executions into a single result for the
PartitionStep
itself.
- allowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
-
- AlwaysSkipItemSkipPolicy - Class in org.springframework.batch.core.step.skip
-
Implementation of the
SkipPolicy
interface that
will always return that an item should be skipped.
- AlwaysSkipItemSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
-
- and(ExitStatus) - Method in class org.springframework.batch.core.ExitStatus
-
Create a new
ExitStatus
with a logical combination of the exit
code, and a concatenation of the descriptions.
- ApplicationContextFactory - Interface in org.springframework.batch.core.configuration.support
-
Factory for the creation of ApplicationContext
s.
- ApplicationContextJobFactory - Class in org.springframework.batch.core.configuration.support
-
A
JobFactory
that creates its own
ApplicationContext
and
pulls a bean out when asked to create a
Job
.
- ApplicationContextJobFactory(String, ApplicationContextFactory) - Constructor for class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
-
- apply(StepContribution) - Method in class org.springframework.batch.core.StepExecution
-
On successful execution just before a chunk commit, this method should be
called.
- applyConfiguration(SimpleStepBuilder<T, S>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
- applyConfiguration(SimpleStepBuilder<T, S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- AutomaticJobRegistrar - Class in org.springframework.batch.core.configuration.support
-
Loads and unloads
Jobs
when the application context is created and destroyed.
- AutomaticJobRegistrar() - Constructor for class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
- autoregisterBeansForNamespace(ParserContext, Object) - Static method in class org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
-
- generateKey(JobParameters) - Method in class org.springframework.batch.core.DefaultJobKeyGenerator
-
Generates the job key to be used based on the
JobParameters
instance
provided.
- generateKey(T) - Method in interface org.springframework.batch.core.JobKeyGenerator
-
Method to generate the unique key used to identify a job instance.
- GenericApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
-
- GenericApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
-
Create an application context factory for the resource specified.
- get(String) - Method in class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
-
Creates a job builder and initializes its job repository.
- get(String) - Method in class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
-
Creates a step builder and initializes its job repository and transaction manager.
- get(String, ObjectFactory) - Method in class org.springframework.batch.core.scope.StepScope
-
- getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
- getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Extension point for subclasses that want to adjust the outputs based on
additional saved data in the inputs.
- getAllFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
-
Return all failure causing exceptions for this JobExecution, including
step executions.
- getAllowStartIfComplete() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getAnnotation() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
- getAnnotation() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
-
- getAnnotation() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- getAttribute(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
-
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
-
- getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
-
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.JobParser
-
- getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
-
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
-
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
-
- getBeanClassName(Element) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
-
- getBeanFactoryPostProcessorClasses() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Protected access to the list of bean factory post processor classes that should be copied over to the context
from the parent.
- getChunkOperations() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the chunk operations to make them available in subclasses.
- getChunkSize() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- getClobTypeToUse() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- getCommitCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of commits for this execution
- getCompositeListener() - Method in class org.springframework.batch.core.step.AbstractStep
-
- getConfigurer(Collection<BatchConfigurer>) - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
-
- getContext() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
-
Getter for the current context if there is one, otherwise returns null.
- getConversationId() - Method in class org.springframework.batch.core.scope.StepScope
-
- getCreateTime() - Method in class org.springframework.batch.core.JobExecution
-
- getDate(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Date represented by the provided key.
- getDate(String, Date) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Date represented by the provided key.
- getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
- getDouble(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Long represented by the provided key.
- getDouble(String, double) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Double represented by the provided key.
- getEndTime() - Method in class org.springframework.batch.core.JobExecution
-
- getEndTime() - Method in class org.springframework.batch.core.StepExecution
-
Returns the time that this execution ended
- getErrorMessage() - Static method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
- getErrors() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
-
Public getter for the startup errors encountered during parent context
creation.
- getErrors() - Method in class org.springframework.batch.core.step.item.Chunk
-
- getException() - Method in class org.springframework.batch.core.step.item.SkipWrapper
-
Public getter for the exception.
- getExceptionHandler() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Convenience method for subclasses to access the exception handler that was injected by user.
- getExceptionHandler() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- getExecutionContext() - Method in class org.springframework.batch.core.JobExecution
-
- getExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
-
- getExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
-
- getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
-
- getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
-
- getExecutionContext() - Method in class org.springframework.batch.core.StepExecution
-
- getExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- getExecutions(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
List the
JobExecutions
associated with a particular
JobInstance
, in reverse order of creation (and therefore usually
of execution).
- getExecutions(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getExitCode() - Method in class org.springframework.batch.core.ExitStatus
-
Getter for the exit code (defaults to blank).
- getExitDescription() - Method in class org.springframework.batch.core.ExitStatus
-
Getter for the exit description (defaults to blank)
- getExitStatus() - Method in class org.springframework.batch.core.JobExecution
-
- getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
-
- getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
-
- getExitStatus(int) - Method in interface org.springframework.batch.core.step.tasklet.SystemProcessExitCodeMapper
-
- getExitStatus() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the status.
- getExitStatus() - Method in class org.springframework.batch.core.StepExecution
-
- getFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
-
- getFailureExceptions() - Method in class org.springframework.batch.core.StepExecution
-
- getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
- getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Extension point for subclasses to calculate the filter count.
- getFilterCount() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the filter counter.
- getFilterCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of items filtered out of this execution
- getFlows() - Method in interface org.springframework.batch.core.job.flow.FlowHolder
-
- getFlows() - Method in class org.springframework.batch.core.job.flow.support.state.FlowState
-
- getFlows() - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
-
- getGridSize() - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
-
Returns the number of step executions.
- getGroupName(BeanDefinition, Job) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
Determine a group name for the job to be registered.
- getId() - Method in class org.springframework.batch.core.Entity
-
- getId() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getItem() - Method in class org.springframework.batch.core.step.item.SkipWrapper
-
Public getter for the item.
- getItemListeners() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- getItemProcessor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- getItemReader() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the
ItemReader
for subclasses to use.
- getItems() - Method in class org.springframework.batch.core.step.item.Chunk
-
- getItemWriter() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the
ItemWriter
for subclasses to use
- getJdbcTemplate() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- getJob(String) - Method in interface org.springframework.batch.core.configuration.JobLocator
-
Locates a
Job
at runtime.
- getJob(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
-
- getJobExecution(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
- getJobExecution(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
- getJobExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- getJobExecution(Long) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
- getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
-
- getJobExecution() - Method in class org.springframework.batch.core.StepExecution
-
Accessor for the execution context information of the enclosing job.
- getJobExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- getJobExecutionId() - Method in class org.springframework.batch.core.StepExecution
-
Accessor for the job execution id.
- getJobExecutionListeners() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Retrieve job executions by their job instance.
- getJobExecutions(JobInstance) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobId() - Method in class org.springframework.batch.core.JobExecution
-
Convenience getter for for the id of the enclosing job.
- getJobInstance(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
- getJobInstance(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobInstance() - Method in class org.springframework.batch.core.JobExecution
-
- getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
The job table is queried for any jobs that match the
given identifier, adding them to a list via the RowMapper callback.
- getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Find the job instance that matches the given name and parameters.
- getJobInstance(Long) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the job instance with the provided identifier.
- getJobInstance(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the JobInstance for the provided JobExecution.
- getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Fetch
JobInstance
values in descending order of creation (and
therefore usually of first execution).
- getJobInstances(String, int, int) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.launch.JobOperator
-
List the
JobInstances
for a given job name, in
reverse order of creation (and therefore usually of first execution).
- getJobInstances(String, int, int) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the last job instances with the provided name, sorted backwards by
primary key.
- getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobLauncher() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
-
- getJobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- getJobName() - Method in interface org.springframework.batch.core.configuration.JobFactory
-
- getJobName() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
-
Just return the name of instance passed in on initialization.
- getJobName() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
-
Just return the name of instance passed in on initialization.
- getJobName() - Method in class org.springframework.batch.core.JobInstance
-
- getJobName() - Method in class org.springframework.batch.core.scope.context.StepContext
-
Convenient accessor for current job name identifier.
- getJobNames() - Method in interface org.springframework.batch.core.configuration.ListableJobLocator
-
Provides the currently registered job names.
- getJobNames() - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
-
Provides an unmodifiable view of the job names.
- getJobNames() - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Query the repository for all unique
JobInstance
names (sorted
alphabetically).
- getJobNames() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobNames() - Method in interface org.springframework.batch.core.launch.JobOperator
-
- getJobNames() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getJobNames() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- getJobNames() - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Retrieve the names of all job instances sorted alphabetically - i.e.
- getJobNames() - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobParameters(Properties) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
Check for suffix on keys and use those to decide how to convert the
value.
- getJobParameters(Properties) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
-
- getJobParameters() - Method in class org.springframework.batch.core.JobExecution
-
- getJobParameters(Properties) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
-
- getJobParameters(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- getJobParameters() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getJobParameters(Job, StepExecution) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
-
- getJobParameters(Job, StepExecution) - Method in interface org.springframework.batch.core.step.job.JobParametersExtractor
-
Extract job parameters from the step execution, for example from the
execution context or other properties.
- getJobParameters() - Method in class org.springframework.batch.core.StepExecution
-
Convenience method to get the current job parameters.
- getJobParametersIncrementer() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
-
- getJobParametersIncrementer() - Method in class org.springframework.batch.core.job.AbstractJob
-
- getJobParametersIncrementer() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getJobParametersIncrementer() - Method in interface org.springframework.batch.core.Job
-
If clients need to generate new parameters for the next execution in a
sequence they can use this incrementer.
- getJobParametersValidator() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
-
- getJobParametersValidator() - Method in class org.springframework.batch.core.job.AbstractJob
-
- getJobParametersValidator() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getJobParametersValidator() - Method in interface org.springframework.batch.core.Job
-
- getJobRepository() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
-
- getJobRepository() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- getJobRepository() - Method in class org.springframework.batch.core.job.AbstractJob
-
Convenience method for subclasses to access the job repository.
- getJobRepository() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getJobRepository() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
-
- getJobRepository() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
Convenience method for clients to grab the
JobRepository
without
a cast.
- getJobRepository() - Method in class org.springframework.batch.core.step.AbstractStep
-
- getJobRepository() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getJobRepository() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
-
- getKey(Object) - Method in interface org.springframework.batch.core.step.item.KeyGenerator
-
- getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- getLastJobExecution(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
- getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
-
- getLastJobExecution(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- getLastJobExecution(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- getLastStepExecution(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- getLastStepExecution(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- getLastUpdated() - Method in class org.springframework.batch.core.JobExecution
-
Get the date representing the last time this JobExecution was updated in
the JobRepository.
- getLastUpdated() - Method in class org.springframework.batch.core.StepExecution
-
- getListener(Object) - Static method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- getListener(Object) - Static method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
Convenience method to wrap any object and expose the appropriate
StepListener
interfaces.
- getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
- getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
-
- getListenerInterface() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
- getListenerInterface() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
-
- getListenerInterface() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- getListeners() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- getLong(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Long represented by the provided key.
- getLong(String, long) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Long represented by the provided key.
- getMapping() - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
-
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
- getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
-
- getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
-
- getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
-
- getMetaDataValues() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- getMetaDataValues() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- getMetaDataValues() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
- getMethodInvokerByName(String, Object, Class<?>...) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- getMethodName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
- getMethodName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
-
- getMethodName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- getName() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
-
Concatenates the group name and the delegate job name (joining with a
".").
- getName() - Method in class org.springframework.batch.core.job.AbstractJob
-
- getName() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getName() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
-
- getName() - Method in interface org.springframework.batch.core.job.flow.Flow
-
- getName() - Method in class org.springframework.batch.core.job.flow.FlowExecution
-
- getName() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
-
- getName() - Method in interface org.springframework.batch.core.job.flow.State
-
The name of the state.
- getName() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Get the name for this flow.
- getName() - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
-
- getName() - Method in interface org.springframework.batch.core.Job
-
- getName() - Method in class org.springframework.batch.core.step.AbstractStep
-
- getName() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getName() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
-
- getName() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public getter for the name of the step.
- getName() - Method in interface org.springframework.batch.core.Step
-
- getNext() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Public getter for the next State name.
- getNext(JobParameters) - Method in interface org.springframework.batch.core.JobParametersIncrementer
-
Increment the provided parameters.
- getNext(JobParameters) - Method in class org.springframework.batch.core.launch.support.RunIdIncrementer
-
Increment the run.id parameter (starting with 1).
- getNextElements(ParserContext, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- getNextElements(ParserContext, String, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- getObject() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Create a
Step
from the configuration provided.
- getObject() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
The type of object to be returned from FactoryBean.getObject()
.
- getObjectType() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
-
Tell clients that we are a factory for
Step
instances.
- getOffset() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
-
- getOrder() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
- getOrder() - Method in class org.springframework.batch.core.scope.StepScope
-
- getParameters() - Method in class org.springframework.batch.core.JobParameters
-
Get a map of all parameters, including string, long, and date.
- getParameters(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
- getParameters(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getParamTypes() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
- getParamTypes() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
-
- getParamTypes() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- getPartitionNames(int) - Method in interface org.springframework.batch.core.partition.support.PartitionNameProvider
-
- getProcessor() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- getProcessSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the process skip count.
- getProcessSkipCount() - Method in class org.springframework.batch.core.StepExecution
-
- getProperties(JobParameters) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
Use the same suffixes to create properties (omitting the string suffix
because it is the default).
- getProperties(JobParameters) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
-
- getProperties(JobParameters) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
-
Convert schedule date to Date, and assume all other parameters can be represented by their default string value.
- getPropertyName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
- getPropertyName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
-
- getPropertyName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- getPropertyValue(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
-
- getQuery(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- getReadCount() - Method in class org.springframework.batch.core.StepContribution
-
Public access to the read counter.
- getReadCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of items read for this execution
- getReader() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- getReadSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
- getReadSkipCount() - Method in class org.springframework.batch.core.StepExecution
-
- getRestartable() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getRollbackCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of rollbacks for this execution
- getRunningExecutions(String) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Get the id values of all the running
JobExecutions
with the given job name.
- getRunningExecutions(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
- getSkipCount() - Method in class org.springframework.batch.core.StepExecution
-
- getSkipLimit() - Method in exception org.springframework.batch.core.step.skip.SkipLimitExceededException
-
- getSkips() - Method in class org.springframework.batch.core.step.item.Chunk
-
- getStartLimit() - Method in class org.springframework.batch.core.step.AbstractStep
-
- getStartLimit() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getStartLimit() - Method in interface org.springframework.batch.core.Step
-
- getStartTime() - Method in class org.springframework.batch.core.JobExecution
-
- getStartTime() - Method in class org.springframework.batch.core.StepExecution
-
Gets the time this execution started
- getState(String) - Method in interface org.springframework.batch.core.job.flow.Flow
-
Retrieve the State with the given name.
- getState(String) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Retrieve the State with the given name.
- getState() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Public getter for the State.
- getStates() - Method in interface org.springframework.batch.core.job.flow.Flow
-
Convenient accessor for clients needing to explore the states of this
flow.
- getStates() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Convenient accessor for clients needing to explore the states of this
flow.
- getStateTransitionReference(ParserContext, BeanDefinition, String, String) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- getStatus() - Method in class org.springframework.batch.core.job.flow.FlowExecution
-
- getStatus() - Method in class org.springframework.batch.core.JobExecution
-
- getStatus() - Method in exception org.springframework.batch.core.JobInterruptedException
-
The desired status of the surrounding execution after the interruption.
- getStatus() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current status of this step
- getStep(String, String) - Method in interface org.springframework.batch.core.configuration.StepRegistry
-
Returns the
Step
of the specified job based on its name.
- getStep(String, String) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
-
- getStep(String) - Method in class org.springframework.batch.core.job.AbstractJob
-
Retrieve the step with the given name.
- getStep(String) - Method in class org.springframework.batch.core.job.flow.FlowJob
-
Retrieve the step with the given name.
- getStep() - Method in class org.springframework.batch.core.job.flow.support.state.StepState
-
- getStep(String) - Method in class org.springframework.batch.core.job.SimpleJob
-
- getStep() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
-
The step instance that will be executed in parallel by this handler.
- getStep() - Method in interface org.springframework.batch.core.step.StepHolder
-
- getStep(String) - Method in interface org.springframework.batch.core.step.StepLocator
-
- getStepContext() - Method in class org.springframework.batch.core.scope.context.ChunkContext
-
- getStepExecution(Long, Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
- getStepExecution(Long, Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
- getStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
- getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
-
- getStepExecution(JobExecution, Long) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
- getStepExecution() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getStepExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getStepExecutionCount(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- getStepExecutionCount(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- getStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- getStepExecutionListeners() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getStepExecutions() - Method in class org.springframework.batch.core.JobExecution
-
Accessor for the step executions.
- getStepExecutionSummaries(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Summarise the
StepExecution
instances belonging to the
JobExecution
with the supplied id, giving details of status,
start and end times etc.
- getStepExecutionSummaries(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getStepName() - Method in interface org.springframework.batch.core.partition.StepExecutionSplitter
-
The name of the step configuration that will be executed remotely.
- getStepName() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
- getStepName() - Method in class org.springframework.batch.core.scope.context.StepContext
-
Convenient accessor for current step name identifier.
- getStepName() - Method in class org.springframework.batch.core.StepExecution
-
- getStepNames() - Method in class org.springframework.batch.core.job.AbstractJob
-
Retrieve the step names.
- getStepNames() - Method in class org.springframework.batch.core.job.flow.FlowJob
-
Retrieve the step names.
- getStepNames() - Method in class org.springframework.batch.core.job.SimpleJob
-
Convenience method for clients to inspect the steps for this job.
- getStepNames() - Method in interface org.springframework.batch.core.step.StepLocator
-
- getStepOperations() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Convenience method for subclasses to access the step operations that were injected by user.
- getStepOperations() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the step operations to make them available in subclasses.
- getStepSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
- getString(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the String represented by the provided key.
- getString(String, String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the String represented by the provided key.
- getSummary(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Summarise the
JobExecution
with the supplied id, giving details
of status, start and end times etc.
- getSummary(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getSummary() - Method in class org.springframework.batch.core.StepExecution
-
- getSystemProperties() - Method in class org.springframework.batch.core.scope.context.StepContext
-
Convenient accessor for System properties to make it easy to access them
from placeholder expressions.
- getTablePrefix() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- getTaskExecutor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Mkae the TaskExecutor
available to subclasses
- getTransactionAttribute() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Getter for the TransactionAttribute
for subclasses only.
- getTransactionManager() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
-
- getTransactionManager() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- getTransactionManager() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
The transaction manager used in this factory.
- getTransactionManager() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getTransactionManager() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
-
- getType() - Method in class org.springframework.batch.core.JobParameter
-
- getUserData() - Method in class org.springframework.batch.core.step.item.Chunk
-
- getValue() - Method in class org.springframework.batch.core.JobParameter
-
- getVersion() - Method in class org.springframework.batch.core.Entity
-
- getWriteCount() - Method in class org.springframework.batch.core.StepContribution
-
Public access to the write counter.
- getWriteCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of items written for this execution
- getWriter() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- getWriteSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
- getWriteSkipCount() - Method in class org.springframework.batch.core.StepExecution
-
- gridSize(int) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
- GroupAwareJob - Class in org.springframework.batch.core.configuration.support
-
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.
- GroupAwareJob(Job) - Constructor for class org.springframework.batch.core.configuration.support.GroupAwareJob
-
Create a new
Job
with the delegate and no group name.
- GroupAwareJob(String, Job) - Constructor for class org.springframework.batch.core.configuration.support.GroupAwareJob
-
Create a new
Job
with the given group name and delegate.
- JdbcExecutionContextDao - Class in org.springframework.batch.core.repository.dao
-
- JdbcExecutionContextDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- JdbcJobExecutionDao - Class in org.springframework.batch.core.repository.dao
-
- JdbcJobExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- JdbcJobInstanceDao - Class in org.springframework.batch.core.repository.dao
-
- JdbcJobInstanceDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- JdbcStepExecutionDao - Class in org.springframework.batch.core.repository.dao
-
JDBC implementation of
StepExecutionDao
.
Allows customization of the tables names used by Spring Batch for step meta
data via a prefix property.
Uses sequences or tables (via Spring's
DataFieldMaxValueIncrementer
abstraction) to create all primary keys before inserting a new row.
- JdbcStepExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
- Job - Interface in org.springframework.batch.core
-
Batch domain object representing a job.
- job(Job) - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
-
Provide a job to execute during the step.
- job(Job) - Method in class org.springframework.batch.core.step.builder.StepBuilder
-
Create a new step builder that will execute a job.
- JOB_NOT_PROVIDED - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
-
- JobBuilder - Class in org.springframework.batch.core.job.builder
-
Convenience for building jobs of various kinds.
- JobBuilder(String) - Constructor for class org.springframework.batch.core.job.builder.JobBuilder
-
Create a new builder for a job with the given name.
- JobBuilderException - Exception in org.springframework.batch.core.job.builder
-
- JobBuilderException(Exception) - Constructor for exception org.springframework.batch.core.job.builder.JobBuilderException
-
- JobBuilderFactory - Class in org.springframework.batch.core.configuration.annotation
-
- JobBuilderFactory(JobRepository) - Constructor for class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
-
- JobBuilderHelper<B extends JobBuilderHelper<B>> - Class in org.springframework.batch.core.job.builder
-
A base class and utility for other job builders providing access to common properties like job repository.
- JobBuilderHelper(String) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper
-
- JobBuilderHelper(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper
-
Create a new builder initialized with any properties in the parent.
- JobBuilderHelper.CommonJobProperties - Class in org.springframework.batch.core.job.builder
-
- JobBuilderHelper.CommonJobProperties() - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- JobBuilderHelper.CommonJobProperties(JobBuilderHelper.CommonJobProperties) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- jobBuilders() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
-
- JobExecution - Class in org.springframework.batch.core
-
Batch domain object representing the execution of a job.
- JobExecution(JobInstance, Long, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
-
Because a JobExecution isn't valid unless the job is set, this
constructor is the only valid one from a modeling point of view.
- JobExecution(JobInstance, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
-
Constructor for transient (unsaved) instances.
- JobExecution(Long, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
-
- JobExecution(Long) - Constructor for class org.springframework.batch.core.JobExecution
-
- JobExecutionAlreadyRunningException - Exception in org.springframework.batch.core.repository
-
- JobExecutionAlreadyRunningException(String) - Constructor for exception org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
-
- JobExecutionAlreadyRunningException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
-
- JobExecutionDao - Interface in org.springframework.batch.core.repository.dao
-
Data Access Object for job executions.
- JobExecutionDecider - Interface in org.springframework.batch.core.job.flow
-
Interface allowing for programmatic access to the decision on what the status
of a flow should be.
- JobExecutionException - Exception in org.springframework.batch.core
-
Root of exception hierarchy for checked exceptions in job and step execution.
- JobExecutionException(String) - Constructor for exception org.springframework.batch.core.JobExecutionException
-
- JobExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.JobExecutionException
-
- JobExecutionListener - Interface in org.springframework.batch.core
-
Provide callbacks at specific points in the lifecycle of a
Job
.
- JobExecutionListenerParser - Class in org.springframework.batch.core.configuration.xml
-
Parser for a step listener element.
- JobExecutionListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
-
- JobExecutionListenerSupport - Class in org.springframework.batch.core.listener
-
- JobExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.JobExecutionListenerSupport
-
- JobExecutionNotFailedException - Exception in org.springframework.batch.core.launch
-
Checked exception to indicate that user asked for a job execution to be
resumed when actually it didn't fail.
- JobExecutionNotFailedException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotFailedException
-
Create an exception with the given message.
- JobExecutionNotFailedException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotFailedException
-
- JobExecutionNotRunningException - Exception in org.springframework.batch.core.launch
-
Execution indicating that a JobExecution that is not currently running has
been requested to stop.
- JobExecutionNotRunningException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotRunningException
-
- JobExecutionNotStoppedException - Exception in org.springframework.batch.core.launch
-
Checked exception to indicate that user asked for a job execution to be
aborted when hasn't been stopped.
- JobExecutionNotStoppedException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotStoppedException
-
Create an exception with the given message.
- JobExplorer - Interface in org.springframework.batch.core.explore
-
Entry point for browsing executions of running or historical jobs and steps.
- JobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
-
A
FactoryBean
that automates the creation of a
SimpleJobExplorer
using JDBC DAO implementations.
- JobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- JobFactory - Interface in org.springframework.batch.core.configuration
-
Strategy for creating a single job.
- JobFactoryRegistrationListener - Class in org.springframework.batch.core.configuration.support
-
- JobFactoryRegistrationListener() - Constructor for class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
-
- JobFlowBuilder - Class in org.springframework.batch.core.job.builder
-
- JobFlowBuilder(FlowJobBuilder) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
-
- JobFlowBuilder(FlowJobBuilder, Step) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
-
- JobFlowBuilder(FlowJobBuilder, JobExecutionDecider) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
-
- JobFlowBuilder(FlowJobBuilder, Flow) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
-
- JobFlowExecutor - Class in org.springframework.batch.core.job.flow
-
- JobFlowExecutor(JobRepository, StepHandler, JobExecution) - Constructor for class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- JobInstance - Class in org.springframework.batch.core
-
Batch domain object representing a uniquely identifiable job run.
- JobInstance(Long, String) - Constructor for class org.springframework.batch.core.JobInstance
-
- JobInstanceAlreadyCompleteException - Exception in org.springframework.batch.core.repository
-
An exception indicating an illegal attempt to restart a job that was already
completed successfully.
- JobInstanceAlreadyCompleteException(String) - Constructor for exception org.springframework.batch.core.repository.JobInstanceAlreadyCompleteException
-
- JobInstanceAlreadyCompleteException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobInstanceAlreadyCompleteException
-
- JobInstanceAlreadyExistsException - Exception in org.springframework.batch.core.launch
-
Checked exception to indicate that a required
Job
is not
available.
- JobInstanceAlreadyExistsException(String) - Constructor for exception org.springframework.batch.core.launch.JobInstanceAlreadyExistsException
-
Create an exception with the given message.
- JobInstanceAlreadyExistsException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobInstanceAlreadyExistsException
-
- JobInstanceDao - Interface in org.springframework.batch.core.repository.dao
-
Data Access Object for job instances.
- JobInterruptedException - Exception in org.springframework.batch.core
-
Exception to indicate the the job has been interrupted.
- JobInterruptedException(String) - Constructor for exception org.springframework.batch.core.JobInterruptedException
-
- JobInterruptedException(String, BatchStatus) - Constructor for exception org.springframework.batch.core.JobInterruptedException
-
- JobKeyGenerator<T> - Interface in org.springframework.batch.core
-
Strategy interface for the generation of the key used in identifying
unique
JobInstance
.
- jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
-
- jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
-
- jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
-
- JobLauncher - Interface in org.springframework.batch.core.launch
-
Simple interface for controlling jobs, including possible ad-hoc executions,
based on different runtime identifiers.
- JobListenerFactoryBean - Class in org.springframework.batch.core.listener
-
- JobListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- JobListenerMetaData - Enum in org.springframework.batch.core.listener
-
Enumeration for
JobExecutionListener
meta data, which ties together the names
of methods, their interfaces, annotation, and expected arguments.
- JobLoader - Interface in org.springframework.batch.core.configuration.support
-
- JobLocator - Interface in org.springframework.batch.core.configuration
-
A runtime service locator interface for retrieving job configurations by
name
.
- JobOperator - Interface in org.springframework.batch.core.launch
-
Low level interface for inspecting and controlling jobs with access only to
primitive and collection types.
- JobParameter - Class in org.springframework.batch.core
-
Domain representation of a parameter to a batch job.
- JobParameter(String, boolean) - Constructor for class org.springframework.batch.core.JobParameter
-
Construct a new JobParameter as a String.
- JobParameter(Long, boolean) - Constructor for class org.springframework.batch.core.JobParameter
-
Construct a new JobParameter as a Long.
- JobParameter(Date, boolean) - Constructor for class org.springframework.batch.core.JobParameter
-
Construct a new JobParameter as a Date.
- JobParameter(Double, boolean) - Constructor for class org.springframework.batch.core.JobParameter
-
Construct a new JobParameter as a Double.
- JobParameter(String) - Constructor for class org.springframework.batch.core.JobParameter
-
Construct a new JobParameter as a String.
- JobParameter(Long) - Constructor for class org.springframework.batch.core.JobParameter
-
Construct a new JobParameter as a Long.
- JobParameter(Date) - Constructor for class org.springframework.batch.core.JobParameter
-
Construct a new JobParameter as a Date.
- JobParameter(Double) - Constructor for class org.springframework.batch.core.JobParameter
-
Construct a new JobParameter as a Double.
- JobParameter.ParameterType - Enum in org.springframework.batch.core
-
Enumeration representing the type of a JobParameter.
- JobParameterExecutionContextCopyListener - Class in org.springframework.batch.core.listener
-
- JobParameterExecutionContextCopyListener() - Constructor for class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
-
- JobParameters - Class in org.springframework.batch.core
-
Value object representing runtime parameters to a batch job.
- JobParameters() - Constructor for class org.springframework.batch.core.JobParameters
-
- JobParameters(Map<String, JobParameter>) - Constructor for class org.springframework.batch.core.JobParameters
-
- JobParametersBuilder - Class in org.springframework.batch.core
-
- JobParametersBuilder() - Constructor for class org.springframework.batch.core.JobParametersBuilder
-
Default constructor.
- JobParametersBuilder(JobParameters) - Constructor for class org.springframework.batch.core.JobParametersBuilder
-
Copy constructor.
- JobParametersConverter - Interface in org.springframework.batch.core.converter
-
- JobParametersExtractor - Interface in org.springframework.batch.core.step.job
-
- JobParametersIncrementer - Interface in org.springframework.batch.core
-
- JobParametersInvalidException - Exception in org.springframework.batch.core
-
- JobParametersInvalidException(String) - Constructor for exception org.springframework.batch.core.JobParametersInvalidException
-
- JobParametersNotFoundException - Exception in org.springframework.batch.core.launch
-
- JobParametersNotFoundException(String) - Constructor for exception org.springframework.batch.core.launch.JobParametersNotFoundException
-
Create an exception with the given message.
- JobParametersNotFoundException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobParametersNotFoundException
-
- JobParametersValidator - Interface in org.springframework.batch.core
-
Strategy interface for a
Job
to use in validating its parameters for
an execution.
- JobParser - Class in org.springframework.batch.core.configuration.xml
-
Parser for the lt;job/gt; element in the Batch namespace.
- JobParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobParser
-
- jobRegistrar() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
-
- jobRegistry() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
-
- jobRegistry() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
-
- JobRegistry - Interface in org.springframework.batch.core.configuration
-
A runtime service registry interface for registering job configurations by
name
.
- JobRegistryBackgroundJobRunner - Class in org.springframework.batch.core.launch.support
-
Command line launcher for registering jobs with a
JobRegistry
.
- JobRegistryBackgroundJobRunner(String) - Constructor for class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
-
- JobRegistryBeanPostProcessor - Class in org.springframework.batch.core.configuration.support
-
- JobRegistryBeanPostProcessor() - Constructor for class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
- jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
-
- jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
-
- jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
-
- JobRepository - Interface in org.springframework.batch.core.repository
-
Repository responsible for persistence of batch meta-data entities.
- JobRepositoryFactoryBean - Class in org.springframework.batch.core.repository.support
-
A
FactoryBean
that automates the creation of a
SimpleJobRepository
using JDBC DAO implementations which persist
batch metadata in database.
- JobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- JobRepositoryParser - Class in org.springframework.batch.core.configuration.xml
-
Parser for the lt;job-repository/gt; element in the Batch namespace.
- JobRepositoryParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobRepositoryParser
-
- JobRestartException - Exception in org.springframework.batch.core.repository
-
An exception indicating an illegal attempt to restart a job.
- JobRestartException(String) - Constructor for exception org.springframework.batch.core.repository.JobRestartException
-
- JobRestartException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobRestartException
-
- JobStep - Class in org.springframework.batch.core.step.job
-
A
Step
that delegates to a
Job
to do its work.
- JobStep() - Constructor for class org.springframework.batch.core.step.job.JobStep
-
- JobStepBuilder - Class in org.springframework.batch.core.step.builder
-
A step builder for
JobStep
instances.
- JobStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.JobStepBuilder
-
Create a new builder initialized with any properties in the parent.
- JVM_EXITCODE_COMPLETED - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
-
- JVM_EXITCODE_GENERIC_ERROR - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
-
- JVM_EXITCODE_JOB_ERROR - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
-
- JvmSystemExiter - Class in org.springframework.batch.core.launch.support
-
Implementation of the
SystemExiter
interface that calls the standards
System.exit method.
- JvmSystemExiter() - Constructor for class org.springframework.batch.core.launch.support.JvmSystemExiter
-
- saveExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
-
Persist the execution context associated with the given jobExecution,
persistent entry for the context should not exist yet.
- saveExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
-
Persist the execution context associated with the given stepExecution,
persistent entry for the context should not exist yet.
- saveExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- saveExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- saveExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
-
- saveExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
-
- saveExecutionContexts(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
-
Persist the execution context associated with each stepExecution in a given collection,
persistent entry for the context should not exist yet.
- saveExecutionContexts(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- saveExecutionContexts(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
-
- saveJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
SQL implementation using Sequences via the Spring incrementer
abstraction.
- saveJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
Save a new JobExecution.
- saveJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
-
- saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
Save a StepExecution.
- saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
-
- saveStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
Save the given StepExecution.
- saveStepExecutions(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
Batch insert StepExecutions
- saveStepExecutions(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
-
- saveStepExecutions(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
Save the given collection of StepExecution as a batch.
- SCHEDULE_DATE_KEY - Static variable in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
-
- ScheduledJobParametersFactory - Class in org.springframework.batch.core.launch.support
-
- ScheduledJobParametersFactory() - Constructor for class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
-
- selectImports(AnnotationMetadata) - Method in class org.springframework.batch.core.configuration.annotation.BatchConfigurationSelector
-
- serialize(Object, OutputStream) - Method in class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
-
Serializes an execution context to the provided
OutputStream
.
- serialize(Object, OutputStream) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
-
Serializes the passed execution context to the supplied OutputStream.
- setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
Flag to indicate that the partition target step is allowed to start if an
execution is complete.
- setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.AbstractStep
-
Public setter for flag that determines whether the step should start again if it is already complete.
- setAllowStartIfComplete(Boolean) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public setter for the flag to indicate that the step should be replayed on a restart, even if successful the
first time.
- setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Setter for the parent application context.
- setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
The enclosing application context, which can be used to check if events
come from the
expected source.
- setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
An application context that can be used as a parent context for all the
factories.
- setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
-
Setter for the parent application context.
- setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
-
- setApplicationContextFactories(ApplicationContextFactory[]) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
Add some factories to the set that will be used to load contexts and jobs.
- setAutoProxy(boolean) - Method in class org.springframework.batch.core.scope.StepScope
-
Flag to indicate that bean definitions need not be auto proxied.
- setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
Public setter for the BackOffPolicy
.
- setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
- setBeanFactoryPostProcessorClasses(Class<? extends BeanFactoryPostProcessor>[]) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Determines which bean factory post processors (like property placeholders) should be copied from the parent
context.
- setBeanFactoryPostProcessorClasses(Class<? extends BeanFactoryPostProcessor>[]) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
Determines which bean factory post processors (like property
placeholders) should be copied from the parent context.
- setBeanName(String) - Method in class org.springframework.batch.core.job.AbstractJob
-
Set the name property if it is not already set.
- setBeanName(String) - Method in class org.springframework.batch.core.step.AbstractStep
-
Set the name property if it is not already set.
- setBeanName(String) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Set the bean name property, which will become the name of the
Step
when it is created.
- setBeanPostProcessorExcludeClasses(Class<?>[]) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Determines by exclusion which bean post processors should be copied from the parent context.
- setBeanPostProcessorExcludeClasses(Class<?>[]) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
Determines by exclusion which bean post processors should be copied from
the parent context.
- setBuffering(boolean) - Method in class org.springframework.batch.core.step.item.ChunkOrientedTasklet
-
Flag to indicate that items should be buffered once read.
- setBuffering(boolean) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
A flag to indicate that items have been buffered and therefore will
always come back as a chunk after a rollback.
- setBundleContext(BundleContext) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
-
Stash the BundleContext
for creating a job application context
later.
- setBusy(boolean) - Method in class org.springframework.batch.core.step.item.Chunk
-
Register an interest in the chunk to prevent it from being cleaned up
before the flag is reset to false.
- setCacheCapacity(int) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
Public setter for the capacity of the cache in the retry policy.
- setCallable(Callable<RepeatStatus>) - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
-
- setChunkCompletionPolicy(CompletionPolicy) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- setChunkListeners(ChunkListener[]) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
Register each of the objects as listeners.
- setChunkMonitor(ChunkMonitor) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
- setChunkOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public setter for the chunkOperations.
- setChunkSize(int) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
-
- setClobType(int) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- setClobTypeToUse(int) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- setCommand(String) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
- setCommitCount(int) - Method in class org.springframework.batch.core.StepExecution
-
Sets the current number of commits for this execution
- setCommitInterval(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Set the commit interval.
- setComplete() - Method in class org.springframework.batch.core.scope.context.ChunkContext
-
Setter for the flag to signal complete processing of a chunk.
- setCopyConfiguration(boolean) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Flag to indicate that configuration such as bean post processors and custom editors should be copied from the
parent context.
- setCopyConfiguration(boolean) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
Flag to indicate that configuration such as bean post processors and
custom editors should be copied from the parent context.
- setCreateTime(Date) - Method in class org.springframework.batch.core.JobExecution
-
- setDatabaseType(String) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
Sets the database type.
- setDataSource(DataSource) - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- setDataSource(DataSource) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- setDataSource(DataSource) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- setDateFormat(DateFormat) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
Public setter for injecting a date format.
- setDateFormat(DateFormat) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
-
Public setter for injecting a date format.
- setDelegate(Object) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- setDelegate(StepExecutionAggregator) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
-
- setDisplayName(String) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
-
- setEnd() - Method in class org.springframework.batch.core.step.item.Chunk
-
Set the flag to say that this chunk represents an end of stream (there is
no more data to process).
- setEndTime(Date) - Method in class org.springframework.batch.core.JobExecution
-
- setEndTime(Date) - Method in class org.springframework.batch.core.StepExecution
-
Sets the time that this execution ended
- setEnvironmentParams(String[]) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
- setExceptionClassifier(SubclassClassifier<Throwable, SkipPolicy>) - Method in class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
-
The classifier that will be used to choose a delegate policy.
- setExceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- setExecutionContext(ExecutionContext) - Method in class org.springframework.batch.core.job.SimpleStepHandler
-
A context containing values to be added to the step execution before it
is handled.
- setExecutionContext(ExecutionContext) - Method in class org.springframework.batch.core.JobExecution
-
- setExecutionContext(ExecutionContext) - Method in class org.springframework.batch.core.StepExecution
-
- setExitCodeMapper(ExitCodeMapper) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
- setExitMessageLength(int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
Public setter for the exit message length in database.
- setExitMessageLength(int) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
Public setter for the exit message length in database.
- setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.JobExecution
-
- setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.StepContribution
-
- setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.StepExecution
-
- setFilterCount(int) - Method in class org.springframework.batch.core.StepExecution
-
Public setter for the number of items filtered out of this execution.
- setFlow(Flow) - Method in class org.springframework.batch.core.job.flow.FlowJob
-
Public setter for the flow.
- setFlow(Flow) - Method in class org.springframework.batch.core.job.flow.FlowStep
-
Public setter for the flow.
- setGridSize(int) - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
-
- setGroupName(String) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
The group name for jobs registered by this component.
- setHierarchicalStreamDriver(HierarchicalStreamDriver) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
-
- setId(Long) - Method in class org.springframework.batch.core.Entity
-
- setImportMetadata(AnnotationMetadata) - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
-
- setIncrementerFactory(DataFieldMaxValueIncrementerFactory) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- setInterruptionPolicy(StepInterruptionPolicy) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
- setInterruptOnCancel(boolean) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
- setIsolation(Isolation) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- setIsolationLevelForCreate(String) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
public setter for the isolation level to be used for the transaction when
job execution entities are initially created.
- setIsReaderTransactionalQueue(boolean) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Flag to signal that the reader is transactional (usually a JMS consumer) so that items are re-presented after a
rollback.
- setItemProcessor(ItemProcessor<? super T, ? extends S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- setItemProcessor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
- setItemReader(ItemReader<? extends T>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- setItemReader(ItemReader<?>) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
-
- setItemWriter(ItemWriter<? super S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- setItemWriter(ItemWriter<? super O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
- setJdbcTemplate(JdbcOperations) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- setJob(Job) - Method in class org.springframework.batch.core.step.job.JobStep
-
The
Job
to delegate to in this step.
- setJobExecutionIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
Setter for
DataFieldMaxValueIncrementer
to be used when
generating primary keys for
JobExecution
instances.
- setJobExecutionListeners(JobExecutionListener[]) - Method in class org.springframework.batch.core.job.AbstractJob
-
- setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
- setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
-
- setJobFactoryRef(String) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Convenience method for subclasses to set the job factory reference if it
is available (null is fine, but the quality of error reports is better if
it is available).
- setJobIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
Setter for
DataFieldMaxValueIncrementer
to be used when
generating primary keys for
JobInstance
instances.
- setJobInstance(JobInstance) - Method in class org.springframework.batch.core.JobExecution
-
- setJobLauncher(JobLauncher) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- setJobLauncher(JobLauncher) - Method in class org.springframework.batch.core.step.job.JobStep
-
- setJobLoader(JobLoader) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
The job loader that will be used to load and manage jobs.
- setJobLoader(JobLoader) - Method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
-
A loader for the jobs that are going to be registered.
- setJobLocator(JobLocator) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
- setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
- setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- setJobParametersExtractor(JobParametersExtractor) - Method in class org.springframework.batch.core.step.job.JobStep
-
- setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.core.job.AbstractJob
-
- setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- setJobParametersValidator(JobParametersValidator) - Method in class org.springframework.batch.core.job.AbstractJob
-
A validator for job parameters.
- setJobParametersValidator(JobParametersValidator) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
- setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
-
Public setter for a
JobRegistry
to use for all the bind and
unbind events.
- setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
- setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
-
A job registry that can be used to create a job loader (if none is provided).
- setJobRegistry(ListableJobLocator) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- setJobRepository(JobRepository) - Method in class org.springframework.batch.core.job.AbstractJob
-
Public setter for the
JobRepository
that is needed to manage the
state of the batch meta domain (jobs, steps, executions) during the life
of a job.
- setJobRepository(JobRepository) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- setJobRepository(JobRepository) - Method in class org.springframework.batch.core.job.SimpleStepHandler
-
- setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
- setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
-
Set the JobRepsitory.
- setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- setJobRepository(JobRepository) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
The job repository that will be used to manage the persistence of the
delegate step executions.
- setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.AbstractStep
-
- setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- setKey(String) - Method in class org.springframework.batch.core.launch.support.RunIdIncrementer
-
The name of the run id in the job parameters.
- setKeyGenerator(KeyGenerator) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
The
KeyGenerator
to use to identify failed items across rollback.
- setKeyGenerator(KeyGenerator) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
The
KeyGenerator
to use to identify failed items across rollback.
- setKeyName(String) - Method in class org.springframework.batch.core.partition.support.MultiResourcePartitioner
-
- setKeyName(String) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
-
Public setter for the key name of a Long value in the
JobParameters
that will contain a commit interval.
- setKeys(String[]) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
-
- setKeys(String[]) - Method in class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
-
- setKeys(String[]) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
-
The key names to pull out of the execution context or job parameters, if
they exist.
- setLastUpdated(Date) - Method in class org.springframework.batch.core.JobExecution
-
Set the last time this JobExecution was updated.
- setLastUpdated(Date) - Method in class org.springframework.batch.core.StepExecution
-
Set the time when the StepExecution was last updated before persisting
- setLauncher(JobLauncher) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
- setListeners(List<? extends ChunkListener>) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
-
Public setter for the listeners.
- setListeners(List<? extends ItemProcessListener<? super T, ? super S>>) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
-
Public setter for the listeners.
- setListeners(List<? extends ItemReadListener<? super T>>) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
-
Public setter for the listeners.
- setListeners(List<? extends ItemWriteListener<? super S>>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
-
Public setter for the listeners.
- setListeners(List<? extends JobExecutionListener>) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
-
Public setter for the listeners.
- setListeners(List<? extends SkipListener<? super T, ? super S>>) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
-
Public setter for the listeners.
- setListeners(StepExecutionListener[]) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
-
Public setter for the listeners.
- setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
Register each of the objects as listeners.
- setListeners(StepListener[]) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
The listeners to inject into the
Step
.
- setListeners(RetryListener[]) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
-
- setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
- setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
-
- setLobHandler(LobHandler) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- setLobHandler(LobHandler) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- setLobHandler(LobHandler) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
A special handler for large objects.
- setMapping(Map<String, Integer>) - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
-
Supply the ExitCodeMappings
- setMappings(Map<Object, ExitStatus>) - Method in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
-
- setMaxSkipsOnRead(int) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
-
- setMaxVarCharLength(int) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
Public setter for the length of long string columns in database.
- setMetaDataMap(Map<String, String>) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- setName(String) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
The name of the flow that is created by this factory.
- setName(String) - Method in class org.springframework.batch.core.job.AbstractJob
-
Set the name property.
- setName(String) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- setName(String) - Method in class org.springframework.batch.core.scope.StepScope
-
Public setter for the name property.
- setName(String) - Method in class org.springframework.batch.core.step.AbstractStep
-
Set the name property.
- setName(String) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- setNoRollbackExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
Exception classes that are candidates for no rollback.
- setNumberFormat(NumberFormat) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
- setOptionalKeys(String[]) - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
-
The keys that are optional in the parameters.
- setOrder(int) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
The order to start up and shutdown.
- setOrder(int) - Method in class org.springframework.batch.core.scope.StepScope
-
- setParameters(List<?>) - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
-
The parameter values that will be set on the PreparedStatement.
- setPartitioner(Partitioner) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
The
Partitioner
that will be used to generate step execution meta
data for the target step.
- setPartitionHandler(PartitionHandler) - Method in class org.springframework.batch.core.partition.support.PartitionStep
-
A
PartitionHandler
which can send out step executions for remote
processing and bring back the results.
- setPath(String) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
-
- setPolicyMap(Map<Class<? extends Throwable>, SkipPolicy>) - Method in class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
-
Setter for policy map.
- setProcessorTransactional(boolean) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
- setProcessorTransactional(boolean) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
Flag to say that the
ItemProcessor
is transactional (defaults to
true).
- setProcessSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
-
Set the number of records skipped during processing.
- setProcessSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
- setPropagation(Propagation) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- setProxyTargetClass(boolean) - Method in class org.springframework.batch.core.scope.StepScope
-
Flag to indicate that proxies should use dynamic subclassing.
- setReadCount(int) - Method in class org.springframework.batch.core.StepExecution
-
Sets the current number of read items for this execution
- setReadSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
-
Set the number of records skipped on read
- setReflectionProvider(ReflectionProvider) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
-
- setRepositoryFactory(MapJobRepositoryFactoryBean) - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
-
The repository factory that can be used to create daos for the explorer.
- setRequiredKeys(String[]) - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
-
The keys that are required in the parameters.
- setResources(Resource[]) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
- setResources(Resource[]) - Method in class org.springframework.batch.core.partition.support.MultiResourcePartitioner
-
The resources to assign to each partition.
- setRestartable(boolean) - Method in class org.springframework.batch.core.job.AbstractJob
-
Boolean flag to prevent categorically a job from restarting, even if it
has failed previously.
- setRestartable(boolean) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- setRetryableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
Public setter for the retryable exceptions classifier map (from throwable class to boolean, true is retryable).
- setRetryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
Override the default retry context cache for retry of chunk processing.
- setRetryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
-
- setRetryLimit(int) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
Public setter for the retry limit.
- setRetryListeners(RetryListener...) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
Public setter for the RetryListener
s.
- setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
Setter for the retry policy.
- setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
-
- setRollbackClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
A classifier that can distinguish between exceptions that cause rollback
(return true) or not (return false).
- setRollbackClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
-
Classifier to determine whether exceptions have been marked as
no-rollback (as opposed to skippable).
- setRollbackCount(int) - Method in class org.springframework.batch.core.StepExecution
-
Setter for number of rollbacks for this execution
- setSerializer(ExecutionContextSerializer) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- setSerializer(ExecutionContextSerializer) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
Setter for Serializer
implementation
- setSerializer(ExecutionContextSerializer) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- setShortContextLength(int) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
The maximum size that an execution context can have and still be stored
completely in short form in the column SHORT_CONTEXT
.
- setSingleton(boolean) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public setter for the singleton flag.
- setSkipLimit(int) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
A limit that determines skip policy.
- setSkipLimit(int) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
-
The absolute number of skips (of skippable exceptions) that can be
tolerated before a failure.
- setSkippableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
Exception classes that when raised won't crash the job but will result in the item which handling caused the
exception being skipped.
- setSkippableExceptionClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
-
The classifier that will be used to decide on skippability.
- setSkippableExceptionMap(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
-
Set up the classifier through a convenient map from throwable class to
boolean (true if skippable).
- setSkipPolicies(SkipPolicy[]) - Method in class org.springframework.batch.core.step.skip.CompositeSkipPolicy
-
- setSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
A
SkipPolicy
that determines the outcome of an exception when processing an item.
- setSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
-
The policy that determines whether exceptions can be skipped on read.
- setStartLimit(int) - Method in class org.springframework.batch.core.step.AbstractStep
-
Public setter for the startLimit.
- setStartLimit(Integer) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- setStartLimit(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public setter for the start limit for the step.
- setStartTime(Date) - Method in class org.springframework.batch.core.JobExecution
-
- setStartTime(Date) - Method in class org.springframework.batch.core.StepExecution
-
Sets the time this execution started
- setStateTransitions(List<StateTransition>) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
The raw state transitions for the flow.
- setStateTransitions(List<StateTransition>) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Public setter for the stateTransitions.
- setStatus(BatchStatus) - Method in class org.springframework.batch.core.JobExecution
-
Set the value of the status field.
- setStatus(BatchStatus) - Method in class org.springframework.batch.core.StepExecution
-
Sets the current status of this step
- setStatuses(String[]) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
-
- setStep(Step) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
-
- setStepExecutionAggregator(StepExecutionAggregator) - Method in class org.springframework.batch.core.partition.support.PartitionStep
-
- setStepExecutionIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
- setStepExecutionListeners(StepExecutionListener[]) - Method in class org.springframework.batch.core.step.AbstractStep
-
Register each of the objects as listeners.
- setStepExecutionSplitter(StepExecutionSplitter) - Method in class org.springframework.batch.core.partition.support.PartitionStep
-
- setStepLocator(StepLocator) - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
-
- setStepName(String) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
The name of the target step that will be executed across the partitions.
- setStepName(String) - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
-
- setStepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public setter for the stepOperations.
- setStepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
- setStepRegistry(StepRegistry) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
- setSteps(List<Step>) - Method in class org.springframework.batch.core.job.SimpleJob
-
Public setter for the steps in this job.
- setStreams(ItemStream[]) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
The streams to inject into the
Step
.
- setStreams(ItemStream[]) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
Register each of the streams for callbacks at the appropriate time in the
step.
- setStrict(boolean) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
-
If set to TRUE, the listener will throw an exception if any 'key' is not
found in the Step
ExecutionContext
.
- setSystemExiter(SystemExiter) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
- setSystemProcessExitCodeMapper(SystemProcessExitCodeMapper) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
- setTablePrefix(String) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
Sets the table prefix for all the batch meta-data tables.
- setTablePrefix(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
Public setter for the table prefix property.
- setTablePrefix(String) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
Sets the table prefix for all the batch meta-data tables.
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
-
Public setter for the taskExecutor.
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
-
Set the TaskExecutor.
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
-
Setter for the TaskExecutor
that is used to farm out step
executions to multiple threads.
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public setter for the TaskExecutor
.
- setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
Sets the task executor that will be used to execute the system command
NB! Avoid using a synchronous task executor
- setTasklet(Tasklet) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
- setTerminateOnly() - Method in class org.springframework.batch.core.StepExecution
-
Set a flag that will signal to an execution environment that this
execution (and its surrounding job) wishes to exit.
- setTerminationCheckInterval(long) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
The time interval how often the tasklet will check for termination
status.
- setThrottleLimit(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public setter for the throttle limit.
- setTimeout(long) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
Timeout in milliseconds.
- setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
Public setter for the TransactionAttribute
.
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
Public setter for the PlatformTransactionManager
.
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public setter for the PlatformTransactionManager
.
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
Public setter for the PlatformTransactionManager
.
- setTransactionTimeout(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
The timeout for an individual transaction in the step.
- setUserData(Object) - Method in class org.springframework.batch.core.step.item.Chunk
-
- setValidateTransactionState(boolean) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
Flag to determine whether to check for an existing transaction when a
JobExecution is created.
- setValidators(List<JobParametersValidator>) - Method in class org.springframework.batch.core.job.CompositeJobParametersValidator
-
Public setter for the validators
- setValues(PreparedStatement) - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
-
- setVersion(Integer) - Method in class org.springframework.batch.core.Entity
-
Public setter for the version needed only by repository methods.
- setWorkingDirectory(String) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
- setWriteCount(int) - Method in class org.springframework.batch.core.StepExecution
-
Sets the current number of written items for this execution
- setWriteSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
-
Set the number of records skipped on write
- setWriteSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
- shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
-
- shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.CompositeSkipPolicy
-
- shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
-
Consult the classifier and find a delegate policy, and then use that to
determine the outcome.
- shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
-
Given the provided exception and skip count, determine whether or not
processing should continue for the given exception.
- shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.NeverSkipItemSkipPolicy
-
- shouldSkip(Throwable, int) - Method in interface org.springframework.batch.core.step.skip.SkipPolicy
-
Returns true or false, indicating whether or not processing should
continue with the given throwable.
- SimpleBatchConfiguration - Class in org.springframework.batch.core.configuration.annotation
-
Base Configuration
class providing common structure for enabling and using Spring Batch.
- SimpleBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
-
- SimpleChunkProcessor<I,O> - Class in org.springframework.batch.core.step.item
-
Simple implementation of the
ChunkProcessor
interface that handles
basic item writing and processing.
- SimpleChunkProcessor(ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>) - Constructor for class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
- SimpleChunkProvider<I> - Class in org.springframework.batch.core.step.item
-
Simple implementation of the ChunkProvider interface that does basic chunk
providing from an
ItemReader
.
- SimpleChunkProvider(ItemReader<? extends I>, RepeatOperations) - Constructor for class org.springframework.batch.core.step.item.SimpleChunkProvider
-
- SimpleFlow - Class in org.springframework.batch.core.job.flow.support
-
A
Flow
that branches conditionally depending on the exit status of
the last
State
.
- SimpleFlow(String) - Constructor for class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Create a flow with the given name.
- SimpleFlowFactoryBean - Class in org.springframework.batch.core.configuration.xml
-
Convenience factory for SimpleFlow instances for use in XML namespace.
- SimpleFlowFactoryBean() - Constructor for class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
- SimpleJob - Class in org.springframework.batch.core.job
-
Simple implementation of
Job
interface providing the ability to run a
JobExecution
.
- SimpleJob() - Constructor for class org.springframework.batch.core.job.SimpleJob
-
Default constructor for job with null name
- SimpleJob(String) - Constructor for class org.springframework.batch.core.job.SimpleJob
-
- SimpleJobBuilder - Class in org.springframework.batch.core.job.builder
-
- SimpleJobBuilder(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.SimpleJobBuilder
-
Create a new builder initialized with any properties in the parent.
- SimpleJobExplorer - Class in org.springframework.batch.core.explore.support
-
- SimpleJobExplorer(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- SimpleJobLauncher - Class in org.springframework.batch.core.launch.support
-
- SimpleJobLauncher() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobLauncher
-
- SimpleJobOperator - Class in org.springframework.batch.core.launch.support
-
Simple implementation of the JobOperator interface.
- SimpleJobOperator() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- SimpleJobRepository - Class in org.springframework.batch.core.repository.support
-
Implementation of
JobRepository
that stores JobInstances,
JobExecutions, and StepExecutions using the injected DAOs.
- SimpleJobRepository(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- SimpleJvmExitCodeMapper - Class in org.springframework.batch.core.launch.support
-
An implementation of
ExitCodeMapper
that can be configured through a
map from batch exit codes (String) to integer results.
- SimpleJvmExitCodeMapper() - Constructor for class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
-
- SimplePartitioner - Class in org.springframework.batch.core.partition.support
-
- SimplePartitioner() - Constructor for class org.springframework.batch.core.partition.support.SimplePartitioner
-
- SimpleRetryExceptionHandler - Class in org.springframework.batch.core.step.item
-
An
ExceptionHandler
that is aware of the retry context so that it can
distinguish between a fatal exception and one that can be retried.
- SimpleRetryExceptionHandler(RetryPolicy, ExceptionHandler, Collection<Class<? extends Throwable>>) - Constructor for class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
-
Create an exception handler from its mandatory properties.
- SimpleStepBuilder<I,O> - Class in org.springframework.batch.core.step.builder
-
Step builder for simple item processing (chunk oriented) steps.
- SimpleStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
Create a new builder initialized with any properties in the parent.
- SimpleStepBuilder(SimpleStepBuilder<I, O>) - Constructor for class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
Create a new builder initialized with any properties in the parent.
- SimpleStepExecutionSplitter - Class in org.springframework.batch.core.partition.support
-
- SimpleStepExecutionSplitter() - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
Default constructor for convenience in configuration.
- SimpleStepExecutionSplitter(JobRepository, boolean, String, Partitioner) - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
- SimpleStepExecutionSplitter(JobRepository, Step, Partitioner) - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
- SimpleStepFactoryBean<T,S> - Class in org.springframework.batch.core.step.factory
-
Most common configuration options for simple steps should be found here.
- SimpleStepFactoryBean() - Constructor for class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- SimpleStepHandler - Class in org.springframework.batch.core.job
-
Implementation of
StepHandler
that manages repository and restart
concerns.
- SimpleStepHandler() - Constructor for class org.springframework.batch.core.job.SimpleStepHandler
-
Convenient default constructor for configuration usage.
- SimpleStepHandler(JobRepository) - Constructor for class org.springframework.batch.core.job.SimpleStepHandler
-
- SimpleStepHandler(JobRepository, ExecutionContext) - Constructor for class org.springframework.batch.core.job.SimpleStepHandler
-
- SimpleSystemProcessExitCodeMapper - Class in org.springframework.batch.core.step.tasklet
-
- SimpleSystemProcessExitCodeMapper() - Constructor for class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
-
- size() - Method in class org.springframework.batch.core.step.item.Chunk
-
- skip(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Explicitly request certain exceptions (and subclasses) to be skipped.
- skip(Exception) - Method in class org.springframework.batch.core.step.item.Chunk
-
Register an anonymous skip.
- SkipException - Exception in org.springframework.batch.core.step.skip
-
Base exception indicating that the skip has failed or caused a failure.
- SkipException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
-
- SkipException(String) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
-
- skipLimit(int) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Sets the maximium number of failed items to skip before the step fails.
- SkipLimitExceededException - Exception in org.springframework.batch.core.step.skip
-
Exception indicating that the skip limit for a particular has
been exceeded.
- SkipLimitExceededException(int, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipLimitExceededException
-
- SkipListener<T,S> - Interface in org.springframework.batch.core
-
Interface for listener to skipped items.
- SkipListenerFailedException - Exception in org.springframework.batch.core.step.skip
-
Special exception to indicate a failure in a skip listener.
- SkipListenerFailedException(String, RuntimeException, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipListenerFailedException
-
- SkipListenerSupport<T,S> - Class in org.springframework.batch.core.listener
-
Basic no-op implementations of all
SkipListener
implementations.
- SkipListenerSupport() - Constructor for class org.springframework.batch.core.listener.SkipListenerSupport
-
- SkipOverflowException - Exception in org.springframework.batch.core.step.item
-
- SkipOverflowException(String) - Constructor for exception org.springframework.batch.core.step.item.SkipOverflowException
-
- skipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Provide an explicit policy for managing skips.
- SkipPolicy - Interface in org.springframework.batch.core.step.skip
-
Policy for determining whether or not some processing should be skipped.
- SkipPolicyFailedException - Exception in org.springframework.batch.core.step.skip
-
Special exception to indicate a failure in a skip policy.
- SkipPolicyFailedException(String, RuntimeException, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipPolicyFailedException
-
- SkipWrapper<T> - Class in org.springframework.batch.core.step.item
-
Wrapper for an item and its exception if it failed processing.
- SkipWrapper(T) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
-
- SkipWrapper(Throwable) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
-
- SkipWrapper(T, Throwable) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
-
- split(TaskExecutor) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
- split(TaskExecutor) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
-
- split(StepExecution, int) - Method in interface org.springframework.batch.core.partition.StepExecutionSplitter
-
- split(StepExecution, int) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
- SplitParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <split/> elements inside a job.
- SplitParser(String) - Constructor for class org.springframework.batch.core.configuration.xml.SplitParser
-
- SplitState - Class in org.springframework.batch.core.job.flow.support.state
-
A
State
implementation that splits a
Flow
into multiple
parallel subflows.
- SplitState(Collection<Flow>, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.SplitState
-
- splitter(StepExecutionSplitter) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
- StandaloneStepParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <step/> elements for a job.
- StandaloneStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.StandaloneStepParser
-
- start() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
Take all the contexts from the factories provided and pass them to the
JobLoader
.
- start(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
Start a flow.
- start(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
If a flow should start with a decision use this as the first state.
- start(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
If a flow should start with a subflow use this as the first state.
- start(Flow) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
-
Start a job with this flow, but expect to transition from there to other flows or steps.
- start(Step) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
-
Start a job with this step, but expect to transition from there to other flows or steps.
- start(Step) - Method in class org.springframework.batch.core.job.builder.JobBuilder
-
Create a new job builder that will execute a step or sequence of steps.
- start(Flow) - Method in class org.springframework.batch.core.job.builder.JobBuilder
-
Create a new job builder that will execute a flow.
- start(Step) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
-
Start the job with this step.
- start(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
-
Start with this decider.
- start(FlowExecutor) - Method in interface org.springframework.batch.core.job.flow.Flow
-
- start(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
- start(String, String) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Start a new instance of a job with the parameters specified.
- start(String, String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- start(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
-
- startLimit(int) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
-
- StartLimitExceededException - Exception in org.springframework.batch.core
-
Indicates the step's start limit has been exceeded.
- StartLimitExceededException(String) - Constructor for exception org.springframework.batch.core.StartLimitExceededException
-
- startNextInstance(String) - Method in interface org.springframework.batch.core.launch.JobOperator
-
- startNextInstance(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- State - Interface in org.springframework.batch.core.job.flow
-
- StateTransition - Class in org.springframework.batch.core.job.flow.support
-
Value object representing a potential transition from one
State
to
another.
- Step - Interface in org.springframework.batch.core
-
Batch domain interface representing the configuration of a step.
- step(Step) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
Provide an actual step instance to execute in parallel.
- StepBuilder - Class in org.springframework.batch.core.step.builder
-
Convenient entry point for building all kinds of steps.
- StepBuilder(String) - Constructor for class org.springframework.batch.core.step.builder.StepBuilder
-
Initialize a step builder for a step with the given name.
- StepBuilderException - Exception in org.springframework.batch.core.step.builder
-
Utility exception thrown by builders when they encounter unexpected checked exceptions.
- StepBuilderException(Exception) - Constructor for exception org.springframework.batch.core.step.builder.StepBuilderException
-
- StepBuilderFactory - Class in org.springframework.batch.core.configuration.annotation
-
- StepBuilderFactory(JobRepository, PlatformTransactionManager) - Constructor for class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
-
- StepBuilderHelper<B extends StepBuilderHelper<B>> - Class in org.springframework.batch.core.step.builder
-
A base class and utility for other step builders providing access to common properties like job repository and
transaction manager.
- StepBuilderHelper(String) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper
-
- StepBuilderHelper(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper
-
Create a new builder initialized with any properties in the parent.
- StepBuilderHelper.CommonStepProperties - Class in org.springframework.batch.core.step.builder
-
- StepBuilderHelper.CommonStepProperties() - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- StepBuilderHelper.CommonStepProperties(StepBuilderHelper.CommonStepProperties) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- stepBuilders() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
-
- StepContext - Class in org.springframework.batch.core.scope.context
-
A context object that can be used to interrogate the current
StepExecution
and some of its associated properties using expressions
based on bean paths.
- StepContext(StepExecution) - Constructor for class org.springframework.batch.core.scope.context.StepContext
-
- StepContextRepeatCallback - Class in org.springframework.batch.core.scope.context
-
Convenient base class for clients who need to do something in a repeat
callback inside a
Step
.
- StepContextRepeatCallback(StepExecution) - Constructor for class org.springframework.batch.core.scope.context.StepContextRepeatCallback
-
- StepContribution - Class in org.springframework.batch.core
-
Represents a contribution to a
StepExecution
, buffering changes until
they can be applied at a chunk boundary.
- StepContribution(StepExecution) - Constructor for class org.springframework.batch.core.StepContribution
-
- StepExecution - Class in org.springframework.batch.core
-
Batch domain object representation the execution of a step.
- StepExecution(String, JobExecution, Long) - Constructor for class org.springframework.batch.core.StepExecution
-
Constructor with mandatory properties.
- StepExecution(String, JobExecution) - Constructor for class org.springframework.batch.core.StepExecution
-
Constructor that substitutes in null for the execution id
- StepExecutionAggregator - Interface in org.springframework.batch.core.partition.support
-
Strategy for a aggregating step executions, usually when they are the result
of partitioned or remote execution.
- StepExecutionDao - Interface in org.springframework.batch.core.repository.dao
-
- StepExecutionListener - Interface in org.springframework.batch.core
-
Listener interface for the lifecycle of a
Step
.
- stepExecutionListenerMetaData() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- StepExecutionListenerSupport - Class in org.springframework.batch.core.listener
-
- StepExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepExecutionListenerSupport
-
- StepExecutionSimpleCompletionPolicy - Class in org.springframework.batch.core.resource
-
- StepExecutionSimpleCompletionPolicy() - Constructor for class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
-
- StepExecutionSplitter - Interface in org.springframework.batch.core.partition
-
Strategy interface for generating input contexts for a partitioned step
execution independent from the fabric they are going to run on.
- StepHandler - Interface in org.springframework.batch.core.job
-
Strategy interface for handling a
Step
on behalf of a
Job
.
- StepHolder - Interface in org.springframework.batch.core.step
-
Interface for holders of a
Step
as a convenience for callers who need
access to the underlying instance.
- StepInterruptionPolicy - Interface in org.springframework.batch.core.step
-
Strategy interface for an interruption policy.
- StepListener - Interface in org.springframework.batch.core
-
- StepListenerFactoryBean - Class in org.springframework.batch.core.listener
-
- StepListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.StepListenerFactoryBean
-
- StepListenerFailedException - Exception in org.springframework.batch.core.listener
-
Exception to indicate a problem in a step listener.
- StepListenerFailedException(String, Throwable) - Constructor for exception org.springframework.batch.core.listener.StepListenerFailedException
-
- StepListenerMetaData - Enum in org.springframework.batch.core.listener
-
Enumeration for
StepListener
meta data, which ties together the names
of methods, their interfaces, annotation, and expected arguments.
- StepListenerParser - Class in org.springframework.batch.core.configuration.xml
-
Parser for a step listener element.
- StepListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.StepListenerParser
-
- StepListenerParser(ListenerMetaData[]) - Constructor for class org.springframework.batch.core.configuration.xml.StepListenerParser
-
- StepListenerSupport<T,S> - Class in org.springframework.batch.core.listener
-
- StepListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepListenerSupport
-
- StepLocator - Interface in org.springframework.batch.core.step
-
Interface for locating a
Step
instance by name.
- stepLocator - Variable in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
-
- StepLocatorStepFactoryBean - Class in org.springframework.batch.core.step
-
- StepLocatorStepFactoryBean() - Constructor for class org.springframework.batch.core.step.StepLocatorStepFactoryBean
-
- stepName - Variable in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
-
- stepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Sets the repeat template used for iterating the tasklet execution.
- StepRegistry - Interface in org.springframework.batch.core.configuration
-
Registry keeping track of all the
Step
defined in a
Job
.
- StepScope - Annotation Type in org.springframework.batch.core.configuration.annotation
-
Convenient annotation for step scoped beans that defaults the proxy mode, so that it doesn't have to be specified
explicitly on every bean definition.
- StepScope - Class in org.springframework.batch.core.scope
-
Scope for step context.
- StepScope() - Constructor for class org.springframework.batch.core.scope.StepScope
-
- StepScopeManager - Class in org.springframework.batch.core.scope.context
-
Convenient aspect to wrap a single threaded step execution, where the
implementation of the
Step
is not step scope aware (i.e.
- StepScopeManager() - Constructor for class org.springframework.batch.core.scope.context.StepScopeManager
-
- StepState - Class in org.springframework.batch.core.job.flow.support.state
-
- StepState(Step) - Constructor for class org.springframework.batch.core.job.flow.support.state.StepState
-
- StepState(String, Step) - Constructor for class org.springframework.batch.core.job.flow.support.state.StepState
-
- StepSynchronizationManager - Class in org.springframework.batch.core.scope.context
-
Central convenience class for framework use in managing the step scope
context.
- StepSynchronizationManager() - Constructor for class org.springframework.batch.core.scope.context.StepSynchronizationManager
-
- stop() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
- stop() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
-
Signal the successful end of the flow.
- stop() - Method in class org.springframework.batch.core.JobExecution
-
- stop(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Send a stop signal to the
JobExecution
with the supplied id.
- stop() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
-
If embedded in a JVM, call this method to terminate the main method.
- stop(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- stopAndRestart(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
-
Stop the flow and provide a flow to start with if the flow is restarted.
- stopAndRestart(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
-
Stop the flow and provide a decider to start with if the flow is restarted.
- stopAndRestart(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
-
Stop the flow and provide a step to start with if the flow is restarted.
- STOPPED - Static variable in class org.springframework.batch.core.ExitStatus
-
Convenient constant value representing finished processing with
interrupted status.
- STOPPED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
-
Special well-known status value.
- stream(ItemStream) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Register a stream for callbacks that manage restart data.
- stream(ItemStream) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
- STRING_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
- switchOriginAndDestination(StateTransition, State, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Convenience method to switch the origin and destination of a transition,
creating a new instance.
- synchronizeStatus(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- synchronizeStatus(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
Because it may be possible that the status of a JobExecution is updated
while running, the following method will synchronize only the status and
version fields.
- synchronizeStatus(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
-
- SystemCommandException - Exception in org.springframework.batch.core.step.tasklet
-
Exception indicating failed execution of system command.
- SystemCommandException(String) - Constructor for exception org.springframework.batch.core.step.tasklet.SystemCommandException
-
- SystemCommandException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.tasklet.SystemCommandException
-
- SystemCommandTasklet - Class in org.springframework.batch.core.step.tasklet
-
Tasklet
that executes a system command.
- SystemCommandTasklet() - Constructor for class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
- SystemExiter - Interface in org.springframework.batch.core.launch.support
-
Interface for exiting the JVM.
- SystemProcessExitCodeMapper - Interface in org.springframework.batch.core.step.tasklet
-
Maps the exit code of a system process to ExitStatus value
returned by a system command.