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

A

afterPropertiesSet() - Method in class org.springframework.batch.integration.async.AsyncItemProcessor
Check mandatory properties (the AsyncItemProcessor.setDelegate(ItemProcessor)).
afterPropertiesSet() - Method in class org.springframework.batch.integration.async.AsyncItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
 
afterPropertiesSet() - Method in class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Asserts that mandatory properties are set.
afterPropertiesSet() - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
afterPropertiesSet() - Method in class org.springframework.batch.integration.step.DelegateStep
Check mandatory properties (delegate).
afterStep(StepExecution) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
aggregate(List<?>) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
aggregator(StepExecutionAggregator) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
AsynchronousFailureException - Exception in org.springframework.batch.integration.chunk
Exception indicating that a failure or early completion condition was detected in a remote worker.
AsynchronousFailureException(String, Throwable) - Constructor for exception org.springframework.batch.integration.chunk.AsynchronousFailureException
Create a new AsynchronousFailureException based on a message and another exception.
AsynchronousFailureException(String) - Constructor for exception org.springframework.batch.integration.chunk.AsynchronousFailureException
Create a new AsynchronousFailureException based on a message.
AsyncItemProcessor<I,O> - Class in org.springframework.batch.integration.async
An ItemProcessor that delegates to a nested processor and in the background.
AsyncItemProcessor() - Constructor for class org.springframework.batch.integration.async.AsyncItemProcessor
 
AsyncItemWriter<T> - Class in org.springframework.batch.integration.async
 
AsyncItemWriter() - Constructor for class org.springframework.batch.integration.async.AsyncItemWriter
 

B

backOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
BatchIntegrationConfiguration - Class in org.springframework.batch.integration.config.annotation
Base configuration class for Spring Batch Integration factory beans.
BatchIntegrationConfiguration(JobRepository, JobExplorer, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
BatchIntegrationNamespaceHandler - Class in org.springframework.batch.integration.config.xml
The namespace handler for the Spring Batch Integration namespace.
BatchIntegrationNamespaceHandler() - Constructor for class org.springframework.batch.integration.config.xml.BatchIntegrationNamespaceHandler
 
beanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Set the bean factory.
beanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the bean factory.
BeanFactoryStepLocator - Class in org.springframework.batch.integration.partition
A StepLocator implementation that just looks in its enclosing bean factory for components of type Step.
BeanFactoryStepLocator() - Constructor for class org.springframework.batch.integration.partition.BeanFactoryStepLocator
 
beforeStep(StepExecution) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
build() - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Build a master TaskletStep.
build() - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Create an IntegrationFlow with a ChunkProcessorChunkHandler configured as a service activator listening to the input channel and replying on the output channel.
build() - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 

C

chunk(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
chunk(CompletionPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
chunk(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
chunk(CompletionPolicy) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
ChunkHandler<T> - Interface in org.springframework.batch.integration.chunk
Interface for a remote worker in the Remote Chunking pattern.
ChunkMessageChannelItemWriter<T> - Class in org.springframework.batch.integration.chunk
 
ChunkMessageChannelItemWriter() - Constructor for class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
chunkOperations(RepeatOperations) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
ChunkProcessorChunkHandler<S> - Class in org.springframework.batch.integration.chunk
A ChunkHandler based on a ChunkProcessor.
ChunkProcessorChunkHandler() - Constructor for class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
 
ChunkRequest<T> - Class in org.springframework.batch.integration.chunk
Encapsulation of a chunk of items to be processed remotely as part of a step execution.
ChunkRequest(int, Collection<? extends T>, long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkRequest
 
ChunkResponse - Class in org.springframework.batch.integration.chunk
Encapsulates a response to processing a chunk of items, summarising the result as a StepContribution.
ChunkResponse(int, Long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(boolean, int, Long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(boolean, int, Long, StepContribution, String) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(ChunkResponse, boolean) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(boolean, int, Long, StepContribution, String, boolean) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
 
close() - Method in class org.springframework.batch.integration.async.AsyncItemWriter
 
close() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 

D

DelegateStep - Class in org.springframework.batch.integration.step
Provides a wrapper for an existing Step, delegating execution to it, but serving all other operations locally.
DelegateStep() - Constructor for class org.springframework.batch.integration.step.DelegateStep
 
doExecute(StepExecution) - Method in class org.springframework.batch.integration.step.DelegateStep
 

E

EnableBatchIntegration - Annotation Type in org.springframework.batch.integration.config.annotation
Enable Spring Batch Integration features and provide a base configuration for setting up remote chunking or partitioning infrastructure beans.
exceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
extract(ChunkResponse, boolean) - Method in class org.springframework.batch.integration.chunk.JmsRedeliveredExtractor
 

F

flow(Flow) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 

G

get(String) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilderFactory
Creates a RemoteChunkingMasterStepBuilder and initializes its job repository and transaction manager.
get(String) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilderFactory
Creates a RemotePartitioningMasterStepBuilder and initializes its job repository, job explorer, bean factory and transaction manager.
get(String) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilderFactory
Creates a RemotePartitioningWorkerStepBuilder and initializes its job repository, job explorer, bean factory and transaction manager.
getInputChannelAttributeName() - Method in class org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
 
getItems() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
 
getJob() - Method in class org.springframework.batch.integration.launch.JobLaunchRequest
 
getJobExecutionId() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
 
getJobId() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
 
getJobId() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
getJobParameters() - Method in class org.springframework.batch.integration.launch.JobLaunchRequest
 
getMessage() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
getObject() - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
Builds a ChunkHandler from the ChunkProcessor extracted from the step provided.
getObjectType() - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
The type of object created by this factory.
getSequence() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
 
getSequence() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
getStep(String) - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
Look up a bean with the provided name of type Step.
getStepContribution() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
 
getStepContribution() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
getStepContributions() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
getStepContributions() - Method in interface org.springframework.batch.integration.chunk.StepContributionSource
Get the currently available contributions and drain the source.
getStepExecutionId() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
 
getStepName() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
 
getStepNames() - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
Look in the bean factory for all beans of type Step.
gridSize(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 

H

handle(StepExecutionSplitter, StepExecution) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
Sends StepExecutionRequest objects to the request channel of the MessagingTemplate, and then receives the result back as a list of StepExecution on a reply channel.
handle(StepExecutionRequest) - Method in class org.springframework.batch.integration.partition.StepExecutionRequestHandler
 
handleChunk(ChunkRequest<T>) - Method in interface org.springframework.batch.integration.chunk.ChunkHandler
Handle the chunk, processing all the items and returning a response summarising the result.
handleChunk(ChunkRequest<S>) - Method in class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
 
handleRequestMessage(Message<?>) - Method in class org.springframework.batch.integration.launch.JobLaunchingGateway
Launches a Batch Job using the provided request Message.

I

init() - Method in class org.springframework.batch.integration.config.xml.BatchIntegrationNamespaceHandler
 
inputChannel(PollableChannel) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Set the input channel on which replies from workers will be received.
inputChannel(MessageChannel) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the input channel on which items sent by the master are received.
inputChannel(MessageChannel) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Set the input channel on which replies from workers will be received.
inputChannel(MessageChannel) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the input channel on which step execution requests sent by the master are received.
isRedelivered() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
isSingleton() - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
Optimization for the bean factory (always returns true).
isSuccessful() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
itemProcessor(ItemProcessor<I, O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the ItemProcessor to use to process items sent by the master step.
itemWriter(ItemWriter<O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the ItemWriter to use to write items sent by the master step.

J

JmsRedeliveredExtractor - Class in org.springframework.batch.integration.chunk
 
JmsRedeliveredExtractor() - Constructor for class org.springframework.batch.integration.chunk.JmsRedeliveredExtractor
 
job(Job) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
jobExplorer(JobExplorer) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Set the job explorer.
jobExplorer(JobExplorer) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the job explorer.
JobLaunchingGateway - Class in org.springframework.batch.integration.launch
The JobLaunchingGateway is used to launch Batch Jobs.
JobLaunchingGateway(JobLauncher) - Constructor for class org.springframework.batch.integration.launch.JobLaunchingGateway
Constructor taking a JobLauncher as parameter.
JobLaunchingGatewayParser - Class in org.springframework.batch.integration.config.xml
The parser for the Job-Launching Gateway, which will instantiate a JobLaunchingGatewayParser.
JobLaunchingGatewayParser() - Constructor for class org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
 
JobLaunchingMessageHandler - Class in org.springframework.batch.integration.launch
Message handler which uses strategies to convert a Message into a job and a set of job parameters
JobLaunchingMessageHandler(JobLauncher) - Constructor for class org.springframework.batch.integration.launch.JobLaunchingMessageHandler
 
JobLaunchRequest - Class in org.springframework.batch.integration.launch
Encapsulation of a Job and its JobParameters forming a request for a job to be launched.
JobLaunchRequest(Job, JobParameters) - Constructor for class org.springframework.batch.integration.launch.JobLaunchRequest
 
JobLaunchRequestHandler - Interface in org.springframework.batch.integration.launch
Interface for handling a JobLaunchRequest and returning a JobExecution.

K

keyGenerator(KeyGenerator) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 

L

launch(JobLaunchRequest) - Method in class org.springframework.batch.integration.launch.JobLaunchingMessageHandler
 
launch(JobLaunchRequest) - Method in interface org.springframework.batch.integration.launch.JobLaunchRequestHandler
 
listener(Object) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(SkipListener<? super I, ? super O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(ChunkListener) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(RetryListener) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(ItemReadListener<? super I>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(ItemWriteListener<? super O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(StepExecutionListener) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(Object) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
listener(StepExecutionListener) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
listener(Object) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
listener(StepExecutionListener) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 

M

maxWaitTimeouts(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
The maximum number of times to wait at the end of a step for a non-null result from the remote workers.
MessageChannelPartitionHandler - Class in org.springframework.batch.integration.partition
A PartitionHandler that uses MessageChannel instances to send instructions to remote workers and receive their responses.
MessageChannelPartitionHandler() - Constructor for class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
MessageSourcePollerInterceptor - Class in org.springframework.batch.integration.chunk
A ChannelInterceptor that turns a pollable channel into a "pass-thru channel": if a client calls receive() on the channel it will delegate to a MessageSource to pull the message directly from an external source.
MessageSourcePollerInterceptor() - Constructor for class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Convenient default constructor for configuration purposes.
MessageSourcePollerInterceptor(MessageSource<?>) - Constructor for class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
 
messagingTemplate(MessagingTemplate) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Set the MessagingTemplate to use to send data to workers.
messagingTemplate(MessagingTemplate) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Set the MessagingTemplate to use to send data to workers.

N

noRetry(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
noRollback(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
noSkip(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 

O

open(ExecutionContext) - Method in class org.springframework.batch.integration.async.AsyncItemWriter
 
open(ExecutionContext) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
org.springframework.batch.integration.async - package org.springframework.batch.integration.async
Components for executing item processing asynchronously and writing the results when processing is complete.
org.springframework.batch.integration.chunk - package org.springframework.batch.integration.chunk
Components for remote chunking.
org.springframework.batch.integration.config.annotation - package org.springframework.batch.integration.config.annotation
APIs for the configuration of Spring Integration components through annotations.
org.springframework.batch.integration.config.xml - package org.springframework.batch.integration.config.xml
APIs for the configuration of Spring Integration components through XML.
org.springframework.batch.integration.launch - package org.springframework.batch.integration.launch
Message based job launching components.
org.springframework.batch.integration.partition - package org.springframework.batch.integration.partition
Remote partitioning components.
org.springframework.batch.integration.step - package org.springframework.batch.integration.step
Support classes related to steps when used with Spring Integration.
outputChannel(MessageChannel) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Set the output channel on which requests to workers will be sent.
outputChannel(MessageChannel) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the output channel on which replies will be sent to the master step.
outputChannel(MessageChannel) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Set the output channel on which requests to workers will be sent.
outputChannel(MessageChannel) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the output channel on which replies will be sent to the master step.

P

parseHandler(Element, ParserContext) - Method in class org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.batch.integration.config.xml.RemoteChunkingMasterParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.batch.integration.config.xml.RemoteChunkingSlaveParser
 
partitioner(String, Partitioner) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
partitioner(String, Partitioner) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
partitioner(Step) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
partitionHandler(PartitionHandler) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
This method will throw a UnsupportedOperationException since the partition handler of the master step will be automatically set to an instance of MessageChannelPartitionHandler.
pollInterval(long) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
How often to poll the job repository for the status of the workers.
preReceive(MessageChannel) - Method in class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Receive from the MessageSource and send immediately to the input channel, so that the call that we are intercepting always a message to receive.
preSend(Message<?>, MessageChannel) - Method in class org.springframework.batch.integration.async.StepExecutionInterceptor
 
process(I) - Method in class org.springframework.batch.integration.async.AsyncItemProcessor
Transform the input by delegating to the provided item processor.
processor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 

R

reader(ItemReader<? extends I>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
readerIsTransactionalQueue() - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
RemoteChunkHandlerFactoryBean<T> - Class in org.springframework.batch.integration.chunk
Convenient factory bean for a chunk handler that also converts an existing chunk-oriented step into a remote chunk master.
RemoteChunkHandlerFactoryBean() - Constructor for class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
 
RemoteChunkingMasterParser - Class in org.springframework.batch.integration.config.xml
Parser for the remote-chunking-master namespace element.
RemoteChunkingMasterParser() - Constructor for class org.springframework.batch.integration.config.xml.RemoteChunkingMasterParser
 
RemoteChunkingMasterStepBuilder<I,O> - Class in org.springframework.batch.integration.chunk
Builder for a master step in a remote chunking setup.
RemoteChunkingMasterStepBuilder(String) - Constructor for class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
RemoteChunkingMasterStepBuilderFactory - Class in org.springframework.batch.integration.chunk
Convenient factory for a RemoteChunkingMasterStepBuilder which sets the JobRepository and PlatformTransactionManager automatically.
RemoteChunkingMasterStepBuilderFactory(JobRepository, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilderFactory
remoteChunkingMasterStepBuilderFactory() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemoteChunkingSlaveParser - Class in org.springframework.batch.integration.config.xml
Parser for the remote-chunking-slave namespace element.
RemoteChunkingSlaveParser() - Constructor for class org.springframework.batch.integration.config.xml.RemoteChunkingSlaveParser
 
RemoteChunkingWorkerBuilder<I,O> - Class in org.springframework.batch.integration.chunk
Builder for a worker in a remote chunking setup.
RemoteChunkingWorkerBuilder() - Constructor for class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
 
remoteChunkingWorkerBuilder() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemotePartitioningMasterStepBuilder - Class in org.springframework.batch.integration.partition
Builder for a master step in a remote partitioning setup.
RemotePartitioningMasterStepBuilder(String) - Constructor for class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
remotePartitioningMasterStepBuilderFactory() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemotePartitioningMasterStepBuilderFactory - Class in org.springframework.batch.integration.partition
Convenient factory for a RemotePartitioningMasterStepBuilder which sets the JobRepository, JobExplorer, BeanFactory and PlatformTransactionManager automatically.
RemotePartitioningMasterStepBuilderFactory(JobRepository, JobExplorer, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilderFactory
RemotePartitioningWorkerStepBuilder - Class in org.springframework.batch.integration.partition
Builder for a worker step in a remote partitioning setup.
RemotePartitioningWorkerStepBuilder(String) - Constructor for class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Initialize a step builder for a step with the given name.
remotePartitioningWorkerStepBuilderFactory() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemotePartitioningWorkerStepBuilderFactory - Class in org.springframework.batch.integration.partition
Convenient factory for a RemotePartitioningWorkerStepBuilder which sets the JobRepository, JobExplorer, BeanFactory and PlatformTransactionManager automatically.
RemotePartitioningWorkerStepBuilderFactory(JobRepository, JobExplorer, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilderFactory
repository(JobRepository) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
repository(JobRepository) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
repository(JobRepository) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
retry(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
retryContextCache(RetryContextCache) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
retryLimit(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
retryPolicy(RetryPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 

S

setBeanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilderFactory
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilderFactory
 
setChannel(MessageChannel) - Method in class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Optional MessageChannel for injecting the message received from the source (defaults to the channel intercepted in MessageSourcePollerInterceptor.preReceive(MessageChannel)).
setChunkProcessor(ChunkProcessor<S>) - Method in class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
Public setter for the ChunkProcessor.
setChunkWriter(ItemWriter<T>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
The item writer to be injected into the step.
setDataSource(DataSource) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
DataSource pointing to the job repository
setDelegate(ItemProcessor<I, O>) - Method in class org.springframework.batch.integration.async.AsyncItemProcessor
The ItemProcessor to use to delegate processing to in a background thread.
setDelegate(ItemWriter<T>) - Method in class org.springframework.batch.integration.async.AsyncItemWriter
 
setDelegate(Step) - Method in class org.springframework.batch.integration.step.DelegateStep
 
setGridSize(int) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
Passed to the StepExecutionSplitter in the MessageChannelPartitionHandler.handle(StepExecutionSplitter, StepExecution) method, instructing it how many StepExecution instances are required, ideally.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
JobExplorer to use to query the job repository.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.integration.partition.StepExecutionRequestHandler
An explorer that should be used to check for StepExecution completion.
setMaxWaitTimeouts(int) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
The maximum number of times to wait at the end of a step for a non-null result from the remote workers.
setMessageSource(MessageSource<?>) - Method in class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
 
setMessagingOperations(MessagingTemplate) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
setMessagingOperations(MessagingTemplate) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
A pre-configured gateway for sending and receiving messages to the remote workers.
setPollInterval(long) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
How often to poll the job repository for the status of the slaves.
setReplyChannel(PollableChannel) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
setReplyChannel(PollableChannel) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
setStep(TaskletStep) - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
The local step that is to be converted to a remote chunk master.
setStepContributionSource(StepContributionSource) - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
A source of StepContribution instances coming back from remote workers.
setStepLocator(StepLocator) - Method in class org.springframework.batch.integration.partition.StepExecutionRequestHandler
Used to locate a Step to execute for each request.
setStepName(String) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
The name of the Step that will be used to execute the partitioned StepExecution.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.integration.async.AsyncItemProcessor
The TaskExecutor to use to allow the item processing to proceed in the background.
setThrottleLimit(long) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
Public setter for the throttle limit.
setTimeout(long) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
When using job repository polling, the time limit to wait.
skip(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
skipLimit(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
skipPolicy(SkipPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
splitter(StepExecutionSplitter) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
startLimit(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
startLimit(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
startLimit(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
step(Step) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
STEP_EXECUTION - Static variable in class org.springframework.batch.integration.async.StepExecutionInterceptor
The name of the header
StepContributionSource - Interface in org.springframework.batch.integration.chunk
A source of StepContribution instances that can be aggregated and used to update an ongoing StepExecution.
StepExecutionInterceptor - Class in org.springframework.batch.integration.async
A ChannelInterceptor that adds the current StepExecution (if there is one) as a header to the message.
StepExecutionInterceptor() - Constructor for class org.springframework.batch.integration.async.StepExecutionInterceptor
 
StepExecutionRequest - Class in org.springframework.batch.integration.partition
Class encapsulating information required to request a step execution in a remote partitioning setup.
StepExecutionRequest(String, Long, Long) - Constructor for class org.springframework.batch.integration.partition.StepExecutionRequest
Create a new StepExecutionRequest instance.
StepExecutionRequestHandler - Class in org.springframework.batch.integration.partition
A MessageEndpoint that can handle a StepExecutionRequest and return a StepExecution as the result.
StepExecutionRequestHandler() - Constructor for class org.springframework.batch.integration.partition.StepExecutionRequestHandler
 
stepLocator(StepLocator) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the step locator used to locate the worker step to execute.
stepOperations(RepeatOperations) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
stream(ItemStream) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 

T

tasklet(Tasklet) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
throttleLimit(long) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Public setter for the throttle limit.
timeout(long) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
When using job repository polling, the time limit to wait.
toString() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
 
toString() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
toString() - Method in class org.springframework.batch.integration.launch.JobLaunchRequest
 
toString() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
 
transactionAttribute(TransactionAttribute) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 

U

update(ExecutionContext) - Method in class org.springframework.batch.integration.async.AsyncItemWriter
 
update(ExecutionContext) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
updateStepContribution(StepContribution, StepContributionSource) - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
Update a StepContribution with all the data from a StepContributionSource.

W

write(List<? extends Future<T>>) - Method in class org.springframework.batch.integration.async.AsyncItemWriter
In the processing of the Futures passed, nulls are not passed to the delegate since they are considered filtered out by the AsyncItemProcessor's delegated ItemProcessor.
write(List<? extends T>) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
writer(ItemWriter<? super O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
This method will throw a UnsupportedOperationException since the item writer of the master step in a remote chunking setup will be automatically set to an instance of ChunkMessageChannelItemWriter.
A B C D E F G H I J K L M N O P R S T U W 
Skip navigation links