Skip navigation links
A B C D E G H I J L M 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
 
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

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
 
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
 

C

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
 
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.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

extract(ChunkResponse, boolean) - Method in class org.springframework.batch.integration.chunk.JmsRedeliveredExtractor
 

G

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.

H

handle(StepExecutionSplitter, StepExecution) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
Sends StepExecutionRequest objects to the request channel of the MessagingOperations, 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
 
isRedelivered() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
isSingleton() - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
Optimization for the bean facctory (always returns true).
isSuccessful() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 

J

JmsRedeliveredExtractor - Class in org.springframework.batch.integration.chunk
 
JmsRedeliveredExtractor() - Constructor for class org.springframework.batch.integration.chunk.JmsRedeliveredExtractor
 
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.

L

launch(JobLaunchRequest) - Method in class org.springframework.batch.integration.launch.JobLaunchingMessageHandler
 
launch(JobLaunchRequest) - Method in interface org.springframework.batch.integration.launch.JobLaunchRequestHandler
 

M

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
 

O

open(ExecutionContext) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
org.springframework.batch.integration.async - package org.springframework.batch.integration.async
 
org.springframework.batch.integration.chunk - package org.springframework.batch.integration.chunk
 
org.springframework.batch.integration.config.xml - package org.springframework.batch.integration.config.xml
 
org.springframework.batch.integration.launch - package org.springframework.batch.integration.launch
 
org.springframework.batch.integration.partition - package org.springframework.batch.integration.partition
 
org.springframework.batch.integration.step - package org.springframework.batch.integration.step
 

P

parseHandler(Element, ParserContext) - Method in class org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
 
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.

R

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
 

S

setBeanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
 
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.
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.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(MessagingOperations) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
setMessagingOperations(MessagingOperations) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
A pre-configured gateway for sending and receiving messages to the remote workers.
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.
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
 
StepExecutionRequest(String, Long, Long) - Constructor for class org.springframework.batch.integration.partition.StepExecutionRequest
 
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
 

T

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
 

U

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
 
write(List<? extends T>) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
A B C D E G H I J L M O P R S T U W 
Skip navigation links

Copyright © 2015. All rights reserved.