Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Org.springframework.xd.dirt Classes and Interfaces - 463 results found.
NameDescriptionTypePackageFramework
AbstractBatchJobsControllerAbstract controller that all the XD batch admin controllers extend.Classorg.springframework.xd.dirt.restSpring XD
AbstractBusPropertiesAccessorClassorg.springframework.xd.dirt.integration.busSpring XD
AbstractComponentScanningBeanDefinitionProviderClassorg.springframework.xd.dirt.container.initializerSpring XD
AbstractDeployerAbstract implementation of the @link ResourceDeployer interface.Classorg.springframework.xd.dirt.streamSpring XD
AbstractEventClassorg.springframework.xd.dirt.eventSpring XD
AbstractFromMessageConverterBase class for converters applied via Spring Integration 4.Classorg.springframework.xd.dirt.integration.bus.converterSpring XD
AbstractInstancePersistingDeployerBase support class for deployers that know how to deal with instances of aAuthor:Eric Bottard, Ilayaperumal GopinathanClassorg.springframework.xd.dirt.streamSpring XD
AbstractJobPluginAbstract class that extends AbstractMessageBusBinderPlugin and has common implementation methods related toAuthor:Ilayaperumal Gopinathan, Gary RussellClassorg.springframework.xd.dirt.pluginsSpring XD
AbstractMessageBusBinderPluginAbstract Plugin that has common implementation methods to bind/unbind Module's message producers andconsumers to/from MessageBus.Classorg.springframework.xd.dirt.pluginsSpring XD
AbstractModuleEventClassorg.springframework.xd.dirt.eventSpring XD
AbstractPluginAbstract Plugin that contains no-op and common implementing methods.Classorg.springframework.xd.dirt.pluginsSpring XD
AbstractResourceBeanDefinitionProviderA OrderedContextInitializer base class for loading XML or Groovy Bean Definitions into the target ContainerAuthor:David TuranskiClassorg.springframework.xd.dirt.container.initializerSpring XD
AbstractSingleNodeNamedChannelModuleBase class for SingleNodeNamedChannel resources used to bind a MessageChannel to a shared channel using aAuthor:David TuranskiClassorg.springframework.xd.dirt.testSpring XD
AbstractSingleNodeNamedChannelModuleFactoryBase class for factories used to create NamedChannelSource and NamedChannelSink.Classorg.springframework.xd.dirt.testSpring XD
AbstractSingleNodeNamedChannelSinkBase class for SingleNode named channel sink types.Classorg.springframework.xd.dirt.test.sinkSpring XD
AbstractSingleNodeNamedChannelSourceBase class for SingleNode named channel source types.Classorg.springframework.xd.dirt.test.sourceSpring XD
AbstractSingleNodeProcessingChainA helper class for building single node streams that use a NamedChannelSource and NamedChannelSink.Classorg.springframework.xd.dirt.test.processSpring XD
AbstractStreamPluginAbstract class that extends AbstractMessageBusBinderPlugin and has common implementation methods related toAuthor:Ilayaperumal Gopinathan, Mark Fisher, Gary RussellClassorg.springframework.xd.dirt.pluginsSpring XD
AddModuleOptionsExpansionStrategyAdds missing module options at the end of a well formed stream definition.Classorg.springframework.xd.dirt.stream.completionSpring XD
AdminDomain object for an XD admin runtime.Classorg.springframework.xd.dirt.clusterSpring XD
AdminAttributesRuntime metadata for a Admin server instance.Classorg.springframework.xd.dirt.clusterSpring XD
AdminControllerClassorg.springframework.xd.dirt.restSpring XD
AdminOptionsHolds configuration options that are valid for the Admin server, when using distributed mode.Classorg.springframework.xd.dirt.server.optionsSpring XD
AdminPortNotAvailableExceptionException thrown when the configured admin port is not available to use.Classorg.springframework.xd.dirt.server.adminSpring XD
AdminRepositoryRepository for persisting Admin entities for admins.Interfaceorg.springframework.xd.dirt.container.storeSpring XD
AdminServerApplicationClassorg.springframework.xd.dirt.server.adminSpring XD
AggregateCountersControllerExposes representations of AggregateCounts.Classorg.springframework.xd.dirt.rest.metricsSpring XD
AggregatorProcessorModuleOptionsMetadataDescribes options to the aggregator processor module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
AggregatorProcessorModuleOptionsMetadata .StoreKindClassorg.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadataSpring XD
AlreadyDeployedExceptionThrown when an attempt is made to deploy a definition that is already deployed.Classorg.springframework.xd.dirt.streamSpring XD
ApplicationUtilsClassorg.springframework.xd.dirt.serverSpring XD
ArgumentNodeRepresents an argument like "--name=value".Classorg.springframework.xd.dirt.job.dslSpring XD
ArgumentNodeRepresents an argument like "--name=value".Classorg.springframework.xd.dirt.stream.dslSpring XD
AstNodeAST base class for AST nodes in a parsed Job specification.Classorg.springframework.xd.dirt.job.dslSpring XD
AstNodeCommon supertype for the ast nodes built during stream parsing.Classorg.springframework.xd.dirt.stream.dslSpring XD
AuthenticationRequestClassorg.springframework.xd.dirt.web.controller.supportSpring XD
BannerUtilsProvides utilities for rendering graphical console output.Classorg.springframework.xd.dirt.utilSpring XD
BaseDefinitionRepresents the base model for a data flow in the system.Classorg.springframework.xd.dirt.coreSpring XD
BaseInstanceA runtime representation of a Definition.Classorg.springframework.xd.dirt.streamSpring XD
BatchJobAlreadyExistsExceptionException thrown when the batch job with the given name already exists.Classorg.springframework.xd.dirt.jobSpring XD
BatchJobAlreadyExistsInRegistryExceptionException thrown when a batch job already exists in the JobRegistry.Classorg.springframework.xd.dirt.plugins.jobSpring XD
BatchJobExecutionsControllerController for batch job executions.Classorg.springframework.xd.dirt.restSpring XD
BatchJobHeadersHeaders definitions used by the batch job plugin.Classorg.springframework.xd.dirt.plugins.jobSpring XD
BatchJobInstancesControllerController for batch job instances.Classorg.springframework.xd.dirt.restSpring XD
BatchJobListenerAbstract batch job listener that sends batch job listener payload to the SubscribableChannel notificationAuthor:Ilayaperumal GopinathanClassorg.springframework.xd.dirt.plugins.job.support.listenerSpring XD
BatchJobRegistryBeanPostProcessorJobRegistryBeanPostProcessor that processes batch job from the job module.Classorg.springframework.xd.dirt.plugins.jobSpring XD
BatchJobsControllerController for batch jobs and job instances, job executions on a given batch job.Classorg.springframework.xd.dirt.restSpring XD
BatchListenerEventTypeenum BatchListenerEventTypeEnumerations to help identify various Batch job events being issued.Classorg.springframework.xd.dirt.plugins.job.support.listenerSpring XD
BatchStepExecutionsControllerController for returning Batch StepExecutions.Classorg.springframework.xd.dirt.restSpring XD
BeanPropertiesPropertySourceA PropertySource that exposes the javabeans properties of an object as properties.Classorg.springframework.xd.dirt.server.optionsSpring XD
BindingRepresents a binding between a module's channel and an adapter endpoint that connects to the MessageBus.Classorg.springframework.xd.dirt.integration.busSpring XD
BusCleanerInterface for implementations that perform cleanup for message buses.Interfaceorg.springframework.xd.dirt.integration.busSpring XD
BusPropertiesCommon bus properties.Interfaceorg.springframework.xd.dirt.integration.busSpring XD
BusTestUtilsClassorg.springframework.xd.dirt.integration.busSpring XD
BusUtilsMessage Bus utilities.Classorg.springframework.xd.dirt.integration.busSpring XD
ByteArrayToStringMessageConverterto convert from byte[] to String applying the Charset provided inthe content-type header if any.Classorg.springframework.xd.dirt.integration.bus.converterSpring XD
ChannelNodeClassorg.springframework.xd.dirt.stream.dslSpring XD
ChannelTypeClassorg.springframework.xd.dirt.stream.dslSpring XD
CheckpointedJobDefinitionExceptionAn extension of JobSpecificationException that remembers the point up to which parsing went OK (signaled by a '*' inthe dumped message).Classorg.springframework.xd.dirt.job.dslSpring XD
CheckpointedStreamDefinitionExceptionAn extension of StreamDefinitionException that remembers the point up to which parsing went OK (signaled by a '*' inthe dumped message).Classorg.springframework.xd.dirt.stream.dslSpring XD
ChildPathIteratorIterator over ChildData instances that are managed by PathChildrenCache.Classorg.springframework.xd.dirt.zookeeperSpring XD
ChunkContextInfoClassorg.springframework.xd.dirt.plugins.job.support.listenerSpring XD
CommandLinePropertySourceOverridingListenerAn ApplicationListener that will parse command line options and also replace the default boot commandlinePropertySource with those values.Classorg.springframework.xd.dirt.server.optionsSpring XD
CommonDistributedOptionsHolds options that are common to both admin and container servers, when used in distributed mode.Classorg.springframework.xd.dirt.server.optionsSpring XD
CommonOptionsBase class for command line options that are common to absolutely every setup (single and distributed).Classorg.springframework.xd.dirt.server.optionsSpring XD
CompletionExpansionStrategyUsed to enhance a well formed stream definition by adding yet more text to it (e.Interfaceorg.springframework.xd.dirt.stream.completionSpring XD
CompletionProviderProvides code completion on a (maybe ill-formed) stream definition.Classorg.springframework.xd.dirt.stream.completionSpring XD
CompletionRecoveryStrategyUsed to provide completions on ill-formed stream definitions, after an initial (failed) parse.Interfaceorg.springframework.xd.dirt.stream.completionSpring XD
CompletionsControllerExposes completion for stream-like definitions as a REST endpoint.Classorg.springframework.xd.dirt.restSpring XD
ComposedJobUtilClassorg.springframework.xd.dirt.job.dslSpring XD
CompositeMessageConverterFactoryA factory for creating an instance of CompositeMessageConverter for a given target MIME typeAuthor:David TuranskiClassorg.springframework.xd.dirt.integration.bus.converterSpring XD
ConfigLocationsStatic constants for configuration locations.Classorg.springframework.xd.dirt.utilSpring XD
ConnectionFactorySettingsConfigures the connection factory used by the rabbit message bus.Classorg.springframework.xd.dirt.integration.rabbitSpring XD
ConnectionFactorySettings .RabbitPropertiesLoaderClassorg.springframework.xd.dirt.integration.rabbit.ConnectionFactorySettingsSpring XD
ContainerDomain object for an XD container.Classorg.springframework.xd.dirt.clusterSpring XD
ContainerAttributesMetadata for a Container instance.Classorg.springframework.xd.dirt.clusterSpring XD
ContainerBootstrapContextPackage private class to bootstrap the Container process.Classorg.springframework.xd.dirt.server.containerSpring XD
ContainerConfigurationContainer Application ContextAuthor:David Turanski, Ilayaperumal Gopinathan, Marius BogoeviciClassorg.springframework.xd.dirt.server.containerSpring XD
ContainerFilterA filter interface that applies filter for the given containers and returnseligible containers for deployment.Interfaceorg.springframework.xd.dirt.clusterSpring XD
ContainerInfoPluginA plugin that exposes information about the container to the Environment.Classorg.springframework.xd.dirt.pluginsSpring XD
ContainerListenerListener implementation that is invoked when containers are added/removed/modified.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
ContainerMatcherModuleDescriptor to.Classorg.springframework.xd.dirt.server.admin.deploymentSpring XD
ContainerMatchingModuleRedeployerThe ModuleRedeployer that deploys the unallocated stream/job modules.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
ContainerOptionsHolds configuration options that are valid for the Container node, when using distributed mode.Classorg.springframework.xd.dirt.server.optionsSpring XD
ContainerRegistrarAn instance of this class, registered as a bean in the context for a Container, will handle the registration of thatContainer's metadata with ZooKeeper by creating an ephemeral node.Classorg.springframework.xd.dirt.server.containerSpring XD
ContainerRepositoryRepository for persisting Container entities.Interfaceorg.springframework.xd.dirt.container.storeSpring XD
ContainersControllerHandles interaction with the runtime containers/and its modules.Classorg.springframework.xd.dirt.restSpring XD
ContainerServerApplicationThe boot application class for a Container server.Classorg.springframework.xd.dirt.server.containerSpring XD
ContainerShutdownExceptionException thrown when shutting down the containerAuthor:Ilayaperumal GopinathanSee Also:Serialized FormClassorg.springframework.xd.dirt.clusterSpring XD
ConversionExceptionException thrown when an error is encountered during message conversion.Classorg.springframework.xd.dirt.integration.bus.converterSpring XD
CountersControllerExposes representations of Counters.Classorg.springframework.xd.dirt.rest.metricsSpring XD
CustomLoggerConverterClassorg.springframework.xd.dirt.util.loggingSpring XD
CustomMimeTypeConverterA custom converter for MediaType that accepts a plain java class name as a shorthand forapplication/x-java-object;type=the.Classorg.springframework.xd.dirt.plugins.streamSpring XD
CustomModuleRegistryFactoryBeanWill create a SynchronizingModuleRegistry for hosting custom modules if necessary, depending on theprotocol scheme (using a synchronizing registry for everything but file:// protocol).Classorg.springframework.xd.dirt.moduleSpring XD
DatabaseVendorFriendlyNameFactoryBeanA factory bean that returns a friendly string name from database metadata.Classorg.springframework.xd.dirt.jdbc.utilSpring XD
DeepAggregateCountResourceAssemblerKnows how to construct AggregateCountsResource out of AggregateCount.Classorg.springframework.xd.dirt.rest.metricsSpring XD
DeepCounterResourceAssemblerKnows how to assemble CounterResources out of Counters.Classorg.springframework.xd.dirt.rest.metricsSpring XD
DeepFieldValueCounterResourceAssemblerKnows how to create rich representations of FieldValueCounter.Classorg.springframework.xd.dirt.rest.metricsSpring XD
DefaultDeploymentStateRecalculatorStream/Job deployment state re-calculator upon leadership election.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
DefaultDeploymentUnitStateCalculatorDefault DeploymentUnitStateCalculatorIf all expected modules are deployed, the state is consideredClassorg.springframework.xd.dirt.server.admin.deploymentSpring XD
DefaultModuleDeploymentPropertiesProviderDefault implementation that retrieves the ModuleDeploymentProperties for the givenAuthor:Ilayaperumal GopinathanClassorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
DefinitionAlreadyExistsExceptionException which is raised when a resource definition with the same name already exists.Classorg.springframework.xd.dirt.streamSpring XD
DelegatingModuleRegistryA ModuleRegistry that delegates to several ModuleRegistries, in order.Classorg.springframework.xd.dirt.moduleSpring XD
DepartedContainerModuleRedeployerThe ModuleRedeployer that re-deploys the stream/job modules that weredeployed into the departing container.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
DependencyExceptionThrown when performing an action cannot be carried over because some dependency would be broken.Classorg.springframework.xd.dirt.moduleSpring XD
DeploymentActionenum DeploymentActionEnum class for the supported deployment actions.Classorg.springframework.xd.dirt.server.admin.deploymentSpring XD
DeploymentConfigurationConfiguration class that holds the beans required for deployment management.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
DeploymentExceptionException thrown when DeploymentHandler encounters problemwhen deploying/un-deploying stream/job.Classorg.springframework.xd.dirt.server.admin.deploymentSpring XD
DeploymentHandlerDeployment handler that is responsible for deploying/un-deploying theDeploymentUnit (Stream/Job) to/from the container.Interfaceorg.springframework.xd.dirt.server.admin.deploymentSpring XD
DeploymentLoaderUtility for loading streams and jobs for the purpose of deployment.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
DeploymentMessageThe message that wraps the details of a deployment request.Classorg.springframework.xd.dirt.server.admin.deploymentSpring XD
DeploymentMessageConsumerConsumer for DeploymentMessagewhich delegates to the corresponding @ResourceDeployerClassorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
DeploymentMessagePublisherPublisher that defines the contract to publish the DeploymentMessage.Interfaceorg.springframework.xd.dirt.server.admin.deploymentSpring XD
DeploymentPropertiesUtilityClass that provides utility methods to handle module deployment properties.Classorg.springframework.xd.dirt.utilSpring XD
DeploymentQueueThis class controls the lifecycle operations of the ZK distributed queue thatholds the DeploymentMessages.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
DeploymentStatusRepositoryInterface definition for repositories that support the reportingof deployment unit state.Interfaceorg.springframework.xd.dirt.coreSpring XD
DeploymentSupervisorProcess that watches ZooKeeper for Container arrivals and departures fromthe XD cluster.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
DeploymentUnitDeploymentUnit is a collection of modules that are intended to bedeployed as a single unit.Interfaceorg.springframework.xd.dirt.coreSpring XD
DeploymentUnitStateCalculatorCalculates the overall status for a deployment unit (stream or job).Interfaceorg.springframework.xd.dirt.server.admin.deploymentSpring XD
DeploymentUnitStatusStatus for a DeploymentUnit.Classorg.springframework.xd.dirt.coreSpring XD
DeploymentUnitStatus .StateDeployment unit states.Classorg.springframework.xd.dirt.core.DeploymentUnitStatusSpring XD
DeploymentUnitTypeenum DeploymentUnitTypeEnum class that defines the deployment unit type.Classorg.springframework.xd.dirt.server.admin.deploymentSpring XD
DeploymentValidatorThis interface defines validation methods that verify a stream or jobcan be saved, deployed, undeployed, or deleted.Interfaceorg.springframework.xd.dirt.streamSpring XD
DetailedContainerDomain object for an XD container with detailed info (deployed modules, messageRates etc.Classorg.springframework.xd.dirt.container.storeSpring XD
DetailedJobInfoA job info for batch jobs that provides more details than the base JobInfoAuthor:Andrew Eisenberg, Ilayaperumal GopinathanClassorg.springframework.xd.dirt.jobSpring XD
DetailedJobInfoResourceAssemblerKnows how to build a REST resource out of our domain model DetailedJobInfo.Classorg.springframework.xd.dirt.restSpring XD
DetailedModuleDefinitionResourceAssemblerKnows how to build DetailedModuleDefinitionResource out of a ModuleDefinition.Classorg.springframework.xd.dirt.restSpring XD
DirtExceptionRoot of the hierarchy of exceptions for DIRT (Distributed Integration RunTime).Classorg.springframework.xd.dirtSpring XD
DistributedJobLocatorto work with batch jobs in a distributed environment.Classorg.springframework.xd.dirt.plugins.jobSpring XD
DistributedJobServiceSimpleJobService in distributed modeAuthor:Ilayaperumal Gopinathan, Andrew Eisenberg, Gunnar HillertClassorg.springframework.xd.dirt.plugins.jobSpring XD
DocumentParseResultRepresents the result of parsing a multiline document, made of several definitions.Classorg.springframework.xd.dirt.streamSpring XD
DocumentParseResult .LineThe parse result of an individual line.Classorg.springframework.xd.dirt.stream.DocumentParseResultSpring XD
DocumentParseResultResourceAssemblerThis class is responsible for creating a REST representation of a DocumentParseResult.Classorg.springframework.xd.dirt.restSpring XD
EmbeddedHeadersMessageConverterEncodes requested headers into payload with format0xff, n(1), [ [lenHdr(1), hdr, lenValue(4), value] .Classorg.springframework.xd.dirt.integration.busSpring XD
EmbeddedZooKeeperHelper class to start an embedded instance of standalone (non clustered) ZooKeeper.Classorg.springframework.xd.dirt.zookeeperSpring XD
EmptyStartYieldsModulesRecoveryStrategyClassorg.springframework.xd.dirt.stream.completionSpring XD
ExecutionContextJacksonMixInJackson MixIn for the JSON serialization of the ExecutionContext class, which is used by theStepExecution class.Classorg.springframework.xd.dirt.plugins.job.supportSpring XD
ExpandedJobParametersConverterMore flexible implementation of the JobParametersConverter.Classorg.springframework.xd.dirt.plugins.jobSpring XD
ExpandOneDashToTwoDashesRecoveryStrategyProvides completion when the user has typed in the first dash to a module option.Classorg.springframework.xd.dirt.stream.completionSpring XD
ExtendedResourceA wrapper around a Resource that adds capabilities lacking in the original interface.Classorg.springframework.xd.dirt.moduleSpring XD
ExtendedResource .FileSystemExtendedResourceClassorg.springframework.xd.dirt.module.ExtendedResourceSpring XD
ExtendedResource .HdfsExtendedResourceClassorg.springframework.xd.dirt.module.ExtendedResourceSpring XD
FieldValueCountersControllerController that exposes FieldValueCounter related representations.Classorg.springframework.xd.dirt.rest.metricsSpring XD
FileAsRefMixinA mixin that can be used every time a module dealing with Files offersthe choice to pass along the File itself or its contents.Classorg.springframework.xd.dirt.modules.metadataSpring XD
FileAuthenticationConfigurationA security configuration that conditionally sets up in-memory users from a file.Classorg.springframework.xd.dirt.server.securitySpring XD
FileDeletionStepExecutionListenerStep listener which can be used to delete files once they have been successfully processed by XD.Classorg.springframework.xd.dirt.plugins.job.support.listenerSpring XD
FilePollHdfsJobOptionsMetadataDescribes the options for the filepollhdfs job.Classorg.springframework.xd.dirt.modules.metadataSpring XD
FileReadingModeenum FileReadingModeDefines the supported modes of reading and processing files for theClassorg.springframework.xd.dirt.modules.metadataSpring XD
FileSinkOptionsMetadataHolds options to the 'file' sink module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
FileSinkOptionsMetadata .ModeClassorg.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadataSpring XD
FileSourceOptionsMetadataHolds module options metadata about the file source.Classorg.springframework.xd.dirt.modules.metadataSpring XD
FlowThe AST node representing a flow.Classorg.springframework.xd.dirt.job.dslSpring XD
FtpHdfsJobOptionsMetadataDescribes the options for the ftphdfs job.Classorg.springframework.xd.dirt.modules.metadataSpring XD
FtpSinkOptionsMetadataModule options for the FTP sink module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
FtpSourceOptionsMetadataModule options for FTP source module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
GaugesControllerExposes representations of Gauges.Classorg.springframework.xd.dirt.rest.metricsSpring XD
GraphRepresents a Graph that Flo will display.Classorg.springframework.xd.dirt.job.dslSpring XD
HdfsMongodbJobOptionsMetadataOptions for Hdfs to Mongodb export job module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
HttpSourceOptionsMetadataDescribes options to the http source module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
IntegerEncoderDecoderA Kafka encoder / decoder used to serialize a single int, used as the kafka partition key.Classorg.springframework.xd.dirt.integration.kafkaSpring XD
JavaToSerializedMessageConverterto convert from a POJO to byte[] with Java.Classorg.springframework.xd.dirt.integration.bus.converterSpring XD
JmsSourceModuleOptionsMetadataCaptures options for the jms source module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
JobDomain model for Job runtime module.Classorg.springframework.xd.dirt.coreSpring XD
JobCaptures runtime information about a deployed JobDefinition.Classorg.springframework.xd.dirt.streamSpring XD
Job .BuilderBuilder object for Job that supports fluent style configuration.Classorg.springframework.xd.dirt.core.JobSpring XD
JobDefinitionRepresents an inlined job definition in a job specification.Classorg.springframework.xd.dirt.job.dslSpring XD
JobDefinitionRepresents a job in the system.Classorg.springframework.xd.dirt.streamSpring XD
JobDefinitionRepositoryA repository for persisting JobDefinitions.Interfaceorg.springframework.xd.dirt.streamSpring XD
JobDefinitionResourceAssemblerKnows how to build a REST resource out of our domain model JobDefinition.Classorg.springframework.xd.dirt.restSpring XD
JobDeployerClassorg.springframework.xd.dirt.streamSpring XD
JobDeploymentsPathBuilder object for paths under Paths.Classorg.springframework.xd.dirt.coreSpring XD
JobDescriptorCommon AST base class for nodes representing job definitions or job references.Classorg.springframework.xd.dirt.job.dslSpring XD
JobDSLMessageContains all the messages that can be produced during Spring XD Job DSL parsing.Classorg.springframework.xd.dirt.job.dslSpring XD
JobDSLMessage .KindClassorg.springframework.xd.dirt.job.dsl.JobDSLMessageSpring XD
JobEventsListenerPluginPlugin to enable the registration of out of the box job listeners.Classorg.springframework.xd.dirt.plugins.jobSpring XD
JobExceptionRoot of the hierarchy of exceptions for Job processing in DIRT.Classorg.springframework.xd.dirt.jobSpring XD
JobExecutionAlreadyRunningExceptionException that is raised when JobExecutionAuthor:Gunnar HillertSee Also:Serialized FormClassorg.springframework.xd.dirt.jobSpring XD
JobExecutionInfoRepresents Batch job execution info.Classorg.springframework.xd.dirt.jobSpring XD
JobExecutionInfoResourceAssemblerKnows how to build a REST resource out of our domain model JobExecutionInfo.Classorg.springframework.xd.dirt.restSpring XD
JobExecutionNotRunningExceptionException for the job execution that is not running.Classorg.springframework.xd.dirt.jobSpring XD
JobFactoryFactory class that builds Job instances.Classorg.springframework.xd.dirt.jobSpring XD
JobInfoRepresents Batch job info.Classorg.springframework.xd.dirt.jobSpring XD
JobInfoResourceAssemblerKnows how to build a REST resource out of our domain model JobInfo.Classorg.springframework.xd.dirt.restSpring XD
JobInstanceAlreadyCompleteExceptionException thrown when the JobInstance is already complete.Classorg.springframework.xd.dirt.jobSpring XD
JobInstanceInfoRepresents Batch job instance info.Classorg.springframework.xd.dirt.jobSpring XD
JobInstanceInfoResourceAssemblerResource assembler that builds the REST resource JobInstanceInfoResource out of domain modelAuthor:Ilayaperumal GopinathanClassorg.springframework.xd.dirt.restSpring XD
JobLaunchingJobRepositoryThis JobRepository implementationprovides the same functionality as Spring Batch'sClassorg.springframework.xd.dirt.plugins.job.supportSpring XD
JobLaunchingJobRepositoryFactoryBeanA FactoryBean for creating an instance ofJobLaunchingJobRepositoryClassorg.springframework.xd.dirt.plugins.job.supportSpring XD
JobLaunchingTaskletA Tasklet implementation that uses the Spring XD MessageBus to launchjobs deployed within the same Spring XD cluster.Classorg.springframework.xd.dirt.batch.taskletSpring XD
JobLaunchRequestTransformerExecutes all jobs defined within a given stream once the context has been started.Classorg.springframework.xd.dirt.plugins.jobSpring XD
JobNodeAST node base type for all elements in an AST parsed from a job specification.Classorg.springframework.xd.dirt.job.dslSpring XD
JobParametersBeanPrepares the JobParameters for the Spring Bach Jobs.Classorg.springframework.xd.dirt.plugins.jobSpring XD
JobParametersInvalidExceptionException thrown when the job parameters are invalid.Classorg.springframework.xd.dirt.jobSpring XD
JobParserParse a Batch DSL Job specification.Classorg.springframework.xd.dirt.job.dslSpring XD
JobPartitionerPluginPlugin to enable job partitioning.Classorg.springframework.xd.dirt.plugins.jobSpring XD
JobPluginPlugin to enable the registration of jobs in a central registry.Classorg.springframework.xd.dirt.plugins.jobSpring XD
JobPluginMetadataResolverA ModuleOptionsMetadataResolver that will dynamically add the module options (such as makeUnique)supported by job modules.Classorg.springframework.xd.dirt.plugins.jobSpring XD
JobPluginMetadataResolver .JobOptionsMetadataClassorg.springframework.xd.dirt.plugins.job.JobPluginMetadataResolverSpring XD
JobReferenceRepresents a simple job reference.Classorg.springframework.xd.dirt.job.dslSpring XD
JobRepositoryA repository for persisting Job instances.Interfaceorg.springframework.xd.dirt.streamSpring XD
JobRestartExceptionException thrown where the batch job is not restartable.Classorg.springframework.xd.dirt.jobSpring XD
JobsControllerHandles all Job related interactions.Classorg.springframework.xd.dirt.restSpring XD
JobSeriesCommon AST base class for nodes representing splits or flows.Classorg.springframework.xd.dirt.job.dslSpring XD
JobSpecificationThe root AST node for any AST parsed from a job specification.Classorg.springframework.xd.dirt.job.dslSpring XD
JobSpecificationExceptionRoot exception for Job Flow DSL parsing related exceptions.Classorg.springframework.xd.dirt.job.dslSpring XD
JobSpecificationVisitorvery basic visitor pattern for a JobSpecVisitor.Classorg.springframework.xd.dirt.job.dslSpring XD
JsonToPojoMessageConverterClassorg.springframework.xd.dirt.integration.bus.converterSpring XD
JsonToTupleMessageConverterto convert from a JSON (byte[] or String) to a Tuple.Classorg.springframework.xd.dirt.integration.bus.converterSpring XD
KafkaMessageBusA message bus that uses Kafka as the underlying middleware.Classorg.springframework.xd.dirt.integration.kafkaSpring XD
KafkaMessageBus .ModeClassorg.springframework.xd.dirt.integration.kafka.KafkaMessageBusSpring XD
KafkaMessageBus .OffsetManagementClassorg.springframework.xd.dirt.integration.kafka.KafkaMessageBusSpring XD
LabelNodeRepresents a label attached to a module.Classorg.springframework.xd.dirt.stream.dslSpring XD
LdapAuthenticationConfigurationClassorg.springframework.xd.dirt.server.securitySpring XD
LinkRepresents a link in a Graph object that Flo will display as a block.Classorg.springframework.xd.dirt.job.dslSpring XD
LocalizedQueueConnectionFactoryA RoutingConnectionFactory that determines the node on which a queue is located andreturns a factory that connects directly to that node.Classorg.springframework.xd.dirt.integration.rabbitSpring XD
LocalMessageBusA simple implementation of MessageBus for in-process use.Classorg.springframework.xd.dirt.integration.bus.localSpring XD
LoggerAbbreviatorClassorg.springframework.xd.dirt.util.loggingSpring XD
LoginControllerController responsible for handling web-logins as well as basic redirects forAuthor:Gunnar HillertClassorg.springframework.xd.dirt.web.controllerSpring XD
LogSinkOptionsMetadataCaptures options for the log sink module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
MBeanExportingPluginExports MBeans from a module using a unique domain name xd.Classorg.springframework.xd.dirt.pluginsSpring XD
MD5StalenessCheckA StalenessCheck that expects to find a .Classorg.springframework.xd.dirt.moduleSpring XD
MessageBusA strategy interface used to bind a MessageChannel to a logical name.Interfaceorg.springframework.xd.dirt.integration.busSpring XD
MessageBus .CapabilityWhen a bus supports durable subscriptions to a pub/sub channel, the streamname will be included in the consumer name.Classorg.springframework.xd.dirt.integration.bus.MessageBusSpring XD
MessageBusAwareChannelResolverA DestinationResolver implementation that first checks for any channelwhose name begins with a colon in the MessageBus.Classorg.springframework.xd.dirt.integration.busSpring XD
MessageBusAwareRouterBeanPostProcessorA BeanPostProcessor that sets a MessageBusAwareChannelResolver on any bean of typeAbstractMappingMessageRouter within the context.Classorg.springframework.xd.dirt.integration.busSpring XD
MessageBusClassLoaderFactoryAn ApplicationListener which tracks which MessageBus implementation ought to be used so that it exposes a ClassLoaderthat knows about the correct jar files for that bus.Classorg.springframework.xd.dirt.serverSpring XD
MessageBusExceptionException thrown to indicate a message bus error (mostlikely a configuration error).Classorg.springframework.xd.dirt.integration.busSpring XD
MessageBusExtensionsConfigurationConfiguration class for Codec and possibly other MessageBus extensionsSince:1.Classorg.springframework.xd.dirt.serverSpring XD
MessageBusSupportClassorg.springframework.xd.dirt.integration.busSpring XD
MessageBusSupport .DirectHandlerClassorg.springframework.xd.dirt.integration.bus.MessageBusSupportSpring XD
MessageBusSupport .PartitioningMetadataClassorg.springframework.xd.dirt.integration.bus.MessageBusSupportSpring XD
MessageBusSupport .SetBuilderClassorg.springframework.xd.dirt.integration.bus.MessageBusSupportSpring XD
MessageConverterUtilsMessage conversion utility methods.Classorg.springframework.xd.dirt.integration.bus.converterSpring XD
MessageValuesA mutable type for allowing MessageBus implementations to transform and enrich message content moreAuthor:David TuranskiClassorg.springframework.xd.dirt.integration.busSpring XD
ModuleAlreadyExistsExceptionThrown when trying to create a new module with the given name and type, but one already exists.Classorg.springframework.xd.dirt.moduleSpring XD
ModuleConfigurationExceptionThrown when something is wrong with options passed to a module.Classorg.springframework.xd.dirt.pluginsSpring XD
ModuleDefinitionRepositoryUtilsClassorg.springframework.xd.dirt.module.supportSpring XD
ModuleDefinitionResourceAssemblerKnows how to build a REST resource out of our domain model ModuleDefinition.Classorg.springframework.xd.dirt.restSpring XD
ModuleDefinitionServiceA service that knows how to handle registration of new module definitions, be it through composition orupload of actual 'bytecode'.Classorg.springframework.xd.dirt.module.supportSpring XD
ModuleDependencyRepositoryUsed to track usage of modules from streams and composed modules.Interfaceorg.springframework.xd.dirt.moduleSpring XD
ModuleDeployedEventClassorg.springframework.xd.dirt.eventSpring XD
ModuleDeployerHandles the creation, deployment, and un-deployment of modules.Classorg.springframework.xd.dirt.moduleSpring XD
ModuleDeploymentPropertiesProviderCallback interface to obtain ModuleDeploymentPropertiesfor a ModuleDescriptor.Interfaceorg.springframework.xd.dirt.server.admin.deploymentSpring XD
ModuleDeploymentRequestsPathBuilder object for paths under Paths.Classorg.springframework.xd.dirt.coreSpring XD
ModuleDeploymentsPathBuilder object for paths under Paths.Classorg.springframework.xd.dirt.coreSpring XD
ModuleDeploymentStatusStatus of a module deployment for a container.Classorg.springframework.xd.dirt.server.admin.deploymentSpring XD
ModuleDeploymentStatus .StateModule deployment states.Classorg.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatusSpring XD
ModuleDeploymentWriterUtility class to write module deployment requests under /xd/deployments/modules.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
ModuleExceptionRoot of the hierarchy of exceptions for Module processing in DIRT.Classorg.springframework.xd.dirt.moduleSpring XD
ModuleInfoPluginA plugin that exposes information such as the module name, index, sequence or count to be available inside theAuthor:Eric Bottard, Marius Bogoevici, Ilayaperumal GopinathanClassorg.springframework.xd.dirt.pluginsSpring XD
ModuleJobLauncherExecutes all jobs defined within a given stream once the context has been started.Classorg.springframework.xd.dirt.plugins.jobSpring XD
ModuleMessageRateNotFoundExceptionException thrown when getting message rate forAuthor:Ilayaperumal GopinathanSee Also:Serialized FormClassorg.springframework.xd.dirt.clusterSpring XD
ModuleMetadataMetadata class for modules at runtime.Classorg.springframework.xd.dirt.module.storeSpring XD
ModuleMetadata .IdIdentity object for instances of ModuleMetadata.Classorg.springframework.xd.dirt.module.store.ModuleMetadataSpring XD
ModuleMetadataRepositoryRepository for persisting ModuleMetadataAuthor:Ilayaperumal GopinathanInterfaceorg.springframework.xd.dirt.module.storeSpring XD
ModuleMetadataResourceAssemblerKnows how to assemble ModuleMetadataResources out of ModuleMetadatas.Classorg.springframework.xd.dirt.restSpring XD
ModuleNodeClassorg.springframework.xd.dirt.stream.dslSpring XD
ModuleNotDeployedExceptionException thrown when a module doesn't exist in the container.Classorg.springframework.xd.dirt.moduleSpring XD
ModuleObjectNamingStrategyObject naming strategy for XD module.Classorg.springframework.xd.dirt.module.jmxSpring XD
ModuleRedeployerAbstract ModuleRedeployer that deploy/re-deploys the unallocated/orphaned modules.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
ModuleRedeployer .ModuleDeploymentHolds information about a module that needs to be re-deployed.Classorg.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployerSpring XD
ModuleRegistryA module registry is used to lookup modules by name and/or type.Interfaceorg.springframework.xd.dirt.moduleSpring XD
ModulesAfterPipeRecoveryStrategyProvides completions for the case where the user has entered a pipe symbol and a module reference is expected next.Classorg.springframework.xd.dirt.stream.completionSpring XD
ModulesControllerHandles all Module related interactions.Classorg.springframework.xd.dirt.restSpring XD
ModulesMetadataControllerController that handles the interaction with the deployed modules.Classorg.springframework.xd.dirt.restSpring XD
ModuleTypeConversionPluginA Plugin for processing module message conversion parameters (inputType and outputType).Classorg.springframework.xd.dirt.plugins.streamSpring XD
ModuleTypeConversionPluginMetadataResolverA ModuleOptionsMetadataResolver that will dynamically add inputType and outputType options toevery module, according to their type.Classorg.springframework.xd.dirt.plugins.streamSpring XD
ModuleTypeConversionSupportSupport class that configures the message converters for the module input/output channel.Classorg.springframework.xd.dirt.plugins.streamSpring XD
ModuleUndeployedEventClassorg.springframework.xd.dirt.eventSpring XD
MqttConnectionMixinFactors out common options about configuring a connection to an MQTT broker.Classorg.springframework.xd.dirt.modules.metadataSpring XD
MqttSinkOptionsMetadataDescribes options to the mqtt sink module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
MqttSourceOptionsMetadataDescribes options to the mqtt source module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
NamedChannelSinkA Sink bound to a named channel.Interfaceorg.springframework.xd.dirt.test.sinkSpring XD
NamedChannelSourceA Source that binds to a named channel.Interfaceorg.springframework.xd.dirt.test.sourceSpring XD
NewJsonPathUtilsSimilar to org.Classorg.springframework.xd.dirt.integration.jsonSpring XD
NoContainerExceptionException thrown when there are no containers availablefor module deployment.Classorg.springframework.xd.dirt.clusterSpring XD
NodeRepresents a node in a Graph object that Flo will display as a block.Classorg.springframework.xd.dirt.job.dslSpring XD
NoSuchBatchJobExceptionException thrown when there is no such batch job with the given name.Classorg.springframework.xd.dirt.jobSpring XD
NoSuchBatchJobInstanceExceptionException thrown when there is no such batch job instance with the given instanceId.Classorg.springframework.xd.dirt.jobSpring XD
NoSuchContainerExceptionException thrown when the container in search could not be found.Classorg.springframework.xd.dirt.clusterSpring XD
NoSuchDefinitionExceptionException which is raised when a named resource definition cannot be found.Classorg.springframework.xd.dirt.streamSpring XD
NoSuchJobExecutionExceptionThrown when attempting to refer to JobExecution that does not exist.Classorg.springframework.xd.dirt.jobSpring XD
NoSuchMetricExceptionThrown when trying to access a named metric that does not exist.Classorg.springframework.xd.dirt.analyticsSpring XD
NoSuchModuleExceptionThrown when attempting to refer to a module that does not exist.Classorg.springframework.xd.dirt.moduleSpring XD
NoSuchStepExecutionExceptionThrown when attempting to refer to StepExecution that does not exist.Classorg.springframework.xd.dirt.jobSpring XD
NotDeployedExceptionThrown when a definition was assumed to be deployed when it actually was not.Classorg.springframework.xd.dirt.streamSpring XD
NothingToDeleteExceptionThrown when a delete operation has nothing to delete.Classorg.springframework.xd.dirt.integration.bus.rabbitSpring XD
OptionNameAfterDashDashRecoveryStrategyProvides completion proposals when the user has typed the two dashes that precede a module option name.Classorg.springframework.xd.dirt.stream.completionSpring XD
OrderedContextInitializerAllows any necessary changes to the Target Context.Interfaceorg.springframework.xd.dirt.container.initializerSpring XD
PageNotFoundExceptionException thrown when a Pageable requests a page that does not exist.Classorg.springframework.xd.dirt.utilSpring XD
PagingUtilityUtility class for paging support in repository accessor methods.Classorg.springframework.xd.dirt.utilSpring XD
ParentConfigurationBeans defined and imported here are in the global parent context, hence available to the entire hierarchy, includingAdmins, Containers, and Modules.Classorg.springframework.xd.dirt.serverSpring XD
ParsingContextCaptures the context in which a parse operation is made.Classorg.springframework.xd.dirt.streamSpring XD
ParsingContext .PositionRepresents the position of a module in an XD DSL declaration.Classorg.springframework.xd.dirt.stream.ParsingContextSpring XD
PartitionKeyExtractorStrategyStrategy for extracting a partition key from a Message.Interfaceorg.springframework.xd.dirt.integration.busSpring XD
PartitionSelectorStrategyStrategy for determining the partition to which a message should be sent.Interfaceorg.springframework.xd.dirt.integration.busSpring XD
PasswordUtilsProvides common utility methods for JobDefinitions andStreamDefinitions (BaseDefinition), e.Classorg.springframework.xd.dirt.restSpring XD
PathsCommon paths and path utilities for XD components.Classorg.springframework.xd.dirt.zookeeperSpring XD
PipeIntoOtherModulesExpansionStrategyContinues a well-formed stream definition by adding a pipe symbol and another module, provided that the streamdefinition hasn't reached its end yet.Classorg.springframework.xd.dirt.stream.completionSpring XD
PluginContextComponentScanningExtensionsInitializerAn OrderedContextInitializer to scan for annotation configured beans in xd.Classorg.springframework.xd.dirt.container.initializerSpring XD
PluginContextResourceExtensionsInitializerAn OrderedContextInitializer to scan resource locations xd.Classorg.springframework.xd.dirt.container.initializerSpring XD
PluginsInitializerAn OrderedContextInitializer to load out-of-the-box XD Plugins.Classorg.springframework.xd.dirt.container.initializerSpring XD
PojoToJsonMessageConverterto convert a Java object to a JSON StringAuthor:David Turanski, David LiuClassorg.springframework.xd.dirt.integration.bus.converterSpring XD
PojoToStringMessageConverterto convert a Java object to a String using toString()Author:David TuranskiClassorg.springframework.xd.dirt.integration.bus.converterSpring XD
RabbitAdminExceptionExceptions thrown while interfacing with the RabbitMQ admin plugin.Classorg.springframework.xd.dirt.integration.busSpring XD
RabbitBusCleanerClassorg.springframework.xd.dirt.integration.bus.rabbitSpring XD
RabbitConnectionMixinFactors out options for the typical connection setup to RabbitMQ.Classorg.springframework.xd.dirt.modules.metadataSpring XD
RabbitManagementUtilsClassorg.springframework.xd.dirt.integration.busSpring XD
RabbitMessageBusA MessageBus implementation backed by RabbitMQ.Classorg.springframework.xd.dirt.integration.rabbitSpring XD
RabbitSinkOptionsMetadataCaptures options to the rabbit sink module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
RabbitSourceOptionsMetadataDescribes options to the rabbit source module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
RedisConnectionMixinMixin for Redis connection options.Classorg.springframework.xd.dirt.modules.metadataSpring XD
RedisMessageBusA MessageBus implementation backed by Redis.Classorg.springframework.xd.dirt.integration.redisSpring XD
RedisSinkOptionsMetadataOptions metadata for Redis sink module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
RepositoryConnectionListenerZooKeeper connection listener that ensures path creation fornodes required by the various repository implementations thatClassorg.springframework.xd.dirt.stream.zookeeperSpring XD
ResourceDefinitionExceptionThrown when a problem is detected with the (DSL) definition of an XD resource.Classorg.springframework.xd.dirt.moduleSpring XD
ResourceDeployerInterface for XD Resource Services.Interfaceorg.springframework.xd.dirt.coreSpring XD
ResourceModuleRegistryResource based implementation of ModuleRegistry.Classorg.springframework.xd.dirt.moduleSpring XD
ResourcePatternScanningOptionHandlerAn OptionHandler that scans a resource pattern for existing resources (using a single '*' wildcard) andallows all String values s that would fit if that single wildcard was replaced by s.Classorg.springframework.xd.dirt.server.optionsSpring XD
ResourcePatternScanningOptionHandlersHolds definitions of ResourcePatternScanningOptionHandlers used in Spring XD.Classorg.springframework.xd.dirt.server.optionsSpring XD
ResourcePatternScanningOptionHandlers .DistributedAnalyticsOptionHandlerComputes values for --analytics in the distributed case (memory is NOT supported).Classorg.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandlersSpring XD
ResourcePatternScanningOptionHandlers .HadoopDistroOptionHandlerComputes values for --hadoopDistro out of names of subdirectories of the lib/ dir.Classorg.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandlersSpring XD
ResourcePatternScanningOptionHandlers .SingleNodeAnalyticsOptionHandlerComputes values for --analytics in the single node case (accepts memory).Classorg.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandlersSpring XD
ResourcePatternScanningOptionHandlers .SingleNodeDataTransportOptionHandlerComputes values for (data) --transport for the singlenode case.Classorg.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandlersSpring XD
ResourceStateVerifierVerifies the state of resources (job or stream) by polling repository state until theresource is in the expected state or the operation times out.Classorg.springframework.xd.dirt.testSpring XD
RestConfigurationTakes care of infrastructure setup for the web/rest layer.Classorg.springframework.xd.dirt.restSpring XD
RestControllerAdviceCentral class for behavior common to all REST controllers.Classorg.springframework.xd.dirt.restSpring XD
RestLogoutSuccessHandlerstatus code of 200.Classorg.springframework.xd.dirt.web.controller.supportSpring XD
RichGaugesControllerExposes representations of Gauges.Classorg.springframework.xd.dirt.rest.metricsSpring XD
RuntimeBatchConfigurerSpring XD runtime specific BatchConfigurer.Classorg.springframework.xd.dirt.batchSpring XD
RuntimeContainerResourceAssemblerKnows how to assemble DetailedContainerResources out of DetailedContainer instances.Classorg.springframework.xd.dirt.restSpring XD
RuntimeIOExceptionThrown when something goes wrong during some IO operation.Classorg.springframework.xd.dirt.coreSpring XD
RuntimeModuleDeploymentPropertiesProviderDefault implementation of ModuleDeploymentPropertiesProviderfor type RuntimeModuleDeploymentProperties.Classorg.springframework.xd.dirt.server.admin.deploymentSpring XD
RuntimeTimeoutExceptionException thrown when a blocking operation times out.Classorg.springframework.xd.dirt.coreSpring XD
RuntimeUtilsUtilities for obtaining runtime information for the running process.Classorg.springframework.xd.dirt.utilSpring XD
SecurityConfigurationSetup Spring Security for the http endpoints of the application.Classorg.springframework.xd.dirt.web.configSpring XD
SecurityConfiguration .AuthorizationConfigHolds configuration for the authorization aspects of security.Classorg.springframework.xd.dirt.web.config.SecurityConfigurationSpring XD
SecurityControllerProvides security-related meta information.Classorg.springframework.xd.dirt.rest.securitySpring XD
SerializationExceptionThrown when something goes wrong with inter-module communication.Classorg.springframework.xd.dirt.integration.busSpring XD
SerializedToJavaMessageConverterto deserialize Serializable Java objects.Classorg.springframework.xd.dirt.integration.bus.converterSpring XD
SftpSourceOptionsMetadataModule options for SFTP source module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
ShallowMetricResourceAssemblerBase class for a ResourceAssembler that builds shallow resources for metrics (exposing only their names, andhence their "self" rel).Classorg.springframework.xd.dirt.rest.metricsSpring XD
SharedServerContextConfigurationBeans defined and imported here are shared by the XD Admin Server and Container Server.Classorg.springframework.xd.dirt.serverSpring XD
SharedServerContextConfiguration .ZookeeperConnectionConfigClassorg.springframework.xd.dirt.server.SharedServerContextConfigurationSpring XD
SimpleXdChunkListenerClassorg.springframework.xd.dirt.plugins.job.support.listenerSpring XD
SimpleXdItemListenerClassorg.springframework.xd.dirt.plugins.job.support.listenerSpring XD
SimpleXdJobExecutionListenerClassorg.springframework.xd.dirt.plugins.job.support.listenerSpring XD
SimpleXdSkipListenerClassorg.springframework.xd.dirt.plugins.job.support.listenerSpring XD
SimpleXdStepExecutionListenerClassorg.springframework.xd.dirt.plugins.job.support.listenerSpring XD
SingleNodeApplicationSingle Node XD Runtime.Classorg.springframework.xd.dirt.server.singlenodeSpring XD
SingleNodeIntegrationTestSupportA helper class that provides methods used for testing streams with SingleNodeApplication.Classorg.springframework.xd.dirt.testSpring XD
SingleNodeNamedChannelSinkFactoryA factory for creating NamedChannelSinks.Classorg.springframework.xd.dirt.test.sinkSpring XD
SingleNodeNamedChannelSourceFactoryA factory for creating NamedChannelSources.Classorg.springframework.xd.dirt.test.sourceSpring XD
SingleNodeNamedQueueSinkA NamedChannelSink implementation that binds to a Queue Channel.Classorg.springframework.xd.dirt.test.sinkSpring XD
SingleNodeNamedQueueSourceA NamedChannelSource implementation that binds to a Queue Channel.Classorg.springframework.xd.dirt.test.sourceSpring XD
SingleNodeNamedTopicSinkA NamedChannelSink implementation that binds to a PubSub Channel.Classorg.springframework.xd.dirt.test.sinkSpring XD
SingleNodeNamedTopicSourceA NamedChannelSource implementation that binds to a PubSub Channel.Classorg.springframework.xd.dirt.test.sourceSpring XD
SingleNodeOptionsHolds options that can be used in single-node mode.Classorg.springframework.xd.dirt.server.optionsSpring XD
SingleNodeProcessingChainCreates a stream to test a processing chain p1 p2 .Classorg.springframework.xd.dirt.test.processSpring XD
SingleNodeProcessingChainConsumerCreates a stream to test a processing chain including a source but no sink and adds a NamedChannelSink tocreate a complete stream.Classorg.springframework.xd.dirt.test.processSpring XD
SingleNodeProcessingChainProducerCreates a stream to test a processing chain including a sink but no source and adds a NamedChannelSource tocreate a complete stream.Classorg.springframework.xd.dirt.test.processSpring XD
SingleNodeProcessingChainSupportA helper class to easily create AbstractSingleNodeProcessingChains using static methods.Classorg.springframework.xd.dirt.test.processSpring XD
SingletonModuleRegistryAn implementation of ModuleRegistry suitable to lookup a module that is atthe root of the classpath.Classorg.springframework.xd.dirt.testSpring XD
SinkChannelNodeClassorg.springframework.xd.dirt.stream.dslSpring XD
SourceChannelNodeClassorg.springframework.xd.dirt.stream.dslSpring XD
SparkStreamingChannelThe DirectChannel that provides support forspark streaming configurations.Classorg.springframework.xd.dirt.plugins.spark.streamingSpring XD
SparkStreamingContainerFilterA ContainerFilter which filters out the containers that have a sparkstreaming module running.Classorg.springframework.xd.dirt.sparkSpring XD
SparkStreamingPluginPlugin for Spark Streaming support.Classorg.springframework.xd.dirt.plugins.spark.streamingSpring XD
SplitThe AST node representing a split.Classorg.springframework.xd.dirt.job.dslSpring XD
SplitterProcessorOptionsMetadataCaptures options for the splitter processor module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
StacktraceFingerprintingCompletionRecoveryStrategyA recovery strategy that will trigger if the parser failure is similar to that of some sample unfinished streamdefinition.Classorg.springframework.xd.dirt.stream.completionSpring XD
StalenessCheckA strategy interface for deciding whether a target definition is stale compared to a source definition.Interfaceorg.springframework.xd.dirt.moduleSpring XD
StandAloneUiAppStarts the Web UI without needing the full Spring XD setup.Classorg.springframework.xd.dirt.webSpring XD
StepExecutionInfoRepresents Batch step execution info.Classorg.springframework.xd.dirt.jobSpring XD
StepExecutionInfoResourceAssemblerKnows how to build a REST resource out of our domain model StepExecutionInfo.Classorg.springframework.xd.dirt.restSpring XD
StepExecutionJacksonMixInJackson MixIn for StepExecution serialization.Classorg.springframework.xd.dirt.plugins.job.supportSpring XD
StepExecutionProgressInfoRepresents Batch job step execution progress info.Classorg.springframework.xd.dirt.jobSpring XD
StepExecutionProgressInfoResourceAssemblerKnows how to build a REST resource out of our domain model StepExecutionProgressInfo.Classorg.springframework.xd.dirt.restSpring XD
StepTypeThe types of Spring Batch Step implementations that are known to the system.Classorg.springframework.xd.dirt.jobSpring XD
StreamDomain model for runtime Stream modules.Classorg.springframework.xd.dirt.coreSpring XD
StreamA runtime representation of a running stream.Classorg.springframework.xd.dirt.streamSpring XD
Stream .BuilderBuilder object for Stream that supports fluent style configuration.Classorg.springframework.xd.dirt.core.StreamSpring XD
StreamConfigParserClassorg.springframework.xd.dirt.stream.dslSpring XD
StreamDefinitionRepresents a model for a data flow in the system.Classorg.springframework.xd.dirt.streamSpring XD
StreamDefinitionExceptionRoot exception for DSL parsing related exceptions.Classorg.springframework.xd.dirt.stream.dslSpring XD
StreamDefinitionRepositoryA repository for persisting StreamDefinitions.Interfaceorg.springframework.xd.dirt.streamSpring XD
StreamDefinitionRepositoryUtilsClassorg.springframework.xd.dirt.streamSpring XD
StreamDefinitionResourceAssemblerKnows how to build a REST resource out of our domain model StreamDefinition.Classorg.springframework.xd.dirt.restSpring XD
StreamDeployerDefault implementation of StreamDeployer that uses providedStreamDefinitionRepository and StreamRepository toClassorg.springframework.xd.dirt.streamSpring XD
StreamDeploymentsPathBuilder object for paths under Paths.Classorg.springframework.xd.dirt.coreSpring XD
StreamExceptionRoot of the hierarchy of exceptions for Module processing in DIRT.Classorg.springframework.xd.dirt.streamSpring XD
StreamFactoryFactory class that builds Stream instances.Classorg.springframework.xd.dirt.streamSpring XD
StreamLookupEnvironmentA lookup environment is used to resolve a stream.Interfaceorg.springframework.xd.dirt.stream.dslSpring XD
StreamNodeClassorg.springframework.xd.dirt.stream.dslSpring XD
StreamPluginClassorg.springframework.xd.dirt.plugins.streamSpring XD
StreamRepositoryA repository for persisting Streams.Interfaceorg.springframework.xd.dirt.streamSpring XD
StreamRuntimePropertiesProviderRuntimeModuleDeploymentPropertiesProvider that provides the stream partition/short circuitproperties for the given ModuleDescriptor.Classorg.springframework.xd.dirt.server.admin.deploymentSpring XD
StreamsControllerHandles all Stream related interaction.Classorg.springframework.xd.dirt.restSpring XD
StrictContentTypeResolverA StringConvertingContentTypeResolver that requires a the content-type to be present.Classorg.springframework.xd.dirt.integration.busSpring XD
StringConvertingContentTypeResolverA DefaultContentTypeResolver that can parse String values.Classorg.springframework.xd.dirt.integration.busSpring XD
StringToByteArrayMessageConverterto convert a String to a byte[], applying the provided Charset inthe content-type header if any.Classorg.springframework.xd.dirt.integration.bus.converterSpring XD
SupervisorElectedEventEvent that is fired after a admin leader is elected.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
SupervisorElectionListenerEvent listener for SupervisorElectedEvents.Interfaceorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
SynchronizingModuleRegistryA ModuleRegistry that is configured with two delegates: a remote (source) and a local (target) registry.Classorg.springframework.xd.dirt.moduleSpring XD
TailSourceOptionsMetadataDescribes options to the tail source module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
TaskletTypeTypes of Tasklet implementations known by Spring XD.Classorg.springframework.xd.dirt.jobSpring XD
ThreadContextClassLoaderSetterAdviceAn advice that will set the thread context ClassLoader to theenclosing ApplicationContext's class loader before invocation and resetClassorg.springframework.xd.dirt.module.supportSpring XD
TimeSourceOptionsMetadataDescribes options to the time source module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
TimestampFileJobOptionsMetadataOptions for the timestampfile job module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
TokenHolder for a kind of token, the associated data and its position in the input data stream (start/end).Classorg.springframework.xd.dirt.job.dslSpring XD
TokenHolder for a kind of token, the associated data and its position in the input data stream (start/end).Classorg.springframework.xd.dirt.stream.dslSpring XD
TokenKindEnumeration of all the token types that may be found in a Job DSL specification.Classorg.springframework.xd.dirt.job.dslSpring XD
TokenKindEnumeration of all the token types that may be found in a DSL definition stream.Classorg.springframework.xd.dirt.stream.dslSpring XD
TokensClass that converts an expression into a list of tokens.Classorg.springframework.xd.dirt.job.dslSpring XD
ToolsControllerA controller for integrating with frontend tools.Classorg.springframework.xd.dirt.restSpring XD
TransitionAn AST node representing a transition found in the parsed Job specification.Classorg.springframework.xd.dirt.job.dslSpring XD
TriggerSourceOptionsMetadataDescribes options to the trigger source module.Classorg.springframework.xd.dirt.modules.metadataSpring XD
TupleToJsonMessageConverterto convert a Tuple to a JSON StringAuthor:David TuranskiClassorg.springframework.xd.dirt.integration.bus.converterSpring XD
UnfinishedModuleNameRecoveryStrategyClassorg.springframework.xd.dirt.stream.completionSpring XD
UnfinishedOptionNameRecoveryStrategyClassorg.springframework.xd.dirt.stream.completionSpring XD
UploadedModuleDefinitionA module definition that serves as a temporary vehicle for the payload of an uploaded module.Classorg.springframework.xd.dirt.moduleSpring XD
ValidationControllerProvides server-validation services.Classorg.springframework.xd.dirt.rest.validationSpring XD
VersionControllerController to retrieve version control information.Classorg.springframework.xd.dirt.rest.metaSpring XD
VersionPatternConverterthat returns the "Implementation-Version" string obtained from themanifest of the jar that this class was loaded from.Classorg.springframework.xd.dirt.util.loggingSpring XD
VersionPatternLayoutExtension of Log4j's EnhancedPatternLayoutwhich supports logging of the "Implementation-Version" stringClassorg.springframework.xd.dirt.util.loggingSpring XD
VersionPatternParserExtension of Log4j's PatternParserthat recognizes the pattern %v which is used to log theClassorg.springframework.xd.dirt.util.loggingSpring XD
WebConfigurationProvides Spring MVC configuration.Classorg.springframework.xd.dirt.webSpring XD
WritableModuleRegistryBase interface for registries that know how to create (and hence how to delete) new module definitions.Interfaceorg.springframework.xd.dirt.moduleSpring XD
WritableResourceModuleRegistryWritable extension of ResourceModuleRegistry.Classorg.springframework.xd.dirt.moduleSpring XD
XdConfigLoggingInitializerInitializer that can print useful stuff about an XD context on startup.Classorg.springframework.xd.dirt.utilSpring XD
XDControllerBase Class for XD Controllers.Classorg.springframework.xd.dirt.restSpring XD
XDController .QueryOptionsData holder class for controlling how the list methods should behave.Classorg.springframework.xd.dirt.rest.XDControllerSpring XD
XDDSLMessagesContains all the messages that can be produced during Spring XD DSL parsing.Classorg.springframework.xd.dirt.stream.dslSpring XD
XDDSLMessages .KindClassorg.springframework.xd.dirt.stream.dsl.XDDSLMessagesSpring XD
XdErrorControllerErrorController that causes 404 errors to be redirected to the Admin-UI 404 page.Classorg.springframework.xd.dirt.restSpring XD
XdHeadersSpring Integration message headers for XD.Classorg.springframework.xd.dirt.integration.busSpring XD
XdJdbcSearchableJobExecutionDaoClassorg.springframework.xd.dirt.job.daoSpring XD
XDJobListenerConstantsInterface holdings constants related to XD JobListeners.Interfaceorg.springframework.xd.dirt.plugins.job.support.listenerSpring XD
XDParserParser to convert a DSL string for a deployable unit (i.Interfaceorg.springframework.xd.dirt.streamSpring XD
XdProfilesStatic constants for XD server's spring profile names.Classorg.springframework.xd.dirt.utilSpring XD
XDStreamParserParser to convert a DSL string for a stream into a list ofobjects that comprise the given stream.Classorg.springframework.xd.dirt.streamSpring XD
XDStreamParser .MultiLineDocumentParserA wrapper around the canonical parser that supports multiline "document" parsing.Classorg.springframework.xd.dirt.stream.XDStreamParserSpring XD
XdUtilsProvides general utilities for Spring XD.Classorg.springframework.xd.dirt.utilSpring XD
ZKDeploymentHandlerAbstract class that has common implementations of ZK based deployments.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
ZKDeploymentMessagePublisherZooKeeper based DeploymentMessagePublisher that publishesdeployment messages into a ZooKeeper/CuratorClassorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
ZKJobDeploymentHandlerDeployment handler that is responsible for the deployment of a Job.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
ZKStreamDeploymentHandlerDeployment handler that is responsible for deploying Stream.Classorg.springframework.xd.dirt.server.admin.deployment.zkSpring XD
ZooKeeperAccessExceptionRuntime exception used to wrap native ZooKeeper checked exceptions thrown whileaccessing ZooKeeper nodes.Classorg.springframework.xd.dirt.zookeeperSpring XD
ZooKeeperAdminRepositoryZooKeeper backed repository for runtime info about Admins.Classorg.springframework.xd.dirt.container.storeSpring XD
ZooKeeperComposedModuleDefinitionRegistryAn implementation of WriteableModuleRegistry dedicated to CompositeModuleDefinitions and that usesZooKeeper as storage mechanism.Classorg.springframework.xd.dirt.module.storeSpring XD
ZooKeeperConnectionA wrapper for a CuratorFramework instance whose lifecycle is managed as a Spring bean.Classorg.springframework.xd.dirt.zookeeperSpring XD
ZooKeeperConnectionConfigurerA strategy interface for configuring ZooKeeperConnection at start up.Interfaceorg.springframework.xd.dirt.zookeeperSpring XD
ZooKeeperConnectionListenerListener for ZooKeeper connection and disconnection events.Interfaceorg.springframework.xd.dirt.zookeeperSpring XD
ZookeeperConnectionPluginSupplies plugins with a reference to the Spring XD ZooKeeperConnectionAuthor:Marius BogoeviciClassorg.springframework.xd.dirt.pluginsSpring XD
ZooKeeperContainerRepositoryZooKeeper backed repository for runtime info about Containers.Classorg.springframework.xd.dirt.container.storeSpring XD
ZooKeeperJobDefinitionRepositoryA Zookeeper backed repository for persisting JobDefinitions.Classorg.springframework.xd.dirt.stream.zookeeperSpring XD
ZooKeeperJobRepositoryJob instance repository.Classorg.springframework.xd.dirt.stream.zookeeperSpring XD
ZooKeeperModuleDependencyRepositoryZooKeeper based implementation of ModuleDependencyRepository that writes each dependency to a node, such as:/xd/modules/[moduletype]/[modulename]/dependencies/[target].Classorg.springframework.xd.dirt.module.storeSpring XD
ZooKeeperModuleMetadataRepositoryZooKeeper backed repository for runtime info about deployed modules.Classorg.springframework.xd.dirt.module.storeSpring XD
ZooKeeperStreamDefinitionRepositoryClassorg.springframework.xd.dirt.stream.zookeeperSpring XD
ZooKeeperStreamRepositoryStream instance repository.Classorg.springframework.xd.dirt.stream.zookeeperSpring XD
ZooKeeperUtilsUtility methods for ZooKeeper.Classorg.springframework.xd.dirt.zookeeperSpring XD
ZooKeeperUtils .StripPathConverterConverter from ChildData to leaf name string.Classorg.springframework.xd.dirt.zookeeper.ZooKeeperUtilsSpring XD