- abandon(Long) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobService
-
- abandonWhenPercentageFull - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- abbreviate(String) - Method in class org.springframework.xd.dirt.util.logging.LoggerAbbreviator
-
- ABSOLUTE_FILE_PATH - Static variable in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
- AbstractBatchJobsController - Class in org.springframework.xd.dirt.rest
-
Abstract controller that all the XD batch admin controllers extend.
- AbstractBatchJobsController() - Constructor for class org.springframework.xd.dirt.rest.AbstractBatchJobsController
-
- AbstractBusPropertiesAccessor - Class in org.springframework.xd.dirt.integration.bus
-
Base class for bus-specific property accessors; common properties
are defined here.
- AbstractBusPropertiesAccessor(Properties) - Constructor for class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
- AbstractComponentScanningBeanDefinitionProvider - Class in org.springframework.xd.dirt.container.initializer
-
- AbstractComponentScanningBeanDefinitionProvider() - Constructor for class org.springframework.xd.dirt.container.initializer.AbstractComponentScanningBeanDefinitionProvider
-
- AbstractDeployer<D extends BaseDefinition> - Class in org.springframework.xd.dirt.stream
-
- AbstractDeployer(ZooKeeperConnection, PagingAndSortingRepository<D, String>, XDParser, ParsingContext) - Constructor for class org.springframework.xd.dirt.stream.AbstractDeployer
-
- AbstractEvent<S> - Class in org.springframework.xd.dirt.event
-
- AbstractEvent(S) - Constructor for class org.springframework.xd.dirt.event.AbstractEvent
-
- AbstractExternalResourceTestSupport<R> - Class in org.springframework.xd.test
-
Abstract base class for JUnit Rule
s that detect the presence of some external resource.
- AbstractExternalResourceTestSupport(String) - Constructor for class org.springframework.xd.test.AbstractExternalResourceTestSupport
-
- AbstractExternalTable - Class in org.springframework.xd.greenplum.support
-
Base settings for all external tables;
- AbstractExternalTable() - Constructor for class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- AbstractFieldMappingAwareDataMapper - Class in org.springframework.xd.analytics.ml
-
- AbstractFieldMappingAwareDataMapper() - Constructor for class org.springframework.xd.analytics.ml.AbstractFieldMappingAwareDataMapper
-
- AbstractFieldMappingAwareDataMapper(String) - Constructor for class org.springframework.xd.analytics.ml.AbstractFieldMappingAwareDataMapper
-
- AbstractFromMessageConverter - Class in org.springframework.xd.dirt.integration.bus.converter
-
Base class for converters applied via Spring Integration 4.x data type channels.
- AbstractFromMessageConverter(MimeType) - Constructor for class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
Creates a converter that ignores content-type message headers
- AbstractFromMessageConverter(Collection<MimeType>) - Constructor for class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
- AbstractFromMessageConverter(Collection<MimeType>, MimeType, ContentTypeResolver) - Constructor for class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
Creates a converter that handles one or more content-type message headers
- AbstractFromMessageConverter(Collection<MimeType>, Collection<MimeType>, ContentTypeResolver) - Constructor for class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
Creates a converter that handles one or more content-type message headers and one or more target MIME types
- AbstractFromMessageConverter(MimeType, MimeType) - Constructor for class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
Creates a converter that requires a specific content-type message header
- AbstractFromMessageConverter(MimeType, Collection<MimeType>) - Constructor for class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
Creates a converter that requires a specific content-type message header and supports multiple target MIME types.
- AbstractGPFDistMessageHandler - Class in org.springframework.xd.greenplum.gpfdist
-
Base implementation of Spring Integration MessageHandler
handling Message
.
- AbstractGPFDistMessageHandler() - Constructor for class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
- AbstractHdfsItemWriter<T> - Class in org.springframework.xd.batch.item.hadoop
-
- AbstractHdfsItemWriter() - Constructor for class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- AbstractHdfsWriter - Class in org.springframework.xd.hadoop.fs
-
Logic for writing to files of a specified size or other strategies go here as they are shared across implementations
- AbstractHdfsWriter() - Constructor for class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- AbstractImportToJdbcOptionsMetadata - Class in org.springframework.xd.jdbc
-
Factors out options that are common to modules/jobs that import into a db table.
- AbstractImportToJdbcOptionsMetadata() - Constructor for class org.springframework.xd.jdbc.AbstractImportToJdbcOptionsMetadata
-
- AbstractInMemoryRepository<T,ID extends java.io.Serializable & java.lang.Comparable<ID>> - Class in org.springframework.xd.store
-
Base implementation for an in-memory store, using a Map
internally.
- AbstractInMemoryRepository() - Constructor for class org.springframework.xd.store.AbstractInMemoryRepository
-
- AbstractInstancePersistingDeployer<D extends BaseDefinition,I extends BaseInstance<D>> - Class in org.springframework.xd.dirt.stream
-
- AbstractInstancePersistingDeployer(ZooKeeperConnection, PagingAndSortingRepository<D, String>, DomainRepository<I, String>, XDParser, DeploymentHandler, ParsingContext) - Constructor for class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
- AbstractJobPlugin - Class in org.springframework.xd.dirt.plugins
-
- AbstractJobPlugin(MessageBus) - Constructor for class org.springframework.xd.dirt.plugins.AbstractJobPlugin
-
- AbstractMailSource<T extends AbstractMailSource<T>> - Class in org.springframework.xd.test.fixtures
-
Base class support for both "mail" and "imap".
- AbstractMailSource() - Constructor for class org.springframework.xd.test.fixtures.AbstractMailSource
-
- AbstractMessageBusBinderPlugin - Class in org.springframework.xd.dirt.plugins
-
Abstract
Plugin
that has common implementation methods to bind/unbind
Module
's message producers and
consumers to/from
MessageBus
.
- AbstractMessageBusBinderPlugin(MessageBus) - Constructor for class org.springframework.xd.dirt.plugins.AbstractMessageBusBinderPlugin
-
- AbstractMessageBusBinderPlugin(MessageBus, ZooKeeperConnection) - Constructor for class org.springframework.xd.dirt.plugins.AbstractMessageBusBinderPlugin
-
- AbstractMetricsCommands - Class in org.springframework.xd.shell.command
-
Base class to factor out similar behavior for all related metrics commands.
- AbstractMetricsCommands(String) - Constructor for class org.springframework.xd.shell.command.AbstractMetricsCommands
-
- AbstractMetricSink - Class in org.springframework.xd.test.fixtures
-
Base class for Metrics related sinks, makes sure named metric is deleted at end of test.
- AbstractMetricSink(JLineShellComponent, String, String) - Constructor for class org.springframework.xd.test.fixtures.AbstractMetricSink
-
- AbstractModule - Class in org.springframework.xd.module.core
-
- AbstractModule(ModuleDescriptor, ModuleDeploymentProperties) - Constructor for class org.springframework.xd.module.core.AbstractModule
-
- AbstractModuleEvent - Class in org.springframework.xd.dirt.event
-
- AbstractModuleEvent(Module, String) - Constructor for class org.springframework.xd.dirt.event.AbstractModuleEvent
-
- AbstractModuleFixture<F extends AbstractModuleFixture<F>> - Class in org.springframework.xd.test.fixtures
-
- AbstractModuleFixture() - Constructor for class org.springframework.xd.test.fixtures.AbstractModuleFixture
-
- AbstractPlugin - Class in org.springframework.xd.dirt.plugins
-
Abstract
Plugin
that contains no-op and common implementing methods.
- AbstractPlugin() - Constructor for class org.springframework.xd.dirt.plugins.AbstractPlugin
-
- AbstractProcessBuilderTasklet - Class in org.springframework.batch.step.tasklet.x
-
Abstract tasklet for running code in a separate process and capturing the log output.
- AbstractProcessBuilderTasklet() - Constructor for class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- AbstractReactorMessageHandler - Class in org.springframework.xd.reactor
-
Abstract base class for Reactor based MessageHandlers.
- AbstractReactorMessageHandler(Processor) - Constructor for class org.springframework.xd.reactor.AbstractReactorMessageHandler
-
Construct a new BroadcasterMessageHandler given the reactor based Processor to delegate
processing to.
- AbstractReactorMessageHandler.ChannelForwardingSubscriber - Class in org.springframework.xd.reactor
-
- AbstractReactorMessageHandler.ChannelForwardingSubscriber() - Constructor for class org.springframework.xd.reactor.AbstractReactorMessageHandler.ChannelForwardingSubscriber
-
- AbstractRedisRepository<T,ID extends java.io.Serializable & java.lang.Comparable<ID>> - Class in org.springframework.xd.store
-
Base implementation for a store, using Redis behind the scenes.
- AbstractRedisRepository(String, RedisOperations<String, String>) - Constructor for class org.springframework.xd.store.AbstractRedisRepository
-
- AbstractRepository<T,ID extends java.io.Serializable> - Class in org.springframework.xd.store
-
Helper class for repositories, implementing some behavior in terms of unit methods.
- AbstractRepository() - Constructor for class org.springframework.xd.store.AbstractRepository
-
- AbstractResourceBeanDefinitionProvider - Class in org.springframework.xd.dirt.container.initializer
-
- AbstractResourceBeanDefinitionProvider() - Constructor for class org.springframework.xd.dirt.container.initializer.AbstractResourceBeanDefinitionProvider
-
- AbstractSingleNodeNamedChannelModule<T extends org.springframework.messaging.MessageChannel> - Class in org.springframework.xd.dirt.test
-
Base class for SingleNodeNamedChannel resources used to bind a
MessageChannel
to a shared channel using a
MessageBus
.
- AbstractSingleNodeNamedChannelModule(MessageBus, T, String) - Constructor for class org.springframework.xd.dirt.test.AbstractSingleNodeNamedChannelModule
-
- AbstractSingleNodeNamedChannelModuleFactory - Class in org.springframework.xd.dirt.test
-
Base class for factories used to create NamedChannelSource and NamedChannelSink.
- AbstractSingleNodeNamedChannelModuleFactory(MessageBus) - Constructor for class org.springframework.xd.dirt.test.AbstractSingleNodeNamedChannelModuleFactory
-
- AbstractSingleNodeNamedChannelSink - Class in org.springframework.xd.dirt.test.sink
-
Base class for SingleNode named channel sink types.
- AbstractSingleNodeNamedChannelSink(MessageBus, String) - Constructor for class org.springframework.xd.dirt.test.sink.AbstractSingleNodeNamedChannelSink
-
- AbstractSingleNodeNamedChannelSource - Class in org.springframework.xd.dirt.test.source
-
Base class for SingleNode named channel source types.
- AbstractSingleNodeNamedChannelSource(MessageBus, SubscribableChannel, String) - Constructor for class org.springframework.xd.dirt.test.source.AbstractSingleNodeNamedChannelSource
-
- AbstractSingleNodeProcessingChain - Class in org.springframework.xd.dirt.test.process
-
- AbstractSingleNodeProcessingChain(SingleNodeApplication, String, String) - Constructor for class org.springframework.xd.dirt.test.process.AbstractSingleNodeProcessingChain
-
- AbstractSingleNodeProcessingChain(SingleNodeApplication, String, String, String) - Constructor for class org.springframework.xd.dirt.test.process.AbstractSingleNodeProcessingChain
-
- AbstractStreamPlugin - Class in org.springframework.xd.dirt.plugins
-
- AbstractStreamPlugin(MessageBus) - Constructor for class org.springframework.xd.dirt.plugins.AbstractStreamPlugin
-
- AbstractStreamPlugin(MessageBus, ZooKeeperConnection) - Constructor for class org.springframework.xd.dirt.plugins.AbstractStreamPlugin
-
- AbstractTcpConnectionFactoryOptionsMetadata - Class in org.springframework.xd.tcp
-
Base class for options metadata that deal with a tcp connection factory in some way.
- AbstractTcpConnectionFactoryOptionsMetadata() - Constructor for class org.springframework.xd.tcp.AbstractTcpConnectionFactoryOptionsMetadata
-
- AbstractTwitterInboundChannelAdapter - Class in org.springframework.integration.x.twitter
-
- AbstractTwitterInboundChannelAdapter(TwitterTemplate) - Constructor for class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter
-
- AbstractTwitterInboundChannelAdapter.StreamReadingTask - Class in org.springframework.integration.x.twitter
-
- AbstractTwitterInboundChannelAdapter.StreamReadingTask() - Constructor for class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter.StreamReadingTask
-
- accept(JobSpecification) - Method in class org.springframework.xd.dirt.job.dsl.JobSpecificationVisitor
-
Called to start a visit of a specific JobSpec.
- add(Object) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport.SetBuilder
-
- add(ModuleOption) - Method in class org.springframework.xd.module.options.SimpleModuleOptionsMetadata
-
- addAll(Set<Object>) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport.SetBuilder
-
- addBinding(Binding) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- addChildren(List<ModuleDescriptor>) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Add the list of children to the list of sub modules.
- addConnectionListener(ConnectionListener) - Method in class org.springframework.xd.dirt.integration.rabbit.LocalizedQueueConnectionFactory
-
- addDelegate(ModuleRegistry) - Method in class org.springframework.xd.dirt.module.DelegatingModuleRegistry
-
- addDescriptor(DocumentParseResultResource.ModuleDescriptor) - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.Line
-
- addEnvironmentProvider(EnvironmentProvider) - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- addError(DocumentParseResultResource.Error) - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.Line
-
- addGploadSqlAfter(String) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- addGploadSqlBefore(String) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- addGroupToPubSub(String, String) - Static method in class org.springframework.xd.dirt.integration.bus.BusUtils
-
- addHeader(Integer, TableHeader) - Method in class org.springframework.xd.shell.util.Table
-
- addHeaders(Map<String, String>, HttpRequest) - Method in class org.springframework.integration.x.http.NettyInboundMessageConverter
-
Add additional headers.
- addJob(String, boolean, boolean) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
Store the job name , job parameterer incrementable and job restartable
flags for the job when there is a registry update
- addLine(DocumentParseResultResource.Line) - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource
-
- addListener(ZooKeeperConnectionListener) - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
- addListener(ApplicationListener<?>) - Method in class org.springframework.xd.module.core.CompositeModule
-
- addListener(ApplicationListener<?>) - Method in interface org.springframework.xd.module.core.Module
-
Add an application listener to the application context.
- addListener(ApplicationListener<?>) - Method in class org.springframework.xd.module.core.SimpleModule
-
- addLocation(String) - Method in class org.springframework.xd.greenplum.support.RuntimeContext
-
- AddModuleOptionsExpansionStrategy - Class in org.springframework.xd.dirt.stream.completion
-
Adds missing module options at the end of a well formed stream definition.
- AddModuleOptionsExpansionStrategy(ModuleRegistry, ModuleOptionsMetadataResolver) - Constructor for class org.springframework.xd.dirt.stream.completion.AddModuleOptionsExpansionStrategy
-
Construct a new AddModuleOptionsExpansionStrategy for use in detecting missing module options.
- addModuleRegistry(ModuleRegistry) - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
- addOption(DetailedModuleDefinitionResource.Option) - Method in class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource
-
- addParameters(Map<String, String>) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Add the contents of the provided map to the map of module parameters.
- addPathListener(String, PathChildrenCacheListener) - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
Add a PathChildrenCacheListener
for the given path.
- addProperties(Properties) - Method in class org.springframework.xd.module.core.CompositeModule
-
- addProperties(Properties) - Method in interface org.springframework.xd.module.core.Module
-
Add properties to the environment.
- addProperties(Properties) - Method in class org.springframework.xd.module.core.SimpleModule
-
- addProposals(String, List<ModuleDescriptor>, CompletionKind, int, List<String>) - Method in class org.springframework.xd.dirt.stream.completion.AddModuleOptionsExpansionStrategy
-
- addProposals(String, List<ModuleDescriptor>, CompletionKind, int, List<String>) - Method in interface org.springframework.xd.dirt.stream.completion.CompletionExpansionStrategy
-
Perform code completion by adding proposals to the proposals
list.
- addProposals(String, E, CompletionKind, int, List<String>) - Method in interface org.springframework.xd.dirt.stream.completion.CompletionRecoveryStrategy
-
Perform code completion by adding proposals to the proposals
list.
- addProposals(String, CheckpointedStreamDefinitionException, CompletionKind, int, List<String>) - Method in class org.springframework.xd.dirt.stream.completion.EmptyStartYieldsModulesRecoveryStrategy
-
- addProposals(String, StreamDefinitionException, CompletionKind, int, List<String>) - Method in class org.springframework.xd.dirt.stream.completion.ExpandOneDashToTwoDashesRecoveryStrategy
-
- addProposals(String, CheckpointedStreamDefinitionException, CompletionKind, int, List<String>) - Method in class org.springframework.xd.dirt.stream.completion.ModulesAfterPipeRecoveryStrategy
-
- addProposals(String, CheckpointedStreamDefinitionException, CompletionKind, int, List<String>) - Method in class org.springframework.xd.dirt.stream.completion.OptionNameAfterDashDashRecoveryStrategy
-
- addProposals(String, List<ModuleDescriptor>, CompletionKind, int, List<String>) - Method in class org.springframework.xd.dirt.stream.completion.PipeIntoOtherModulesExpansionStrategy
-
- addProposals(String, NoSuchModuleException, CompletionKind, int, List<String>) - Method in class org.springframework.xd.dirt.stream.completion.UnfinishedModuleNameRecoveryStrategy
-
- addProposals(String, CheckpointedStreamDefinitionException, CompletionKind, int, List<String>) - Method in class org.springframework.xd.dirt.stream.completion.UnfinishedOptionNameRecoveryStrategy
-
- addresses(String) - Method in class org.springframework.xd.test.fixtures.RabbitSink
-
Sets the addresses for the fixture
- addRow(String...) - Method in class org.springframework.xd.shell.util.Table
-
- addScript(Resource) - Method in class org.springframework.xd.jdbc.SingleTableDatabaseInitializer
-
- addSource(Object) - Method in class org.springframework.xd.module.core.CompositeModule
-
- addSource(Object) - Method in interface org.springframework.xd.module.core.Module
-
- addSource(Object) - Method in class org.springframework.xd.module.core.SimpleModule
-
- addStepNames(String, Collection<String>) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
Add the collection of step names into XD_JOB_REGISTRY_STEP_NAMES for a given job.
- addValue(Date, long) - Method in class org.springframework.xd.rest.domain.metrics.AggregateCountsResource
-
Add a data point to the set.
- addValue(Integer, String) - Method in class org.springframework.xd.shell.util.TableRow
-
Add a value to the to the specified column within this row.
- Admin - Class in org.springframework.xd.dirt.cluster
-
Domain object for an XD admin runtime.
- Admin(String, Map<String, String>) - Constructor for class org.springframework.xd.dirt.cluster.Admin
-
Construct a Container object.
- ADMIN_ID_KEY - Static variable in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- ADMIN_PASSWORD - Static variable in class org.springframework.xd.test.fixtures.DisposableMailSupport
-
- ADMIN_PROFILE - Static variable in class org.springframework.xd.dirt.util.XdProfiles
-
- ADMIN_TOKEN - Static variable in class org.springframework.xd.integration.util.ConfigUtil
-
- ADMIN_USER - Static variable in class org.springframework.xd.test.fixtures.DisposableMailSupport
-
- AdminAttributes - Class in org.springframework.xd.dirt.cluster
-
Runtime metadata for a Admin server instance.
- AdminAttributes() - Constructor for class org.springframework.xd.dirt.cluster.AdminAttributes
-
Default constructor generates a random id.
- AdminAttributes(String) - Constructor for class org.springframework.xd.dirt.cluster.AdminAttributes
-
Constructor to be called when the id is already known.
- AdminAttributes(Map<? extends String, ? extends String>) - Constructor for class org.springframework.xd.dirt.cluster.AdminAttributes
-
Constructor to be called when the attributes are already known.
- adminAttributes() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- adminContext() - Method in class org.springframework.xd.dirt.server.singlenode.SingleNodeApplication
-
- AdminController - Class in org.springframework.xd.dirt.rest
-
- AdminController(EntityLinks) - Constructor for class org.springframework.xd.dirt.rest.AdminController
-
- ADMINELECTION - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of admins (that could participate to become leader) node.
- AdminOptions - Class in org.springframework.xd.dirt.server.options
-
Holds configuration options that are valid for the Admin server, when using distributed mode.
- AdminOptions() - Constructor for class org.springframework.xd.dirt.server.options.AdminOptions
-
- AdminPortNotAvailableException - Exception in org.springframework.xd.dirt.server.admin
-
Exception thrown when the configured admin port is not available to use.
- AdminPortNotAvailableException(String) - Constructor for exception org.springframework.xd.dirt.server.admin.AdminPortNotAvailableException
-
Construct an AdminPortNotAvailableException
.
- AdminRepository - Interface in org.springframework.xd.dirt.container.store
-
Repository for persisting
Admin
entities for admins.
- adminRepository() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- ADMINS - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of admins node.
- AdminServerApplication - Class in org.springframework.xd.dirt.server.admin
-
- AdminServerApplication() - Constructor for class org.springframework.xd.dirt.server.admin.AdminServerApplication
-
- afterChunk(ChunkContext) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdChunkListener
-
- afterChunkError(ChunkContext) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdChunkListener
-
- afterCreate(EntryEvent<K, V>) - Method in class org.springframework.xd.gemfire.server.LoggingCacheListener
-
- afterDestroy(EntryEvent<K, V>) - Method in class org.springframework.xd.gemfire.server.LoggingCacheListener
-
- afterInvalidate(EntryEvent<K, V>) - Method in class org.springframework.xd.gemfire.server.LoggingCacheListener
-
- afterJob(JobExecution) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdJobExecutionListener
-
- afterProcess(I, Object) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdItemListener
-
- afterPropertiesSet() - Method in class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
- afterPropertiesSet() - Method in class org.springframework.integration.x.kafka.WindowingOffsetManager
-
- afterPropertiesSet() - Method in class org.springframework.xd.batch.hsqldb.server.HSQLServerBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.batch.item.hadoop.HdfsTextItemWriter
-
- afterPropertiesSet() - Method in class org.springframework.xd.batch.item.hadoop.SimpleHdfsTextItemWriter
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.jdbc.util.DatabaseVendorFriendlyNameFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.job.dao.XdJdbcSearchableJobExecutionDao
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.module.CustomModuleRegistryFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.module.ModuleDeployer
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.module.WritableResourceModuleRegistry
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.plugins.job.JobParametersBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.plugins.job.support.JobLaunchingJobRepositoryFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentQueue
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- afterPropertiesSet() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- afterPropertiesSet() - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
- afterPropertiesSet() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- afterPropertiesSet() - Method in class org.springframework.xd.greenplum.support.ControlFileFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.greenplum.support.LoadFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.hadoop.fs.DatasetDefinitionFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.xd.jdbc.NamedColumnJdbcBatchItemWriter
-
- afterPropertiesSet() - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReader
-
- afterPropertiesSet() - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- afterPropertiesSet() - Method in class org.springframework.xd.jdbc.SingleTableDatabaseInitializer
-
- afterPropertiesSet() - Method in class org.springframework.xd.shell.command.ConfigCommands
-
Initialize the default
Target
for the XD Admin Server.
- afterPropertiesSet() - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- afterRead(I) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdItemListener
-
- afterRegionClear(RegionEvent<K, V>) - Method in class org.springframework.xd.gemfire.server.LoggingCacheListener
-
- afterRegionCreate(RegionEvent<K, V>) - Method in class org.springframework.xd.gemfire.server.LoggingCacheListener
-
- afterRegionDestroy(RegionEvent<K, V>) - Method in class org.springframework.xd.gemfire.server.LoggingCacheListener
-
- afterRegionInvalidate(RegionEvent<K, V>) - Method in class org.springframework.xd.gemfire.server.LoggingCacheListener
-
- afterRegionLive(RegionEvent<K, V>) - Method in class org.springframework.xd.gemfire.server.LoggingCacheListener
-
- afterReturningInvocation(ParseResult, Object) - Method in class org.springframework.xd.shell.hadoop.ConfigurationAware
-
- afterReturningInvocation(ParseResult, Object) - Method in class org.springframework.xd.shell.hadoop.ConfigurationCommands
-
- afterSave(D) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
Callback method that subclasses may override to get a chance to act on newly saved definitions.
- afterStep(StepExecution) - Method in class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
- afterStep(StepExecution) - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- afterStep(StepExecution) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.FileDeletionStepExecutionListener
-
- afterStep(StepExecution) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdStepExecutionListener
-
- afterStep(StepExecution) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- afterStep(StepExecution) - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- afterThrowingInvocation(ParseResult, Throwable) - Method in class org.springframework.xd.shell.hadoop.ConfigurationAware
-
- afterThrowingInvocation(ParseResult, Throwable) - Method in class org.springframework.xd.shell.hadoop.ConfigurationCommands
-
- afterUpdate(EntryEvent<K, V>) - Method in class org.springframework.xd.gemfire.server.LoggingCacheListener
-
- afterWrite(List<? extends Object>) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdItemListener
-
- aggrCounterOperations() - Method in class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- aggrCounterOperations() - Method in interface org.springframework.xd.rest.client.SpringXDOperations
-
Returns the portion of the API for interaction with Aggregate Counters.
- AggregateCount - Class in org.springframework.xd.analytics.metrics.core
-
Represents the data returned from an aggregate count query.
- AggregateCount(String, Interval, long[], AggregateCountResolution) - Constructor for class org.springframework.xd.analytics.metrics.core.AggregateCount
-
- AggregateCounterCommands - Class in org.springframework.xd.shell.command
-
Commands for interacting with aggregate counter analytics.
- AggregateCounterCommands() - Constructor for class org.springframework.xd.shell.command.AggregateCounterCommands
-
- AggregateCounterHandler - Class in org.springframework.xd.analytics.metrics.integration
-
Handles incoming messages for the
aggregate-counter
module, resolves SpEL expressions
as needed and delegate the heavy lifting to an
AggregateCounterRepository
.
- AggregateCounterHandler(AggregateCounterRepository, String, String) - Constructor for class org.springframework.xd.analytics.metrics.integration.AggregateCounterHandler
-
- AggregateCounterOperations - Interface in org.springframework.xd.rest.client
-
Interface defining operations available when dealing with Aggregate Counters.
- AggregateCounterOperations.Resolution - Enum in org.springframework.xd.rest.client
-
- AggregateCounterRepository - Interface in org.springframework.xd.analytics.metrics.core
-
A repository to interact with Aggregate Counters.
- AggregateCountersController - Class in org.springframework.xd.dirt.rest.metrics
-
- AggregateCountersController(AggregateCounterRepository) - Constructor for class org.springframework.xd.dirt.rest.metrics.AggregateCountersController
-
- AggregateCounterSink - Class in org.springframework.xd.test.fixtures
-
Fixture class for an aggregate counter.
- AggregateCounterSink(JLineShellComponent, String) - Constructor for class org.springframework.xd.test.fixtures.AggregateCounterSink
-
- AggregateCounterSinkOptionsMetadata - Class in org.springframework.xd.analytics.metrics.metadata
-
Captures options for the aggregate-counter
sink module.
- AggregateCounterSinkOptionsMetadata() - Constructor for class org.springframework.xd.analytics.metrics.metadata.AggregateCounterSinkOptionsMetadata
-
- AggregateCounterTemplate - Class in org.springframework.xd.rest.client.impl
-
Implementation of the Aggregate Counter part of the metrics API.
- AggregateCounterTemplate(AbstractTemplate) - Constructor for class org.springframework.xd.rest.client.impl.AggregateCounterTemplate
-
- AggregateCountResolution - Enum in org.springframework.xd.analytics.metrics.core
-
The resolution options available for querying an aggregate counter.
- AggregateCountsResource - Class in org.springframework.xd.rest.domain.metrics
-
The REST representation of an Aggregate Count.
- AggregateCountsResource() - Constructor for class org.springframework.xd.rest.domain.metrics.AggregateCountsResource
-
No-arg constructor for serialization frameworks.
- AggregateCountsResource(String) - Constructor for class org.springframework.xd.rest.domain.metrics.AggregateCountsResource
-
- AggregatorProcessorModuleOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Describes options to the aggregator
processor module.
- AggregatorProcessorModuleOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- AggregatorProcessorModuleOptionsMetadata.StoreKind - Enum in org.springframework.xd.dirt.modules.metadata
-
- ALL_MEDIA_TYPES - Static variable in class org.springframework.xd.dirt.test.AbstractSingleNodeNamedChannelModule
-
- ALLOCATED - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of the deployment modules node that are allocated to containers.
- AlreadyDeployedException - Exception in org.springframework.xd.dirt.stream
-
Thrown when an attempt is made to deploy a definition that is already deployed.
- AlreadyDeployedException(String, String) - Constructor for exception org.springframework.xd.dirt.stream.AlreadyDeployedException
-
Create a new exception.
- AlreadyDeployedException(String, String, Throwable) - Constructor for exception org.springframework.xd.dirt.stream.AlreadyDeployedException
-
Create a new exception.
- alternateUsernameAllowed - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- Analytic<I,O> - Interface in org.springframework.xd.analytics.ml
-
Base interface for the definition of analytical logic.
- appendToFile(String) - Method in class org.springframework.xd.test.fixtures.FileSource
-
- appendToFile(String) - Method in class org.springframework.xd.test.fixtures.TailSource
-
- appendToRemoteFile(String, String, String, String, String) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Appends the payload to an existing file on a remote EC2 Instance.
- ApplicationUtils - Class in org.springframework.xd.dirt.server
-
- ApplicationUtils() - Constructor for class org.springframework.xd.dirt.server.ApplicationUtils
-
- apply(Buffer) - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistCodec
-
- apply(Statement, Description) - Method in class org.springframework.xd.test.AbstractExternalResourceTestSupport
-
- apply(Statement, Description) - Method in class org.springframework.xd.test.HostNotWindowsRule
-
- applyPrefix(String, String) - Static method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
For bus implementations that support a prefix, apply the prefix to the name.
- applyProperties(JedisConnectionFactory) - Method in class org.springframework.xd.redis.RedisSinkConfiguration
-
- applyPubSub(String) - Static method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
For bus implementations that include a pub/sub component in identifiers, construct the name.
- applyRequests(String) - Static method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Build the requests entity name.
- AppmasterApplication - Class in org.springframework.xd.yarn
-
Boot appmaster application.
- AppmasterApplication() - Constructor for class org.springframework.xd.yarn.AppmasterApplication
-
- ARCHIVE_AS_FILE_EXTENSION - Static variable in class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
The extension the module 'File' must have if it's not in exploded dir format.
- ArchiveResourceLoader - Class in org.springframework.xd.module.support
-
Spring ResourceLoader that can locate nested boot archives inside a root archive.
- ArchiveResourceLoader(Archive) - Constructor for class org.springframework.xd.module.support.ArchiveResourceLoader
-
- ArgumentNode - Class in org.springframework.xd.dirt.job.dsl
-
Represents an argument like "--name=value".
- ArgumentNode(String, String, int, int) - Constructor for class org.springframework.xd.dirt.job.dsl.ArgumentNode
-
- ArgumentNode - Class in org.springframework.xd.dirt.stream.dsl
-
Represents an argument like "--name=value".
- ArgumentNode(String, String, int, int) - Constructor for class org.springframework.xd.dirt.stream.dsl.ArgumentNode
-
- AsciidocLinkChecker - Class in org.springframework.xd.documentation
-
A tool that checks that for files that will form the whole "concatenated" documentation, any link of the form
- AsciidocLinkChecker(String) - Constructor for class org.springframework.xd.documentation.AsciidocLinkChecker
-
- asPropertySource() - Method in class org.springframework.xd.module.options.ModuleOptions
-
- asPropertySource() - Method in class org.springframework.xd.module.options.PrefixNarrowingModuleOptions
-
- Assertions - Class in org.springframework.xd.shell.util
-
Various utility methods when dealing with shell commands.
- assertReceived(URL, String, String, String, int) - Method in class org.springframework.xd.integration.util.XdEc2Validation
-
Verifies that the instances for the channel and module has in fact processed the correct number of messages.
- assertReceived(URL, String, int) - Method in class org.springframework.xd.integration.util.XdEc2Validation
-
Retrieves the stream and verifies that all modules in the stream processed the data.
- asStringArray(String, String[]) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Convert a comma-delimited String property to a String[] if
present, or return the default value.
- AstNode - Class in org.springframework.xd.dirt.job.dsl
-
AST base class for AST nodes in a parsed Job specification.
- AstNode(int, int) - Constructor for class org.springframework.xd.dirt.job.dsl.AstNode
-
- AstNode - Class in org.springframework.xd.dirt.stream.dsl
-
Common supertype for the ast nodes built during stream parsing.
- AstNode(int, int) - Constructor for class org.springframework.xd.dirt.stream.dsl.AstNode
-
- atMostOneOf(boolean...) - Static method in class org.springframework.xd.module.options.validation.Exclusives
-
Return true when 0 or 1 boolean are true, false otherwise.
- atMostOneOf(Object...) - Static method in class org.springframework.xd.shell.util.Assertions
-
Accepts 2*N arguments, even ones being names and odd ones being values for those names.
- AuthenticationRequest - Class in org.springframework.xd.dirt.web.controller.support
-
- AuthenticationRequest() - Constructor for class org.springframework.xd.dirt.web.controller.support.AuthenticationRequest
-
- AuthenticationRequest(String, String) - Constructor for class org.springframework.xd.dirt.web.controller.support.AuthenticationRequest
-
- AUTHORIZATION_RULE - Static variable in class org.springframework.xd.dirt.web.config.SecurityConfiguration
-
- authorize(AuthenticationRequest, HttpServletRequest) - Method in class org.springframework.xd.dirt.web.controller.LoginController
-
- AUTO_COMMIT_OFFSET_ENABLED - Static variable in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- AutoOffsetResetStrategy - Enum in org.springframework.integration.x.kafka
-
The possible values for automatically resetting the offset of Kafka client
- available() - Method in class org.springframework.xd.shell.command.AggregateCounterCommands
-
- available() - Method in class org.springframework.xd.shell.command.CounterCommands
-
- available() - Method in class org.springframework.xd.shell.command.FieldValueCounterCommands
-
- available() - Method in class org.springframework.xd.shell.command.GaugeCommands
-
- available() - Method in class org.springframework.xd.shell.command.JobCommands
-
- available() - Method in class org.springframework.xd.shell.command.ModuleCommands
-
- available() - Method in class org.springframework.xd.shell.command.RichGaugeCommands
-
- available() - Method in class org.springframework.xd.shell.command.RuntimeCommands
-
- available() - Method in class org.springframework.xd.shell.command.StreamCommands
-
- AvailableSocketPorts - Class in org.springframework.xd.test.fixtures.util
-
Utility class to find available server ports.
- cacheEventExpression(String) - Method in class org.springframework.xd.test.fixtures.GemFireSource
-
Set the cache key.
- CacheServer - Class in org.springframework.xd.gemfire.server
-
A simple driver class to run a Gemfire cache server.
- CacheServer() - Constructor for class org.springframework.xd.gemfire.server.CacheServer
-
- calculate(DeploymentUnit, ModuleDeploymentPropertiesProvider<ModuleDeploymentProperties>, Collection<ModuleDeploymentStatus>) - Method in class org.springframework.xd.dirt.server.admin.deployment.DefaultDeploymentUnitStateCalculator
-
For a given deployment unit (stream or job) calculate the overall status.
- calculate(DeploymentUnit, ModuleDeploymentPropertiesProvider<ModuleDeploymentProperties>, Collection<ModuleDeploymentStatus>) - Method in interface org.springframework.xd.dirt.server.admin.deployment.DeploymentUnitStateCalculator
-
For a given deployment unit (stream or job) calculate the overall status.
- calculateColumnWidths() - Method in class org.springframework.xd.shell.util.Table
-
- canConvertFrom(Message<?>, Class<?>) - Method in class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
- canConvertTo(Object, MessageHeaders) - Method in class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
Not supported by default
- canRead(EvaluationContext, Object, String) - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor
-
- canRead(EvaluationContext, Object, String) - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor.MessageOptimalPropertyAccessor
-
- canRead(EvaluationContext, Object, String) - Method in class org.springframework.xd.tuple.spel.TuplePropertyAccessor
-
- canWrite(EvaluationContext, Object, String) - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor
-
- canWrite(EvaluationContext, Object, String) - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor.MessageOptimalPropertyAccessor
-
- canWrite(EvaluationContext, Object, String) - Method in class org.springframework.xd.tuple.spel.TuplePropertyAccessor
-
- CassandraConfiguration - Class in org.springframework.xd.cassandra
-
- CassandraConfiguration() - Constructor for class org.springframework.xd.cassandra.CassandraConfiguration
-
- CassandraConnectionMixin - Class in org.springframework.xd.cassandra.mixins
-
- CassandraConnectionMixin() - Constructor for class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- CassandraSinkConfiguration - Class in org.springframework.xd.cassandra
-
- CassandraSinkConfiguration() - Constructor for class org.springframework.xd.cassandra.CassandraSinkConfiguration
-
- cassandraSinkMessageHandler() - Method in class org.springframework.xd.cassandra.CassandraSinkConfiguration
-
- CassandraSinkOptionsMetadata - Class in org.springframework.xd.cassandra
-
- CassandraSinkOptionsMetadata() - Constructor for class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- cat(String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- chain(SingleNodeApplication, String, String) - Static method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainSupport
-
- chain(SingleNodeApplication, String, String, String) - Static method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainSupport
-
- chainConsumer(SingleNodeApplication, String, String) - Static method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainSupport
-
- chainConsumer(SingleNodeApplication, String, String, String) - Static method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainSupport
-
- chainProducer(SingleNodeApplication, String, String) - Static method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainSupport
-
- chainProducer(SingleNodeApplication, String, String, String) - Static method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainSupport
-
- ChannelNode - Class in org.springframework.xd.dirt.stream.dsl
-
- ChannelNode(ChannelType, int, int, List<String>, List<String>) - Constructor for class org.springframework.xd.dirt.stream.dsl.ChannelNode
-
- ChannelType - Enum in org.springframework.xd.dirt.stream.dsl
-
- checkpoint() - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Indicate that a piece of the DSL has been successfully processed.
- CheckpointedJobDefinitionException - Exception in org.springframework.xd.dirt.job.dsl
-
An extension of JobSpecificationException that remembers the point up to which parsing went OK (signaled by a '*' in
the dumped message).
- CheckpointedJobDefinitionException(String, int, int, int, List<Token>, JobDSLMessage, Object...) - Constructor for exception org.springframework.xd.dirt.job.dsl.CheckpointedJobDefinitionException
-
Construct a new exception
- CheckpointedStreamDefinitionException - Exception in org.springframework.xd.dirt.stream.dsl
-
An extension of StreamDefinitionException that remembers the point up to which parsing went OK (signaled by a '*' in
the dumped message).
- CheckpointedStreamDefinitionException(String, int, int, int, List<Token>, XDDSLMessages, Object...) - Constructor for exception org.springframework.xd.dirt.stream.dsl.CheckpointedStreamDefinitionException
-
Construct a new exception
- chgrp(boolean, String, String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- childEvent(CuratorFramework, PathChildrenCacheEvent) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ContainerListener
- ChildPathIterator<T> - Class in org.springframework.xd.dirt.zookeeper
-
Iterator over ChildData
instances that are managed by PathChildrenCache
.
- ChildPathIterator(Converter<ChildData, T>, PathChildrenCache) - Constructor for class org.springframework.xd.dirt.zookeeper.ChildPathIterator
-
Construct a ChildPathIterator.
- chmod(boolean, String, String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- chown(boolean, String, String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- CHUNK_EVENTS_SUFFIX - Static variable in interface org.springframework.xd.dirt.plugins.job.support.listener.XDJobListenerConstants
-
- ChunkContextInfo - Class in org.springframework.xd.dirt.plugins.job.support.listener
-
- ChunkContextInfo() - Constructor for class org.springframework.xd.dirt.plugins.job.support.listener.ChunkContextInfo
-
- ClasspathEnvironmentProvider - Class in org.springframework.batch.step.tasklet.x
-
- ClasspathEnvironmentProvider(ConfigurableEnvironment, Class<?>) - Constructor for class org.springframework.batch.step.tasklet.x.ClasspathEnvironmentProvider
-
- clean(String, boolean) - Method in interface org.springframework.xd.dirt.integration.bus.BusCleaner
-
Clean up all resources for the supplied stream/job.
- clean(String, boolean) - Method in class org.springframework.xd.dirt.integration.bus.rabbit.RabbitBusCleaner
-
- clean(String, String, String, String, String, String, boolean) - Method in class org.springframework.xd.dirt.integration.bus.rabbit.RabbitBusCleaner
-
- clean(String, String, String, String, String, String) - Method in class org.springframework.xd.dirt.rest.JobsController
-
- clean(String, String, String, String, String, String) - Method in class org.springframework.xd.dirt.rest.StreamsController
-
- cleanBusResources(String) - Method in interface org.springframework.xd.rest.client.ResourceOperations
-
Remove any bus resources that cannot be automatically removed during undeploy.
- cleanRabbitBus(String, String, String, String, String, String, boolean) - Method in class org.springframework.xd.dirt.rest.XDController
-
- cleanup() - Method in class org.springframework.xd.test.fixtures.AbstractMetricSink
-
- cleanup() - Method in interface org.springframework.xd.test.fixtures.Disposable
-
Free up resources that this fixture may have created.
- cleanup() - Method in class org.springframework.xd.test.fixtures.DisposableFileSupport
-
- cleanup() - Method in class org.springframework.xd.test.fixtures.DisposableMailSupport
-
- cleanup() - Method in class org.springframework.xd.test.fixtures.FileSource
-
- cleanup() - Method in class org.springframework.xd.test.fixtures.FtpSink
-
- cleanup() - Method in class org.springframework.xd.test.fixtures.FtpSource
-
- cleanup() - Method in class org.springframework.xd.test.fixtures.JdbcSink
-
If using a in memory database this method will shutdown the database.
- cleanup() - Method in class org.springframework.xd.test.fixtures.JdbcSource
-
- cleanup() - Method in class org.springframework.xd.test.fixtures.TcpSink
-
- cleanup() - Static method in class org.springframework.xd.test.RandomConfigurationSupport
-
- cleanupResource() - Method in class org.springframework.xd.test.AbstractExternalResourceTestSupport
-
- cleanupResource() - Method in class org.springframework.xd.test.kafka.KafkaTestSupport
-
- cleanupResource() - Method in class org.springframework.xd.test.mqtt.MqttTestSupport
-
- cleanupResource() - Method in class org.springframework.xd.test.rabbit.RabbitAdminTestSupport
-
- cleanupResource() - Method in class org.springframework.xd.test.rabbit.RabbitTestSupport
-
- cleanupResource() - Method in class org.springframework.xd.test.redis.RedisTestSupport
-
- clear() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- clear() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- clear() - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- clear() - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- clearConnectionListeners() - Method in class org.springframework.xd.dirt.integration.rabbit.LocalizedQueueConnectionFactory
-
- ClientApplication - Class in org.springframework.xd.yarn
-
Cli for controlling XD instances on an application master.
- ClientApplication() - Constructor for class org.springframework.xd.yarn.ClientApplication
-
- ClientTcpConnectionFactoryOptionsMetadataMixin - Class in org.springframework.xd.tcp
-
Mixin for options metadata that configure a client tcp connection factory.
- ClientTcpConnectionFactoryOptionsMetadataMixin() - Constructor for class org.springframework.xd.tcp.ClientTcpConnectionFactoryOptionsMetadataMixin
-
- close() - Method in class org.springframework.integration.x.kafka.WindowingOffsetManager
-
- close() - Method in class org.springframework.xd.batch.item.hadoop.HdfsTextItemWriter
-
- close() - Method in class org.springframework.xd.batch.item.hadoop.SimpleHdfsTextItemWriter
-
- close() - Method in class org.springframework.xd.dirt.server.singlenode.SingleNodeApplication
-
- close() - Method in class org.springframework.xd.gemfire.server.LoggingCacheListener
-
- close() - Method in class org.springframework.xd.hadoop.fs.DatasetWriter
-
- close() - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriter
-
- close() - Method in interface org.springframework.xd.hadoop.fs.HdfsWriter
-
- closeReader(Reader) - Static method in class org.springframework.xd.shell.util.CommonUtils
-
- code() - Method in enum org.springframework.integration.x.kafka.AutoOffsetResetStrategy
-
- codec() - Method in class org.springframework.xd.dirt.server.MessageBusExtensionsConfiguration
-
- codec - Variable in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- codecs - Variable in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- collect(Resource, List<ModuleDefinition>) - Method in class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
- collect(ConfigurableListableBeanFactory) - Method in class org.springframework.xd.module.options.DefaultModuleOptionsMetadataCollector
-
- collectionName(String) - Method in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
Sets the name of the collection where the data will be written.
- collectionToCommaDelimitedString(Collection<String>) - Static method in class org.springframework.xd.shell.util.CommonUtils
-
Convert a List of Strings to a comma delimited String.
- COLUMN_1 - Static variable in class org.springframework.xd.shell.util.UiUtils
-
- COLUMN_2 - Static variable in class org.springframework.xd.shell.util.UiUtils
-
- COLUMN_3 - Static variable in class org.springframework.xd.shell.util.UiUtils
-
- COLUMN_4 - Static variable in class org.springframework.xd.shell.util.UiUtils
-
- COLUMN_5 - Static variable in class org.springframework.xd.shell.util.UiUtils
-
- COLUMN_6 - Static variable in class org.springframework.xd.shell.util.UiUtils
-
- columns(String) - Method in class org.springframework.xd.test.fixtures.JdbcSink
-
allows a user to set the columns (comma delimited list) that the sink will write its results to.
- commandLineListener() - Method in class org.springframework.xd.dirt.server.container.ContainerBootstrapContext
-
- CommandLinePropertySourceOverridingListener<T extends CommonOptions> - Class in org.springframework.xd.dirt.server.options
-
An ApplicationListener
that will parse command line options and also replace the default boot commandline
PropertySource
with those values.
- CommandLinePropertySourceOverridingListener(T) - Constructor for class org.springframework.xd.dirt.server.options.CommandLinePropertySourceOverridingListener
-
- CommonDistributedOptions - Class in org.springframework.xd.dirt.server.options
-
Holds options that are common to both admin and container servers, when used in distributed mode.
- CommonDistributedOptions() - Constructor for class org.springframework.xd.dirt.server.options.CommonDistributedOptions
-
- CommonOptions - Class in org.springframework.xd.dirt.server.options
-
Base class for command line options that are common to absolutely every setup (single and distributed).
- CommonOptions() - Constructor for class org.springframework.xd.dirt.server.options.CommonOptions
-
- CommonUtils - Class in org.springframework.xd.shell.util
-
Contains common non-ui related helper methods for rendering text to the console.
- compareTo(Admin) - Method in class org.springframework.xd.dirt.cluster.Admin
- compareTo(AdminAttributes) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
Compares using the adminId.
- compareTo(Container) - Method in class org.springframework.xd.dirt.cluster.Container
- compareTo(ContainerAttributes) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
Compares using the containerId.
- compareTo(BaseDefinition) - Method in class org.springframework.xd.dirt.core.BaseDefinition
-
- compareTo(ModuleMetadata) - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata
-
- compareTo(ModuleMetadata.Id) - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata.Id
-
- compareTo(ModuleRedeployer.ModuleDeployment) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer.ModuleDeployment
-
- compareTo(Job) - Method in class org.springframework.xd.dirt.stream.Job
-
- compareTo(Stream) - Method in class org.springframework.xd.dirt.stream.Stream
-
- compareTo(ModuleDefinition) - Method in class org.springframework.xd.module.ModuleDefinition
-
- compareTo(ModuleDescriptor) - Method in class org.springframework.xd.module.ModuleDescriptor
- compareTo(ModuleDescriptor.Key) - Method in class org.springframework.xd.module.ModuleDescriptor.Key
- complete(CompletionKind, String, int) - Method in class org.springframework.xd.dirt.stream.completion.CompletionProvider
-
- CompletionConverter - Class in org.springframework.xd.shell.converter
-
A converter that provides DSL completion wherever parts of stream definitions may appear.
- CompletionConverter() - Constructor for class org.springframework.xd.shell.converter.CompletionConverter
-
- CompletionExpansionStrategy - Interface in org.springframework.xd.dirt.stream.completion
-
Used to enhance a well formed stream definition by adding yet more text to it (e.g. adding more options to a
module).
- CompletionKind - Enum in org.springframework.xd.rest.domain
-
Used to represent the context in which the code completion facility is invoked.
- CompletionOperations - Interface in org.springframework.xd.rest.client
-
Provides access to the dsl completion facility.
- completionOperations() - Method in class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- completionOperations() - Method in interface org.springframework.xd.rest.client.SpringXDOperations
-
Returns the portion of the API for providing code completion.
- CompletionProvider - Class in org.springframework.xd.dirt.stream.completion
-
Provides code completion on a (maybe ill-formed) stream definition.
- CompletionProvider(XDParser, List<CompletionRecoveryStrategy<? extends Exception>>, List<CompletionExpansionStrategy>) - Constructor for class org.springframework.xd.dirt.stream.completion.CompletionProvider
-
Construct a new CompletionProvider given a list of recovery strategies and expansion strategies.
- CompletionRecoveryStrategy<E extends java.lang.Exception> - Interface in org.springframework.xd.dirt.stream.completion
-
Used to provide completions on ill-formed stream definitions, after an initial (failed) parse.
- completions(CompletionKind, String, int) - Method in class org.springframework.xd.dirt.rest.CompletionsController
-
Return a list of possible completions given a prefix string that the user has started typing.
- completions(CompletionKind, String, int) - Method in interface org.springframework.xd.rest.client.CompletionOperations
-
Return the list of completions that are compatible with the given DSL prefix.
- completions(CompletionKind, String, int) - Method in class org.springframework.xd.rest.client.impl.CompletionTemplate
-
- CompletionsController - Class in org.springframework.xd.dirt.rest
-
Exposes completion for stream-like definitions as a REST endpoint.
- CompletionsController(CompletionProvider) - Constructor for class org.springframework.xd.dirt.rest.CompletionsController
-
- CompletionTemplate - Class in org.springframework.xd.rest.client.impl
-
- compose(String, ModuleType, String, boolean) - Method in class org.springframework.xd.dirt.module.support.ModuleDefinitionService
-
- compose(String, String, boolean) - Method in class org.springframework.xd.dirt.rest.ModulesController
-
Create (install) a new module, by way of composition.
- compose(ModuleType, String, String, boolean) - Method in class org.springframework.xd.dirt.rest.ModulesController
-
Create (install) a new module, by way of composition.
- composeChannel(ChannelStream<IN, OUT>) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapter
-
- composeChannel(ChannelStream<Buffer, Buffer>) - Method in class org.springframework.xd.integration.reactor.syslog.SyslogInboundChannelAdapter
-
- composed(String, ModuleType, String, List<ModuleDefinition>) - Static method in class org.springframework.xd.module.ModuleDefinitions
-
Create a new definition for a composed module (one where its behavior comes not from its own 'code', but from
composing pre-existing modules).
- composedJobParser - Variable in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- ComposedJobUtil - Class in org.springframework.xd.dirt.job.dsl
-
- ComposedJobUtil() - Constructor for class org.springframework.xd.dirt.job.dsl.ComposedJobUtil
-
- composeModule(String, String, boolean) - Method in class org.springframework.xd.rest.client.impl.ModuleTemplate
-
- composeModule(String, String, boolean) - Method in interface org.springframework.xd.rest.client.ModuleOperations
-
Compose a new composed Module.
- composeModule(String, String, boolean) - Method in class org.springframework.xd.shell.command.ModuleCommands
-
- CompositeMessageConverterFactory - Class in org.springframework.xd.dirt.integration.bus.converter
-
A factory for creating an instance of CompositeMessageConverter
for a given target MIME type
- CompositeMessageConverterFactory(Collection<AbstractFromMessageConverter>) - Constructor for class org.springframework.xd.dirt.integration.bus.converter.CompositeMessageConverterFactory
-
- CompositeModule - Class in org.springframework.xd.module.core
-
- CompositeModule(ModuleDescriptor, ModuleDeploymentProperties, List<Module>) - Constructor for class org.springframework.xd.module.core.CompositeModule
-
- CompositeModuleDefinition - Class in org.springframework.xd.module
-
A module definition for a module which has been custom created as the composition of several other
modules (either
simple
or
themselves
composed
.
- COMPRESS - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
Compression enabled.
- COMPRESSION_CODEC - Static variable in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- concatArrays(List<long[]>, int, int) - Static method in class org.springframework.xd.analytics.metrics.core.MetricUtils
-
Concatenate size
many values from the passed in arrays, starting at offset start
.
- CONCURRENCY - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
The minimum number of concurrent deliveries.
- config() - Method in class org.springframework.xd.dirt.web.config.SecurityConfiguration
-
- ConfigCommands - Class in org.springframework.xd.shell.command
-
Defines several shell commands in order to configure the shell itself.
- ConfigCommands() - Constructor for class org.springframework.xd.shell.command.ConfigCommands
-
- ConfigLocations - Class in org.springframework.xd.dirt.util
-
Static constants for configuration locations.
- Configuration - Class in org.springframework.xd.shell
-
Encapsulates various configuration properties for the shell such as
Target
and the configurable
TimeZone
.
- Configuration() - Constructor for class org.springframework.xd.shell.Configuration
-
- ConfigurationAware - Class in org.springframework.xd.shell.hadoop
-
Utility base class for components monitoring Configuration
changes in order to update state.
- ConfigurationAware() - Constructor for class org.springframework.xd.shell.hadoop.ConfigurationAware
-
- configurationChanged() - Method in class org.springframework.xd.shell.hadoop.ConfigurationAware
-
Called before invoking a command in case the configuration changed.
- configurationChanged() - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- ConfigurationCommands - Class in org.springframework.xd.shell.hadoop
-
Command for configuring the global Hadoop Configuration
object used by other components.
- ConfigurationCommands() - Constructor for class org.springframework.xd.shell.hadoop.ConfigurationCommands
-
- ConfigurationModifiedEvent - Class in org.springframework.xd.shell.hadoop
-
Notification event that a Configuration object (attached) has been modified.
- ConfigurationModifiedEvent(Configuration) - Constructor for class org.springframework.xd.shell.hadoop.ConfigurationModifiedEvent
-
- configure(HttpSecurity) - Method in class org.springframework.xd.dirt.web.config.SecurityConfiguration
-
- configureMessageConverter(MimeType) - Method in class org.springframework.xd.dirt.plugins.spark.streaming.SparkStreamingChannel
-
Configure message converter for this direct channel.
- configureMessageConverters(AbstractMessageChannel, MimeType, ClassLoader) - Method in class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionSupport
-
Configure the message converters for the given message channel and content type.
- configureModuleApplicationContext(SimpleModuleDefinition) - Method in class org.springframework.xd.module.core.JavaConfiguredModule
-
- configureModuleApplicationContext(SimpleModuleDefinition) - Method in class org.springframework.xd.module.core.ResourceConfiguredModule
-
- configureModuleApplicationContext(SimpleModuleDefinition) - Method in class org.springframework.xd.module.core.SimpleModule
-
Subclasses implement this method to configure the application context from sources contained in the
ModuleDefinition
- configureModuleInputChannelMessageConverters(Module) - Method in class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionSupport
-
Configure message converters for the given module's input channel.
- configureModuleOutputChannelMessageConverters(Module) - Method in class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionSupport
-
Configure message converters for the given module's output channel.
- configurer() - Method in class org.springframework.xd.dirt.rest.RestConfiguration
-
- configureZooKeeperConnection(ZooKeeperConnection) - Method in interface org.springframework.xd.dirt.zookeeper.ZooKeeperConnectionConfigurer
-
- ConfigUtil - Class in org.springframework.xd.integration.util
-
Tools to create and read configuration files for an environment deployed on EC2.
- ConfigUtil() - Constructor for class org.springframework.xd.integration.util.ConfigUtil
-
- ConnectionFactorySettings - Class in org.springframework.xd.dirt.integration.rabbit
-
Configures the connection factory used by the rabbit message bus.
- ConnectionFactorySettings() - Constructor for class org.springframework.xd.dirt.integration.rabbit.ConnectionFactorySettings
-
- ConnectionFactorySettings.RabbitPropertiesLoader - Class in org.springframework.xd.dirt.integration.rabbit
-
- ConnectionFactorySettings.RabbitPropertiesLoader() - Constructor for class org.springframework.xd.dirt.integration.rabbit.ConnectionFactorySettings.RabbitPropertiesLoader
-
- connectionProperties - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- ConsoleUserInput - Class in org.springframework.xd.shell.command
-
- ConsoleUserInput() - Constructor for class org.springframework.xd.shell.command.ConsoleUserInput
-
- constructDLQName(String) - Static method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
For bus implementations that support dead lettering, construct the name of the dead letter entity for the
underlying pipe name.
- constructPipeName(String, int) - Static method in class org.springframework.xd.dirt.integration.bus.BusUtils
-
Construct a pipe name from the group and index.
- constructTapPrefix(String) - Static method in class org.springframework.xd.dirt.integration.bus.BusUtils
-
- consumeMessage(DeploymentMessage, StreamDeployer, JobDeployer) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentMessageConsumer
-
- consumeMessage(DeploymentMessage) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentMessageConsumer
-
Consume the deployment message and delegate to the deployer.
- CONSUMER - Static variable in class org.springframework.xd.dirt.integration.bus.Binding
-
- CONSUMER_REQUEST_REPLY_PROPERTIES - Static variable in class org.springframework.xd.dirt.integration.bus.local.LocalMessageBus
-
- CONSUMER_RETRY_PROPERTIES - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- CONSUMER_STANDARD_PROPERTIES - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
The set of properties every bus implementation must support (or at least tolerate).
- Container - Class in org.springframework.xd.dirt.cluster
-
Domain object for an XD container.
- Container(String, Map<String, String>) - Constructor for class org.springframework.xd.dirt.cluster.Container
-
Construct a Container object.
- CONTAINER_ATTRIBUTES_PREFIX - Static variable in class org.springframework.xd.dirt.server.container.ContainerServerApplication
-
- CONTAINER_ID_KEY - Static variable in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- CONTAINER_PROFILE - Static variable in class org.springframework.xd.dirt.util.XdProfiles
-
- CONTAINER_TOKEN - Static variable in class org.springframework.xd.integration.util.ConfigUtil
-
- ContainerAttributes - Class in org.springframework.xd.dirt.cluster
-
Metadata for a Container instance.
- ContainerAttributes() - Constructor for class org.springframework.xd.dirt.cluster.ContainerAttributes
-
Default constructor generates a random id.
- ContainerAttributes(String) - Constructor for class org.springframework.xd.dirt.cluster.ContainerAttributes
-
Constructor to be called when the id is already known.
- ContainerAttributes(Map<? extends String, ? extends String>) - Constructor for class org.springframework.xd.dirt.cluster.ContainerAttributes
-
Constructor to be called when the attributes are already known.
- containerAttributes() - Method in class org.springframework.xd.dirt.server.container.ContainerServerApplication
-
- ContainerBootstrapContext - Class in org.springframework.xd.dirt.server.container
-
Package private class to bootstrap the Container process.
- ContainerBootstrapContext(T) - Constructor for class org.springframework.xd.dirt.server.container.ContainerBootstrapContext
-
- ContainerConfiguration - Class in org.springframework.xd.dirt.server.container
-
Container Application Context
- ContainerConfiguration() - Constructor for class org.springframework.xd.dirt.server.container.ContainerConfiguration
-
- containerContext() - Method in class org.springframework.xd.dirt.server.singlenode.SingleNodeApplication
-
- ContainerFilter - Interface in org.springframework.xd.dirt.cluster
-
A filter interface that applies filter for the given containers and returns
eligible containers for deployment.
- ContainerInfoPlugin - Class in org.springframework.xd.dirt.plugins
-
A plugin that exposes information about the container to the Environment.
- ContainerInfoPlugin(ContainerAttributes) - Constructor for class org.springframework.xd.dirt.plugins.ContainerInfoPlugin
-
- ContainerListener - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
Listener implementation that is invoked when containers are added/removed/modified.
- ContainerListener(ZooKeeperConnection, ContainerRepository, StreamFactory, JobFactory, PathChildrenCache, PathChildrenCache, PathChildrenCache, ContainerMatcher, ModuleDeploymentWriter, DeploymentUnitStateCalculator, ScheduledExecutorService, AtomicLong) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.ContainerListener
-
Construct a ContainerListener.
- ContainerMatcher - Class in org.springframework.xd.dirt.server.admin.deployment
-
Implementation of a Container matching strategy that returns a collection of containers to deploy a
ModuleDescriptor
to.
- ContainerMatcher() - Constructor for class org.springframework.xd.dirt.server.admin.deployment.ContainerMatcher
-
Creates a container matcher instance and prepares the SpEL evaluation context to support Map properties directly.
- ContainerMatcher(ContainerFilter...) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.ContainerMatcher
-
Creates a container matcher instance with the provided
ContainerFilter
s
and prepares the SpEL evaluation context to support Map properties directly.
- ContainerMatchingModuleRedeployer - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
- ContainerMatchingModuleRedeployer(ZooKeeperConnection, ContainerRepository, StreamFactory, JobFactory, PathChildrenCache, PathChildrenCache, PathChildrenCache, ContainerMatcher, ModuleDeploymentWriter, DeploymentUnitStateCalculator) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.ContainerMatchingModuleRedeployer
-
Constructs ArrivingContainerModuleRedeployer
- ContainerOptions - Class in org.springframework.xd.dirt.server.options
-
Holds configuration options that are valid for the Container node, when using distributed mode.
- ContainerOptions() - Constructor for class org.springframework.xd.dirt.server.options.ContainerOptions
-
- containerRegistrar() - Method in class org.springframework.xd.dirt.server.container.ContainerConfiguration
-
- ContainerRegistrar - Class in org.springframework.xd.dirt.server.container
-
An instance of this class, registered as a bean in the context for a Container, will handle the registration of that
Container's metadata with ZooKeeper by creating an ephemeral node.
- ContainerRegistrar(ZooKeeperConnection, ContainerAttributes, ContainerRepository, DeploymentListener) - Constructor for class org.springframework.xd.dirt.server.container.ContainerRegistrar
-
- ContainerRepository - Interface in org.springframework.xd.dirt.container.store
-
Repository for persisting
Container
entities.
- ContainerResolver - Class in org.springframework.xd.integration.fixtures
-
Resolve runtime hosts for modules.
- ContainerResolver(URL, Map<String, String>, String) - Constructor for class org.springframework.xd.integration.fixtures.ContainerResolver
-
- CONTAINERS - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of containers node.
- ContainersController - Class in org.springframework.xd.dirt.rest
-
Handles interaction with the runtime containers/and its modules.
- ContainersController(ContainerRepository) - Constructor for class org.springframework.xd.dirt.rest.ContainersController
-
- ContainerServerApplication - Class in org.springframework.xd.dirt.server.container
-
The boot application class for a Container server.
- ContainerServerApplication() - Constructor for class org.springframework.xd.dirt.server.container.ContainerServerApplication
-
- ContainerShutdownException - Exception in org.springframework.xd.dirt.cluster
-
Exception thrown when shutting down the container
from admin server.
- ContainerShutdownException() - Constructor for exception org.springframework.xd.dirt.cluster.ContainerShutdownException
-
Construct a ContainerShutdownException
.
- ContainerShutdownException(String) - Constructor for exception org.springframework.xd.dirt.cluster.ContainerShutdownException
-
Construct a ContainerShutdownException
with a description.
- containsKey(Object) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- containsKey(Object) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- containsKey(Object) - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- containsKey(Object) - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- containsValue(Object) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- containsValue(Object) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- containsValue(Object) - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- containsValue(Object) - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- contentLength() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- ControlFile - Class in org.springframework.xd.greenplum.support
-
- ControlFile() - Constructor for class org.springframework.xd.greenplum.support.ControlFile
-
- ControlFile.OutputMode - Enum in org.springframework.xd.greenplum.support
-
- ControlFileFactoryBean - Class in org.springframework.xd.greenplum.support
-
- ControlFileFactoryBean() - Constructor for class org.springframework.xd.greenplum.support.ControlFileFactoryBean
-
- ConversionException - Exception in org.springframework.xd.dirt.integration.bus.converter
-
Exception thrown when an error is encountered during message conversion.
- ConversionException(String) - Constructor for exception org.springframework.xd.dirt.integration.bus.converter.ConversionException
-
- ConversionException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.integration.bus.converter.ConversionException
-
- convert(String) - Method in class org.springframework.xd.dirt.plugins.stream.CustomMimeTypeConverter
-
- convert(ILoggingEvent) - Method in class org.springframework.xd.dirt.util.logging.CustomLoggerConverter
-
- convert(ILoggingEvent) - Method in class org.springframework.xd.dirt.util.logging.VersionPatternConverter
-
- convert(ChildData) - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperUtils.StripPathConverter
- convert(FieldSet) - Method in class org.springframework.xd.mongodb.FieldSetConverter
-
- convert(Tuple) - Method in class org.springframework.xd.mongodb.TupleWriteConverter
-
- convert(Properties) - Static method in class org.springframework.xd.rest.domain.support.DeploymentPropertiesFormat
-
Convert a Properties to a Map with String keys and values.
- convert(byte[]) - Method in class org.springframework.xd.tuple.JsonBytesToTupleConverter
-
- convert(JsonNode) - Method in class org.springframework.xd.tuple.JsonNodeToTupleConverter
-
- convert(String) - Method in class org.springframework.xd.tuple.JsonStringToTupleConverter
-
- convert(String) - Method in class org.springframework.xd.tuple.StringToDateConverter
-
- convert(Tuple) - Method in class org.springframework.xd.tuple.TupleToJsonStringConverter
-
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.xd.dirt.integration.bus.converter.ByteArrayToStringMessageConverter
-
Don't need to manipulate message headers.
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.xd.dirt.integration.bus.converter.JavaToSerializedMessageConverter
-
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.xd.dirt.integration.bus.converter.JsonToPojoMessageConverter
-
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.xd.dirt.integration.bus.converter.JsonToTupleMessageConverter
-
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.xd.dirt.integration.bus.converter.PojoToJsonMessageConverter
-
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.xd.dirt.integration.bus.converter.PojoToStringMessageConverter
-
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.xd.dirt.integration.bus.converter.SerializedToJavaMessageConverter
-
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.xd.dirt.integration.bus.converter.StringToByteArrayMessageConverter
-
Don't need to manipulate message headers.
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.xd.dirt.integration.bus.converter.TupleToJsonMessageConverter
-
- convertFromText(String, Class<?>, String) - Method in class org.springframework.xd.shell.converter.CompletionConverter
-
- convertFromText(String, Class<?>, String) - Method in class org.springframework.xd.shell.converter.ExistingXDEntityConverter
-
- convertFromText(String, Class<?>, String) - Method in class org.springframework.xd.shell.converter.MediaTypeConverter
-
- convertFromText(String, Class<?>, String) - Method in class org.springframework.xd.shell.converter.NumberFormatConverter
-
- convertFromText(String, Class<?>, String) - Method in class org.springframework.xd.shell.converter.QualifiedModuleNameConverter
-
- convertJobGrabToText(Graph) - Method in class org.springframework.xd.dirt.rest.ToolsController
-
Convert a graph format into DSL text format.
- convertJsonToList(String) - Static method in class org.springframework.xd.shell.util.JsonUtil
-
- convertJsonToMap(String) - Static method in class org.springframework.xd.shell.util.JsonUtil
-
- convertToJson(Object) - Static method in class org.springframework.xd.shell.util.JsonUtil
-
- copy(byte[], FSDataOutputStream) - Method in class org.springframework.xd.batch.item.hadoop.SimpleHdfsTextItemWriter
-
Simple not optimized copy
- copy(byte[], FSDataOutputStream) - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriter
-
Simple not optimized copy
- copyFileToRemote(String, String, URI, File, long) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Copy a file from test machine to remote machine.
- copyFromLocal(String, String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- copyHeadersIfAbsent(Map<String, Object>) - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- copyMergeToLocal(String, String, boolean) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- copyOf() - Method in class org.springframework.xd.dirt.stream.dsl.ChannelNode
-
- copyOf() - Method in class org.springframework.xd.dirt.stream.dsl.SinkChannelNode
-
- copyOf() - Method in class org.springframework.xd.dirt.stream.dsl.SourceChannelNode
-
- copyToLocal(String, String, boolean, boolean) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- count() - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- count() - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- count() - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- count() - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- COUNT - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
The number of consumers, i.e.
- count() - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- count() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- count() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- count() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- count() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- count(boolean, String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- count() - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
- count() - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- COUNT_KEY - Static variable in class org.springframework.xd.module.ModuleDeploymentProperties
-
Key for the count
property.
- Counter - Class in org.springframework.xd.analytics.metrics.core
-
Represents the data stored in a valueer of a single value.
- Counter(String) - Constructor for class org.springframework.xd.analytics.metrics.core.Counter
-
Construct a new Counter given a name
- Counter(String, long) - Constructor for class org.springframework.xd.analytics.metrics.core.Counter
-
Construct a new Counter given a name and a initial value of the value
- CounterCommands - Class in org.springframework.xd.shell.command
-
Commands for interacting with Counter analytics.
- CounterCommands() - Constructor for class org.springframework.xd.shell.command.CounterCommands
-
- CounterOperations - Interface in org.springframework.xd.rest.client
-
Interface defining operations available when dealing with Counters.
- counterOperations() - Method in class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- counterOperations() - Method in interface org.springframework.xd.rest.client.SpringXDOperations
-
Returns the portion of the API for interaction with Counters.
- CounterRepository - Interface in org.springframework.xd.analytics.metrics.core
-
Interface for repositories that now how to deal with
Counter
s.
- CounterResource - Class in org.springframework.xd.rest.domain.metrics
-
The REST representation of a Counter.
- CounterResource() - Constructor for class org.springframework.xd.rest.domain.metrics.CounterResource
-
No-arg constructor for serialization frameworks.
- CounterResource(String, long) - Constructor for class org.springframework.xd.rest.domain.metrics.CounterResource
-
- CountersController - Class in org.springframework.xd.dirt.rest.metrics
-
Exposes representations of
Counter
s.
- CountersController(CounterRepository) - Constructor for class org.springframework.xd.dirt.rest.metrics.CountersController
-
- counterSink(String) - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Constructs a Counter Sink for capturing count metrics.
- CounterSink - Class in org.springframework.xd.test.fixtures
-
Fixture class for an "simple" counter.
- CounterSink(JLineShellComponent, String) - Constructor for class org.springframework.xd.test.fixtures.CounterSink
-
- CounterTemplate - Class in org.springframework.xd.rest.client.impl
-
- CounterTemplate(AbstractTemplate) - Constructor for class org.springframework.xd.rest.client.impl.CounterTemplate
-
- countTopLevelJobExecutions() - Method in class org.springframework.xd.dirt.job.dao.XdJdbcSearchableJobExecutionDao
-
- countTopLevelJobExecutions() - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobService
-
- cp(String, String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- create(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryFieldValueCounterRepository
-
- create(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryGaugeRepository
-
- create(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- create(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryRichGaugeRepository
-
- createAndDeployStream(StreamDefinition) - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
Create and deploy a stream.
- createAndRegisterChannel(String) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport.SharedChannelProvider
-
- createClassPath() - Method in class org.springframework.batch.step.tasklet.x.ClasspathEnvironmentProvider
-
- createCommand() - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- createCommand() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- createCommand() - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- createConfiguration(Map<String, String>) - Static method in class org.springframework.xd.sqoop.SqoopRunner
-
- createConnection() - Method in class org.springframework.xd.dirt.integration.rabbit.LocalizedQueueConnectionFactory
-
- createConnectionFactory(String) - Method in class org.springframework.xd.dirt.integration.rabbit.LocalizedQueueConnectionFactory
-
Create a dedicated connection factory for the address.
- createDataFileOnRemote(String, String, String, String, String, int) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Creates a file on a remote EC2 machine with the payload as its contents.
- createDefinition(String, String) - Method in class org.springframework.xd.dirt.rest.JobsController
-
- createDefinition(String, String) - Method in class org.springframework.xd.dirt.rest.StreamsController
-
- createDefinition(String, String) - Method in class org.springframework.xd.dirt.rest.XDController
-
- createDefinition(String, String) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- createDefinition(String, String) - Method in class org.springframework.xd.dirt.stream.JobDeployer
-
- createDefinition(String, String) - Method in class org.springframework.xd.dirt.stream.StreamDeployer
- createExternalReadableTable(LoadConfiguration, String, List<String>) - Static method in class org.springframework.xd.greenplum.support.SqlUtils
-
- createFinalArguments(String, String, List<String>, boolean, Map<String, String>, List<String>) - Static method in class org.springframework.xd.sqoop.SqoopRunner
-
- createHandler() - Method in class org.springframework.xd.integration.hadoop.config.HdfsStoreMessageHandlerFactoryBean
-
- createInstance() - Method in class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- createJob(String, Map<String, String>) - Method in class org.springframework.xd.dirt.job.JobFactory
-
Create a new instance of
Job
for the given name and
properties.
- createJob(String, String, boolean) - Method in class org.springframework.xd.rest.client.impl.JobTemplate
-
- createJob(String, String, boolean) - Method in interface org.springframework.xd.rest.client.JobOperations
-
Create a new Job, optionally deploying it.
- createJob(String, String, boolean) - Method in class org.springframework.xd.shell.command.JobCommands
-
- createJobRepository() - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- createKey() - Method in class org.springframework.xd.module.ModuleDescriptor
-
- createLocationString(String[]) - Static method in class org.springframework.xd.greenplum.support.SqlUtils
-
Converts string array to greenplum friendly string.
- createMessageListenerContainer(Properties, String, int, String, long, boolean) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- createModule(ModuleDescriptor, ModuleDeploymentProperties) - Method in class org.springframework.xd.dirt.module.ModuleDeployer
-
- createModule(ModuleDescriptor, ModuleDeploymentProperties) - Method in class org.springframework.xd.module.core.ModuleFactory
-
- createModuleDefinitions(List<ModuleDescriptor>) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
Create a list of ModuleDefinitions given the results of parsing the definition.
- createModuleDeploymentProperties(Map<String, String>, ModuleDescriptor) - Static method in class org.springframework.xd.dirt.util.DeploymentPropertiesUtility
-
- createModuleDeploymentRequestsPath(CuratorFramework, ModuleDescriptor, RuntimeModuleDeploymentProperties) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ZKDeploymentHandler
-
- createModuleDiscoveryClassLoader(Resource, ClassLoader) - Static method in class org.springframework.xd.module.options.ModuleUtils
-
Create a "simple" ClassLoader for a module, suitable for early discovery phase, before module options are known.
- createModuleRuntimeClassLoader(SimpleModuleDefinition, ModuleOptions, ClassLoader) - Static method in class org.springframework.xd.module.options.ModuleUtils
-
Create a ClassLoader suitable for running a module.
- createNamedChannelSink(String) - Method in class org.springframework.xd.dirt.test.sink.SingleNodeNamedChannelSinkFactory
-
- createNamedChannelSource(String) - Method in class org.springframework.xd.dirt.test.source.SingleNodeNamedChannelSourceFactory
-
- createOptimalAccessor(EvaluationContext, Object, String) - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor
-
- createPatternParser(String) - Method in class org.springframework.xd.dirt.util.logging.VersionPatternLayout
-
- createProperties() - Method in class org.springframework.xd.extension.script.ScriptModulePropertiesFactoryBean
-
- createProperties() - Method in class org.springframework.xd.mail.JavaMailPropertiesFactoryBean
-
- createQueue() - Method in class org.springframework.xd.test.fixtures.RabbitSource
-
Creates an instance of the queue on the rabbit broker.
- createRelative(String) - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- createRemoteDirectory(String, String, String, int) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Creates a directory on a remote machine.
- createRestTemplate(String) - Method in class org.springframework.xd.dirt.integration.rabbit.LocalizedQueueConnectionFactory
-
Create a RestTemplate for the supplied URI.
- createSharedChannel(String) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport.SharedChannelProvider
-
- createSink() - Method in class org.springframework.xd.dirt.test.process.AbstractSingleNodeProcessingChain
-
- createSink() - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChain
-
- createSink() - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainConsumer
-
- createSink() - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainProducer
-
- createSource() - Method in class org.springframework.xd.dirt.test.process.AbstractSingleNodeProcessingChain
-
- createSource() - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChain
-
- createSource() - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainConsumer
-
- createSource() - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainProducer
-
- createSqlParameterSource(FieldSet) - Method in class org.springframework.xd.batch.item.jdbc.FieldSetSqlParameterSourceProvider
-
- createSqlParameterSource(Tuple) - Method in class org.springframework.xd.tuple.batch.TupleSqlParameterSourceProvider
-
- createStream(String, Map<String, String>) - Method in class org.springframework.xd.dirt.stream.StreamFactory
-
Create a new instance of
Stream
for the given name and
properties.
- createStream(String, String, boolean) - Method in class org.springframework.xd.rest.client.impl.StreamTemplate
-
- createStream(String, String, boolean) - Method in interface org.springframework.xd.rest.client.StreamOperations
-
Create a new Stream, optionally deploying it.
- createStream(String, String, boolean) - Method in class org.springframework.xd.shell.command.StreamCommands
-
- createWriter() - Method in class org.springframework.xd.hadoop.fs.DatasetWriterFactory
-
- createWriter() - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- createWriter() - Method in interface org.springframework.xd.hadoop.fs.HdfsWriterFactory
-
- CRITERIA_KEY - Static variable in class org.springframework.xd.module.ModuleDeploymentProperties
-
Key for the criteria
property.
- CronExpression - Annotation Type in org.springframework.xd.module.options.validation
-
The annotated element must be a valid Spring cron expression (6 fields).
- CronExpression.CronValidator - Class in org.springframework.xd.module.options.validation
-
- CronExpression.CronValidator() - Constructor for class org.springframework.xd.module.options.validation.CronExpression.CronValidator
-
- CronExpression.List - Annotation Type in org.springframework.xd.module.options.validation
-
- CronValidation - Class in org.springframework.xd.rest.domain.validation
-
- CronValidation() - Constructor for class org.springframework.xd.rest.domain.validation.CronValidation
-
- CustomLoggerConverter - Class in org.springframework.xd.dirt.util.logging
-
- CustomLoggerConverter() - Constructor for class org.springframework.xd.dirt.util.logging.CustomLoggerConverter
-
- CustomMimeTypeConverter - Class in org.springframework.xd.dirt.plugins.stream
-
A custom converter for MediaType
that accepts a plain java class name as a shorthand for
application/x-java-object;type=the.qualified.ClassName
.
- CustomMimeTypeConverter() - Constructor for class org.springframework.xd.dirt.plugins.stream.CustomMimeTypeConverter
-
- CustomModuleRegistryFactoryBean - Class in org.springframework.xd.dirt.module
-
Will create a
SynchronizingModuleRegistry
for hosting custom modules if necessary, depending on the
protocol scheme (using a synchronizing registry for everything but
file://
protocol).
- CustomModuleRegistryFactoryBean(String) - Constructor for class org.springframework.xd.dirt.module.CustomModuleRegistryFactoryBean
-
- DatabaseVendorFriendlyNameFactoryBean - Class in org.springframework.xd.dirt.jdbc.util
-
A factory bean that returns a friendly string name from database metadata.
- DatabaseVendorFriendlyNameFactoryBean() - Constructor for class org.springframework.xd.dirt.jdbc.util.DatabaseVendorFriendlyNameFactoryBean
-
- DatasetDefinitionFactoryBean - Class in org.springframework.xd.hadoop.fs
-
FactoryBean that creates a default DatasetDefinition
- DatasetDefinitionFactoryBean() - Constructor for class org.springframework.xd.hadoop.fs.DatasetDefinitionFactoryBean
-
- DatasetOutboundChannelAdapterParser - Class in org.springframework.xd.integration.hadoop.config
-
Parser for the 'dataset-outbound-channel-adapter' element.
- DatasetOutboundChannelAdapterParser() - Constructor for class org.springframework.xd.integration.hadoop.config.DatasetOutboundChannelAdapterParser
-
- DatasetWriter - Class in org.springframework.xd.hadoop.fs
-
- DatasetWriter(DatasetOperations) - Constructor for class org.springframework.xd.hadoop.fs.DatasetWriter
-
- DatasetWriterFactory - Class in org.springframework.xd.hadoop.fs
-
- DatasetWriterFactory(DatasetOperations) - Constructor for class org.springframework.xd.hadoop.fs.DatasetWriterFactory
-
- DatasetWritingMessageHandlerFactoryBean - Class in org.springframework.xd.integration.hadoop.config
-
- DatasetWritingMessageHandlerFactoryBean(DatasetOperations) - Constructor for class org.springframework.xd.integration.hadoop.config.DatasetWritingMessageHandlerFactoryBean
-
- dateFormat(String) - Method in class org.springframework.xd.integration.hadoop.expression.MessageExpressionMethods.MessageWrappedMessage
-
- DateFormat - Annotation Type in org.springframework.xd.module.options.validation
-
The annotated must be a valid SimpleDateFormat
pattern.
- DateFormat.DateFormatValidator - Class in org.springframework.xd.module.options.validation
-
- DateFormat.DateFormatValidator() - Constructor for class org.springframework.xd.module.options.validation.DateFormat.DateFormatValidator
-
- DateFormat.List - Annotation Type in org.springframework.xd.module.options.validation
-
Defines several
DateFormat
annotations on the same element.
- DateFormatMixin - Class in org.springframework.xd.module.options.mixins
-
Provides a dateFormat
module option, meant to hold a pattern that conforms to SimpleDateFormat
.
- DateFormatMixin() - Constructor for class org.springframework.xd.module.options.mixins.DateFormatMixin
-
- DateTrigger - Class in org.springframework.xd.module.support
-
A Trigger
implementation that enables execution on a series of Dates.
- DateTrigger(Date...) - Constructor for class org.springframework.xd.module.support.DateTrigger
-
- DateWithCustomFormat - Annotation Type in org.springframework.xd.module.options.validation
-
Used as a class level annotation to cross-validate a String representation of a date according to a date format
which is itself a property of the annotated class.
- DateWithCustomFormat.DateWithCustomFormatValidator - Class in org.springframework.xd.module.options.validation
-
- DateWithCustomFormat.DateWithCustomFormatValidator() - Constructor for class org.springframework.xd.module.options.validation.DateWithCustomFormat.DateWithCustomFormatValidator
-
- DateWithCustomFormat.List - Annotation Type in org.springframework.xd.module.options.validation
-
- decodeExceptionMessage(Message<?>) - Static method in class org.springframework.xd.dirt.integration.bus.EmbeddedHeadersMessageConverter
-
- decoder(Consumer<Buffer>) - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistCodec
-
- decrement(long) - Method in class org.springframework.xd.analytics.metrics.core.Counter
-
Decrement this counter by a given amount.
- decrement(String) - Method in interface org.springframework.xd.analytics.metrics.core.CounterRepository
-
Decrement the given counter, creating it if it did not exist.
- decrement(String, String) - Method in interface org.springframework.xd.analytics.metrics.core.FieldValueCounterRepository
-
Decrement the FieldValueCounter for a given field name by one, creating missing counters.
- decrement(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- decrement(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryCounterRepository
-
- decrement(String, String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryFieldValueCounterRepository
-
- decrement(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisCounterRepository
-
- decrement(String, String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- decrement(String, String, double) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- decrementPosition() - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Decrement the current token position and return the new position.
- DeepAggregateCountResourceAssembler - Class in org.springframework.xd.dirt.rest.metrics
-
- DeepAggregateCountResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.metrics.DeepAggregateCountResourceAssembler
-
- DeepCounterResourceAssembler - Class in org.springframework.xd.dirt.rest.metrics
-
- DeepCounterResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.metrics.DeepCounterResourceAssembler
-
- DeepFieldValueCounterResourceAssembler - Class in org.springframework.xd.dirt.rest.metrics
-
- DeepFieldValueCounterResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.metrics.DeepFieldValueCounterResourceAssembler
-
- DEFAULT - Static variable in class org.springframework.xd.shell.converter.NumberFormatConverter
-
- DEFAULT_ADDRESSES - Static variable in class org.springframework.xd.test.fixtures.RabbitSink
-
- DEFAULT_APP_JAR - Static variable in class org.springframework.xd.test.fixtures.SparkAppJob
-
- DEFAULT_APP_SOURCE_JAR - Static variable in class org.springframework.xd.test.fixtures.SparkAppJob
-
- DEFAULT_BASE_FILENAME - Static variable in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- DEFAULT_BASE_PATH - Static variable in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- DEFAULT_BROKER_LIST - Static variable in class org.springframework.xd.test.fixtures.KafkaSink
-
- DEFAULT_CLIENT_CONNECT_STRING - Static variable in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
The default client connect string.
- DEFAULT_COLLECTION_NAME - Static variable in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
- DEFAULT_COLUMN - Static variable in class org.springframework.xd.test.fixtures.IncrementalJdbcHdfsJob
-
- DEFAULT_COLUMN_NAMES - Static variable in class org.springframework.xd.test.fixtures.PartitionedJdbcHdfsJob
-
- DEFAULT_COLUMNS - Static variable in class org.springframework.xd.test.fixtures.JdbcHdfsJob
-
- DEFAULT_CONNECTION_TIMEOUT - Static variable in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
The default ZooKeeper connection timeout in milliseconds.
- DEFAULT_DATA_PATH - Static variable in class org.springframework.xd.integration.hadoop.IntegrationHadoopSystemConstants
-
Default writer path.
- DEFAULT_DATE - Static variable in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- DEFAULT_DELETE_FILES - Static variable in class org.springframework.xd.test.fixtures.FileJdbcJob
-
- DEFAULT_DIRECTORY - Static variable in class org.springframework.xd.test.fixtures.FileJdbcJob
-
- DEFAULT_DIRECTORY - Static variable in class org.springframework.xd.test.fixtures.FilePollHdfsJob
-
- DEFAULT_DIRECTORY - Static variable in class org.springframework.xd.test.fixtures.HdfsJdbcJob
-
- DEFAULT_DIRECTORY - Static variable in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
- DEFAULT_DIRECTORY - Static variable in class org.springframework.xd.test.fixtures.HdfsSink
-
- DEFAULT_DIRECTORY - Static variable in class org.springframework.xd.test.fixtures.IncrementalJdbcHdfsJob
-
- DEFAULT_DIRECTORY - Static variable in class org.springframework.xd.test.fixtures.JdbcHdfsJob
-
- DEFAULT_EXCHANGE - Static variable in class org.springframework.xd.test.fixtures.RabbitSink
-
- DEFAULT_EXCHANGE - Static variable in class org.springframework.xd.test.fixtures.RabbitSource
-
- DEFAULT_FIELD_NAME_MAPPING_SPLIT_TOKEN - Static variable in class org.springframework.xd.analytics.ml.AbstractFieldMappingAwareDataMapper
-
- DEFAULT_FILE_NAME - Static variable in class org.springframework.xd.test.fixtures.FileJdbcJob
-
- DEFAULT_FILE_NAME - Static variable in class org.springframework.xd.test.fixtures.FilePollHdfsJob
-
- DEFAULT_FILE_NAME - Static variable in class org.springframework.xd.test.fixtures.HdfsJdbcJob
-
- DEFAULT_FILE_NAME - Static variable in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
- DEFAULT_FILE_NAME - Static variable in class org.springframework.xd.test.fixtures.HdfsSink
-
- DEFAULT_FILE_NAME - Static variable in class org.springframework.xd.test.fixtures.IncrementalJdbcHdfsJob
-
- DEFAULT_FILE_NAME - Static variable in class org.springframework.xd.test.fixtures.JdbcHdfsJob
-
- DEFAULT_FILE_SUFFIX - Static variable in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- DEFAULT_GROUP - Static variable in interface org.springframework.xd.module.options.spi.ValidationGroupsProvider
-
- DEFAULT_HOST - Static variable in class org.springframework.xd.shell.Target
-
- DEFAULT_HOST - Static variable in class org.springframework.xd.test.fixtures.SyslogTcpSource
-
- DEFAULT_HOST - Static variable in class org.springframework.xd.test.fixtures.SyslogUdpSource
-
- DEFAULT_HOST_NAME - Static variable in class org.springframework.xd.test.fixtures.FtpHdfsJob
-
- DEFAULT_ID_FIELD - Static variable in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
- DEFAULT_ID_FILE_NAMING_STRATEGY - Static variable in class org.springframework.xd.integration.hadoop.IntegrationHadoopSystemConstants
-
Default bean id for file naming policy.
- DEFAULT_ID_FILE_ROLLOVER_STRATEGY - Static variable in class org.springframework.xd.integration.hadoop.IntegrationHadoopSystemConstants
-
Default bean id for file rollover policy.
- DEFAULT_ID_STORE_WRITER - Static variable in class org.springframework.xd.integration.hadoop.IntegrationHadoopSystemConstants
-
Default bean id for store writer.
- DEFAULT_INITIAL_RETRY_WAIT - Static variable in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
The default initial number of milliseconds between connection retries.
- DEFAULT_ISOLATION_LEVEL - Static variable in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- DEFAULT_MAIN_CLASS - Static variable in class org.springframework.xd.test.fixtures.SparkAppJob
-
- DEFAULT_MASTER - Static variable in class org.springframework.xd.test.fixtures.SparkAppJob
-
- DEFAULT_MAX_RETRY_ATTEMPTS - Static variable in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
The default number of connection attempts that will be made after
a failed connection attempt.
- DEFAULT_MESSAGE - Static variable in annotation type org.springframework.xd.module.options.validation.CronExpression
-
- DEFAULT_MESSAGE - Static variable in annotation type org.springframework.xd.module.options.validation.DateFormat
-
- DEFAULT_MESSAGE - Static variable in annotation type org.springframework.xd.module.options.validation.DateWithCustomFormat
-
- DEFAULT_MODE - Static variable in class org.springframework.xd.test.fixtures.SimpleFileSink
-
- DEFAULT_NAME - Static variable in class org.springframework.xd.test.fixtures.SparkAppJob
-
- DEFAULT_NAMES - Static variable in class org.springframework.xd.test.fixtures.FileJdbcJob
-
- DEFAULT_NAMES - Static variable in class org.springframework.xd.test.fixtures.HdfsJdbcJob
-
- DEFAULT_NAMES - Static variable in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
- DEFAULT_OUTPUT_TYPE - Static variable in class org.springframework.xd.test.fixtures.KafkaSource
-
- DEFAULT_OVERRIDE - Static variable in class org.springframework.xd.test.fixtures.IncrementalJdbcHdfsJob
-
- DEFAULT_PARTITION_COLUMN - Static variable in class org.springframework.xd.test.fixtures.PartitionedJdbcHdfsJob
-
- DEFAULT_PARTITIONS - Static variable in class org.springframework.xd.test.fixtures.PartitionedJdbcHdfsJob
-
- DEFAULT_PORT - Static variable in class org.springframework.xd.shell.Target
-
- DEFAULT_PORT - Static variable in class org.springframework.xd.test.fixtures.FtpHdfsJob
-
- DEFAULT_PORT - Static variable in class org.springframework.xd.test.fixtures.JmsSource
-
- DEFAULT_PORT - Static variable in class org.springframework.xd.test.fixtures.SyslogTcpSource
-
- DEFAULT_PORT - Static variable in class org.springframework.xd.test.fixtures.SyslogUdpSource
-
- DEFAULT_QUEUE - Static variable in class org.springframework.xd.test.fixtures.RabbitSource
-
- DEFAULT_ROLLOVER_THRESHOLD_IN_BYTES - Static variable in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- DEFAULT_ROUTING_KEY - Static variable in class org.springframework.xd.test.fixtures.RabbitSink
-
- DEFAULT_SCHEME - Static variable in class org.springframework.xd.shell.Target
-
- DEFAULT_SESSION_TIMEOUT - Static variable in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
The default ZooKeeper session timeout in milliseconds.
- DEFAULT_SPECIFIED_PASSWORD - Static variable in class org.springframework.xd.shell.Target
-
- DEFAULT_SQL - Static variable in class org.springframework.xd.test.fixtures.JdbcHdfsJob
-
- DEFAULT_TABLE - Static variable in class org.springframework.xd.test.fixtures.IncrementalJdbcHdfsJob
-
- DEFAULT_TABLE - Static variable in class org.springframework.xd.test.fixtures.JdbcHdfsJob
-
- DEFAULT_TABLE - Static variable in class org.springframework.xd.test.fixtures.PartitionedJdbcHdfsJob
-
- DEFAULT_TABLE_NAME - Static variable in class org.springframework.xd.test.fixtures.FileJdbcJob
-
- DEFAULT_TABLE_NAME - Static variable in class org.springframework.xd.test.fixtures.HdfsJdbcJob
-
- DEFAULT_TARGET - Static variable in class org.springframework.xd.shell.Target
-
- DEFAULT_TOPIC - Static variable in class org.springframework.xd.test.fixtures.KafkaSink
-
- DEFAULT_TOPIC - Static variable in class org.springframework.xd.test.fixtures.KafkaSource
-
- DEFAULT_UNSPECIFIED_PASSWORD - Static variable in class org.springframework.xd.shell.Target
-
- DEFAULT_USERNAME - Static variable in class org.springframework.xd.shell.Target
-
- DEFAULT_XD_DATE_FORMAT_PATTERN - Static variable in class org.springframework.xd.rest.domain.util.TimeUtils
-
- DEFAULT_XD_DATE_TIME_FORMAT_PATTERN - Static variable in class org.springframework.xd.rest.domain.util.TimeUtils
-
- DEFAULT_XD_DURATION_FORMAT_PATTERN - Static variable in class org.springframework.xd.rest.domain.util.TimeUtils
-
- DEFAULT_XD_TIME_FORMAT_PATTERN - Static variable in class org.springframework.xd.rest.domain.util.TimeUtils
-
- DEFAULT_XD_TIMEZONE_ID - Static variable in class org.springframework.xd.rest.domain.util.TimeUtils
-
- DEFAULT_ZK_CLIENT - Static variable in class org.springframework.xd.test.fixtures.KafkaSource
-
- defaultBackOffInitialInterval - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- defaultBackOffMaxInterval - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- defaultBackOffMultiplier - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- defaultBatchBufferLimit - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- defaultBatchingEnabled - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- defaultBatchSize - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- defaultBatchTimeout - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- defaultCompress - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- defaultConcurrency - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- DefaultDeploymentStateRecalculator - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
Stream/Job deployment state re-calculator upon leadership election.
- DefaultDeploymentStateRecalculator() - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.DefaultDeploymentStateRecalculator
-
- DefaultDeploymentUnitStateCalculator - Class in org.springframework.xd.dirt.server.admin.deployment
-
- DefaultDeploymentUnitStateCalculator() - Constructor for class org.springframework.xd.dirt.server.admin.deployment.DefaultDeploymentUnitStateCalculator
-
- DefaultDistributedTestSupport - Class in org.springframework.xd.distributed.util
-
- DefaultDistributedTestSupport() - Constructor for class org.springframework.xd.distributed.util.DefaultDistributedTestSupport
-
- defaultDurableSubscription - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- DefaultGreenplumLoad - Class in org.springframework.xd.greenplum.support
-
- DefaultGreenplumLoad(LoadConfiguration, LoadService) - Constructor for class org.springframework.xd.greenplum.support.DefaultGreenplumLoad
-
- defaultInstance - Static variable in class org.springframework.xd.module.ModuleDeploymentProperties
-
Default instance of ModuleDeploymentProperties
.
- DefaultLoadService - Class in org.springframework.xd.greenplum.support
-
- DefaultLoadService(JdbcTemplate) - Constructor for class org.springframework.xd.greenplum.support.DefaultLoadService
-
- defaultMaxAttempts - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- DefaultModuleDeploymentPropertiesProvider - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
- DefaultModuleDeploymentPropertiesProvider(DeploymentUnit) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.DefaultModuleDeploymentPropertiesProvider
-
- DefaultModuleOptionsMetadataCollector - Class in org.springframework.xd.module.options
-
A (fake) PlaceholderConfigurer that will collect the placeholders it encounters and derive a
ModuleOption
out
of them.
- DefaultModuleOptionsMetadataCollector() - Constructor for class org.springframework.xd.module.options.DefaultModuleOptionsMetadataCollector
-
- DefaultModuleOptionsMetadataResolver - Class in org.springframework.xd.module.options
-
The default implementation of
ModuleOptionsMetadataResolver
that deals with simple modules and reads the
companion
.properties
file sitting next to the module definition.
- DefaultModuleOptionsMetadataResolver() - Constructor for class org.springframework.xd.module.options.DefaultModuleOptionsMetadataResolver
-
- DefaultSimpleModuleInformationResolver - Class in org.springframework.xd.module.info
-
- DefaultSimpleModuleInformationResolver() - Constructor for class org.springframework.xd.module.info.DefaultSimpleModuleInformationResolver
-
- DefaultSparkStreamingModuleOptionsMetadata - Class in org.springframework.xd.spark.streaming
-
- DefaultSparkStreamingModuleOptionsMetadata() - Constructor for class org.springframework.xd.spark.streaming.DefaultSparkStreamingModuleOptionsMetadata
-
- DefaultTuple - Class in org.springframework.xd.tuple
-
Default implementation of Tuple interface
- DefaultTuple(List<String>, List<Object>, ConfigurableConversionService) - Constructor for class org.springframework.xd.tuple.DefaultTuple
-
- DefaultTupleConversionService - Class in org.springframework.xd.tuple
-
Base
ConversionService
implementation suitable for use with
Tuple
- DefaultTupleConversionService() - Constructor for class org.springframework.xd.tuple.DefaultTupleConversionService
-
- DefaultTupleSerializer - Class in org.springframework.xd.tuple.serializer.kryo
-
Deserializes Tuples by writing the field names and then the values as class/object pairs
followed by the tuple Id and timestamp.
- DefaultTupleSerializer() - Constructor for class org.springframework.xd.tuple.serializer.kryo.DefaultTupleSerializer
-
- DefinitionAlreadyExistsException - Exception in org.springframework.xd.dirt.stream
-
Exception which is raised when a resource definition with the same name already exists.
- DefinitionAlreadyExistsException(String, String) - Constructor for exception org.springframework.xd.dirt.stream.DefinitionAlreadyExistsException
-
Create a new exception.
- definitionKind - Variable in class org.springframework.xd.dirt.stream.AbstractDeployer
-
Used in exception messages as well as indication to the parser.
- DelegatingModuleInformationResolver - Class in org.springframework.xd.module.info
-
A composite resolver that will try delegates until one returns a non null
result.
- DelegatingModuleInformationResolver() - Constructor for class org.springframework.xd.module.info.DelegatingModuleInformationResolver
-
- DelegatingModuleOptionsMetadataResolver - Class in org.springframework.xd.module.options
-
- DelegatingModuleOptionsMetadataResolver() - Constructor for class org.springframework.xd.module.options.DelegatingModuleOptionsMetadataResolver
-
- DelegatingModuleRegistry - Class in org.springframework.xd.dirt.module
-
A
ModuleRegistry
that delegates to several ModuleRegistries, in order.
- DelegatingModuleRegistry(ModuleRegistry...) - Constructor for class org.springframework.xd.dirt.module.DelegatingModuleRegistry
-
- DelegatingModuleRegistry() - Constructor for class org.springframework.xd.dirt.module.DelegatingModuleRegistry
-
- delete(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- delete(Counter) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- delete(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- delete(M) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- delete(Iterable<? extends M>) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- delete(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisAggregateCounterRepository
-
- delete(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- delete(FieldValueCounter) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- delete(Iterable<? extends FieldValueCounter>) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- delete(String) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- delete(Container) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- delete(Iterable<? extends Container>) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- delete(String) - Method in interface org.springframework.xd.dirt.core.ResourceDeployer
-
Delete the Definition using the provided name.
- delete(ModuleDefinition) - Method in class org.springframework.xd.dirt.module.DelegatingModuleRegistry
-
- delete() - Method in class org.springframework.xd.dirt.module.ExtendedResource
-
Delete the resource and all of its children, if any.
- delete() - Method in class org.springframework.xd.dirt.module.ExtendedResource.FileSystemExtendedResource
-
- delete() - Method in class org.springframework.xd.dirt.module.ExtendedResource.HdfsExtendedResource
-
- delete(String, ModuleType, String) - Method in interface org.springframework.xd.dirt.module.ModuleDependencyRepository
-
Remove an atomic dependency from a module (composed or not) to some target (stream, or composed module).
- delete(ModuleDefinition) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperComposedModuleDefinitionRegistry
-
- delete(String, ModuleType, String) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleDependencyRepository
-
- delete(ModuleMetadata.Id) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- delete(ModuleMetadata) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- delete(Iterable<? extends ModuleMetadata>) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- delete(String, ModuleType) - Method in class org.springframework.xd.dirt.module.support.ModuleDefinitionService
-
- delete(ModuleDefinition) - Method in class org.springframework.xd.dirt.module.SynchronizingModuleRegistry
-
- delete(ModuleDefinition) - Method in interface org.springframework.xd.dirt.module.WritableModuleRegistry
-
Attempt to delete the given definition, if that registry is responsible for it.
- delete(ModuleDefinition) - Method in class org.springframework.xd.dirt.module.WritableResourceModuleRegistry
-
- delete(String) - Method in class org.springframework.xd.dirt.rest.JobsController
-
Request removal of an existing resource definition (stream or job).
- delete(ModuleType, String) - Method in class org.springframework.xd.dirt.rest.ModulesController
-
Delete a module.
- delete(String) - Method in class org.springframework.xd.dirt.rest.XDController
-
Request removal of an existing resource definition (stream or job).
- delete(String) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- delete(String) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- delete(JobDefinition) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- delete(Iterable<? extends JobDefinition>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- delete(String) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- delete(Job) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- delete(Iterable<? extends Job>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- delete(String) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- delete(StreamDefinition) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- delete(Iterable<? extends StreamDefinition>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- delete(String) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- delete(Stream) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- delete(Iterable<? extends Stream>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- delete(String) - Method in interface org.springframework.xd.rest.client.AggregateCounterOperations
-
Delete the given named aggregate counter
- delete(String) - Method in interface org.springframework.xd.rest.client.CounterOperations
-
Delete the counter with given name
- delete(String) - Method in interface org.springframework.xd.rest.client.FieldValueCounterOperations
-
Delete the given named field value counter
- delete(String) - Method in interface org.springframework.xd.rest.client.GaugeOperations
-
Delete the given named gauge.
- delete(String) - Method in interface org.springframework.xd.rest.client.RichGaugeOperations
-
Delete the given named rich gauge
- delete(String) - Method in class org.springframework.xd.shell.command.AggregateCounterCommands
-
- delete(String) - Method in class org.springframework.xd.shell.command.CounterCommands
-
- delete(String) - Method in class org.springframework.xd.shell.command.FieldValueCounterCommands
-
- delete(String) - Method in class org.springframework.xd.shell.command.GaugeCommands
-
- delete(String) - Method in class org.springframework.xd.shell.command.RichGaugeCommands
-
- delete(ID) - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
- delete(T) - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
- delete(ID) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- delete(Iterable<? extends T>) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- delete(T) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- delete(Iterable<? extends T>) - Method in class org.springframework.xd.store.AbstractRepository
-
- deleteAll() - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- deleteAll() - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- deleteAll() - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- deleteAll() - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- deleteAll() - Method in interface org.springframework.xd.dirt.core.ResourceDeployer
-
Delete all the definitions
- deleteAll() - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- deleteAll() - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
Delete all the registry and step name entries.
- deleteAll() - Method in class org.springframework.xd.dirt.rest.JobsController
-
Request removal of all definitions.
- deleteAll() - Method in class org.springframework.xd.dirt.rest.XDController
-
Request removal of all definitions.
- deleteAll() - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- deleteAll() - Method in class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
- deleteAll() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- deleteAll() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- deleteAll() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- deleteAll() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- deleteAll() - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
- deleteAll() - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- deleteBinding(String, MessageChannel) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- deleteBindings(String) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- deleteDependencies(ModuleDependencyRepository, ModuleDefinition, String) - Static method in class org.springframework.xd.dirt.module.support.ModuleDefinitionRepositoryUtils
-
- deleteDependencies(ModuleDependencyRepository, StreamDefinition) - Static method in class org.springframework.xd.dirt.stream.StreamDefinitionRepositoryUtils
-
Delete the dependencies of each module to its containing stream.
- deleteJobRegistry(String) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
Delete the job entry from the registry table.
- deleteModule(String, RESTModuleType) - Method in class org.springframework.xd.rest.client.impl.ModuleTemplate
-
- deleteModule(String, RESTModuleType) - Method in interface org.springframework.xd.rest.client.ModuleOperations
-
Request deletion of module with given name and type.
- deleteOffset(Partition) - Method in class org.springframework.integration.x.kafka.WindowingOffsetManager
-
- deleteStream(String) - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
Delete a stream.
- DelimitedStringToMapPropertyEditor - Class in org.springframework.xd.extension.process
-
Converts a String of comma delimited name-value pairs to a Map.
- DelimitedStringToMapPropertyEditor() - Constructor for class org.springframework.xd.extension.process.DelimitedStringToMapPropertyEditor
-
- DepartedContainerModuleRedeployer - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
The
ModuleRedeployer
that re-deploys the stream/job modules that were
deployed into the departing container.
- DepartedContainerModuleRedeployer(ZooKeeperConnection, ContainerRepository, StreamFactory, JobFactory, PathChildrenCache, ContainerMatcher, ModuleDeploymentWriter, DeploymentUnitStateCalculator) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.DepartedContainerModuleRedeployer
-
Constructs DepartingContainerModuleRedeployer
- DependencyException - Exception in org.springframework.xd.dirt.module
-
Thrown when performing an action cannot be carried over because some dependency would be broken.
- DependencyException(String, String, ModuleType, Set<String>) - Constructor for exception org.springframework.xd.dirt.module.DependencyException
-
- deploy(String, Map<String, String>) - Method in interface org.springframework.xd.dirt.core.ResourceDeployer
-
Deploy a resource (job or stream).
- deploy(Module, ModuleDescriptor) - Method in class org.springframework.xd.dirt.module.ModuleDeployer
-
Deploy the given module to this container.
- deploy(String, String) - Method in class org.springframework.xd.dirt.rest.XDController
-
Request deployment of an existing definition resource.
- deploy(String) - Method in interface org.springframework.xd.dirt.server.admin.deployment.DeploymentHandler
-
- deploy(String) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ZKJobDeploymentHandler
-
Deploy the Job with the given name.
- deploy(String) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ZKStreamDeploymentHandler
-
Deploy the stream with the given name.
- deploy(String, Map<String, String>) - Method in class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
- deploy(String, Map<String, String>) - Method in interface org.springframework.xd.rest.client.ResourceOperations
-
Deploy an already created resource.
- DeployableResource - Class in org.springframework.xd.rest.domain
-
Abstract base class for resources that represent deployable units.
- DeployableResource() - Constructor for class org.springframework.xd.rest.domain.DeployableResource
-
No arg constructor for serialization frameworks.
- DeployableResource(String) - Constructor for class org.springframework.xd.rest.domain.DeployableResource
-
- deployer - Variable in class org.springframework.xd.dirt.rest.XDController
-
- deployJob(String, String, File) - Method in class org.springframework.xd.shell.command.JobCommands
-
- DEPLOYMENT_QUEUE - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of the stream deployment queue path.
- DeploymentAction - Enum in org.springframework.xd.dirt.server.admin.deployment
-
Enum class for the supported deployment actions.
- DeploymentConfiguration - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
Configuration class that holds the beans required for deployment management.
- DeploymentConfiguration() - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- DeploymentException - Exception in org.springframework.xd.dirt.server.admin.deployment
-
Exception thrown when
DeploymentHandler
encounters problem
when deploying/un-deploying stream/job.
- DeploymentException(String) - Constructor for exception org.springframework.xd.dirt.server.admin.deployment.DeploymentException
-
- DeploymentException(String, Exception) - Constructor for exception org.springframework.xd.dirt.server.admin.deployment.DeploymentException
-
- DeploymentHandler - Interface in org.springframework.xd.dirt.server.admin.deployment
-
Deployment handler that is responsible for deploying/un-deploying the
DeploymentUnit
(Stream/Job) to/from the container.
- deploymentHandler - Variable in class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
- deploymentInfo(String, String) - Method in class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
Query deployment information about definitions whose ids range from first
to last
.
- deploymentInfo(String) - Method in class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
Query deployment information about the definition whose ID is provided.
- deploymentListener() - Method in class org.springframework.xd.dirt.server.container.ContainerConfiguration
-
- DeploymentLoader - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
Utility for loading streams and jobs for the purpose of deployment.
- DeploymentLoader() - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentLoader
-
- DeploymentMessage - Class in org.springframework.xd.dirt.server.admin.deployment
-
The message that wraps the details of a deployment request.
- DeploymentMessage() - Constructor for class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- DeploymentMessage(DeploymentUnitType) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- deploymentMessageConsumer() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- DeploymentMessageConsumer - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
- DeploymentMessageConsumer() - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentMessageConsumer
-
- deploymentMessageProducer() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- DeploymentMessagePublisher - Interface in org.springframework.xd.dirt.server.admin.deployment
-
- DeploymentOptionKeys - Class in org.springframework.xd.shell.command
-
Used to factor out names of the options that are shared by all deploy commands.
- DeploymentOptionKeys() - Constructor for class org.springframework.xd.shell.command.DeploymentOptionKeys
-
- DeploymentPropertiesFormat - Class in org.springframework.xd.rest.domain.support
-
Provides utility methods for formatting and parsing deployment properties.
- deploymentPropertiesProvider - Variable in class org.springframework.xd.dirt.server.admin.deployment.RuntimeModuleDeploymentPropertiesProvider
-
- DeploymentPropertiesUtility - Class in org.springframework.xd.dirt.util
-
Class that provides utility methods to handle module deployment properties.
- DeploymentPropertiesUtility() - Constructor for class org.springframework.xd.dirt.util.DeploymentPropertiesUtility
-
- deploymentQueue() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- DeploymentQueue - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
This class controls the lifecycle operations of the ZK distributed queue that
holds the
DeploymentMessage
s.
- DeploymentQueue(ZooKeeperConnection) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentQueue
-
Construct deployment queue
- DeploymentQueue(CuratorFramework, QueueConsumer, String, ExecutorService) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentQueue
-
Construct deployment queue
- DEPLOYMENTS - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of deployments node.
- DeploymentStatusRepository<T,ID extends java.io.Serializable & java.lang.Comparable<ID>> - Interface in org.springframework.xd.dirt.core
-
Interface definition for repositories that support the reporting
of deployment unit state.
- deploymentSupervisor() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- DeploymentSupervisor - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
Process that watches ZooKeeper for Container arrivals and departures from
the XD cluster.
- DeploymentSupervisor(AdminAttributes) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentSupervisor
-
Construct Deployment Supervisor
- DeploymentUnit - Interface in org.springframework.xd.dirt.core
-
DeploymentUnit
is a collection of modules that are intended to be
deployed as a single unit.
- deploymentUnit - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer.ModuleDeployment
-
- DeploymentUnitStateCalculator - Interface in org.springframework.xd.dirt.server.admin.deployment
-
Calculates the overall status for a deployment unit (stream or job).
- deploymentUnitStateCalculator() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- DeploymentUnitStatus - Class in org.springframework.xd.dirt.core
-
- DeploymentUnitStatus(DeploymentUnitStatus.State) - Constructor for class org.springframework.xd.dirt.core.DeploymentUnitStatus
-
Construct a DeploymentUnitStatus
.
- DeploymentUnitStatus(DeploymentUnitStatus.State, String) - Constructor for class org.springframework.xd.dirt.core.DeploymentUnitStatus
-
Construct a DeploymentUnitStatus
with an error description.
- DeploymentUnitStatus(Map<String, String>) - Constructor for class org.springframework.xd.dirt.core.DeploymentUnitStatus
-
Construct a DeploymentUnitStatus
using the entries in
the provided map.
- DeploymentUnitStatus.State - Enum in org.springframework.xd.dirt.core
-
Deployment unit states.
- DeploymentUnitType - Enum in org.springframework.xd.dirt.server.admin.deployment
-
Enum class that defines the deployment unit type.
- DeploymentValidator - Interface in org.springframework.xd.dirt.stream
-
This interface defines validation methods that verify a stream or job
can be saved, deployed, undeployed, or deleted.
- deployModules(Container) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ContainerMatchingModuleRedeployer
-
Handle the arrival of a container.
- deployModules(Container) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DepartedContainerModuleRedeployer
-
Handle the departure of a container.
- deployModules(Container) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer
-
Deploy unallocated/orphaned modules.
- deployResource(String) - Method in class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
Deploy the deployment unit with the given name.
- deployStream(StreamDefinition) - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
Deploy a stream.
- deployStream(StreamDefinition, Map<String, String>) - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
Deploy a stream with properties.
- deployStream(StreamDefinition, Map<String, String>, boolean) - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
Deploy a stream with properties and allow return on incomplete deployment
- deployStream(String, String, File) - Method in class org.springframework.xd.shell.command.StreamCommands
-
- describeTo(Description) - Method in class org.springframework.xd.test.fixtures.EventuallyMatcher
-
- describeTo(Description) - Method in class org.springframework.xd.test.fixtures.FileSink.FileSinkContentsMatcher
-
- describeTo(Description) - Method in class org.springframework.xd.test.fixtures.MetricHasSimpleValueMatcher
-
- deserialize(String, String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisCounterRepository
-
- deserialize(JsonParser, DeserializationContext) - Method in class org.springframework.xd.rest.client.impl.support.JobParameterJacksonDeserializer
-
- deserialize(ID, String) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
Deserialize from the String representation to the domain object.
- deserializeId(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisCounterRepository
-
- deserializeId(String) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
Deserialize an entity id from its String representation.
- deserializePayloadIfNecessary(Message<?>) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- deserializePayloadIfNecessary(MessageValues) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- destroy() - Method in class org.springframework.integration.x.kafka.WindowingOffsetManager
-
- destroy() - Method in class org.springframework.xd.batch.hsqldb.server.HSQLServerBean
-
- destroy() - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- destroy() - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- destroy() - Method in class org.springframework.xd.dirt.integration.redis.RedisMessageBus
-
- destroy() - Method in class org.springframework.xd.dirt.plugins.job.BatchJobRegistryBeanPostProcessor
-
- destroy() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentQueue
-
- destroy() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentSupervisor
- destroy() - Method in class org.springframework.xd.dirt.stream.JobDeployer
-
- destroy() - Method in class org.springframework.xd.dirt.test.process.AbstractSingleNodeProcessingChain
-
- destroy() - Method in class org.springframework.xd.greenplum.support.LoadFactoryBean
-
- destroy() - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- destroy() - Method in class org.springframework.xd.module.core.CompositeModule
-
- destroy() - Method in interface org.springframework.xd.module.core.Module
-
Destroy this module's application context.
- destroy() - Method in class org.springframework.xd.module.core.SimpleModule
-
- destroy() - Method in class org.springframework.xd.reactor.BroadcasterMessageHandler
-
- destroy() - Method in class org.springframework.xd.reactor.MultipleBroadcasterMessageHandler
-
- destroy(String) - Method in interface org.springframework.xd.rest.client.ResourceOperations
-
Destroy an existing resource.
- destroy() - Method in class org.springframework.xd.rxjava.MultipleSubjectMessageHandler
-
- destroy() - Method in class org.springframework.xd.rxjava.SubjectMessageHandler
-
- destroyAll() - Method in interface org.springframework.xd.rest.client.ResourceOperations
-
Undeploy all the resources known to the system.
- destroyAllJobs(boolean) - Method in class org.springframework.xd.shell.command.JobCommands
-
- destroyAllStreams(URL) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Removes all the streams from the cluster.
- destroyAllStreams(boolean) - Method in class org.springframework.xd.shell.command.StreamCommands
-
- destroyInstance(BasicDataSource) - Method in class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- destroyJob(String) - Method in class org.springframework.xd.shell.command.JobCommands
-
- destroyModule(ModuleCommands.QualifiedModuleName) - Method in class org.springframework.xd.shell.command.ModuleCommands
-
- destroyQueue() - Method in class org.springframework.xd.test.fixtures.RabbitSource
-
Creates an instance of the queue on the rabbit broker.
- destroyStream(String) - Method in class org.springframework.xd.shell.command.StreamCommands
-
- DetailedContainer - Class in org.springframework.xd.dirt.container.store
-
Domain object for an XD container with detailed info (deployed modules, messageRates etc.,).
- DetailedContainer(Container) - Constructor for class org.springframework.xd.dirt.container.store.DetailedContainer
-
Construct a RuntimeContainer object.
- DetailedContainerResource - Class in org.springframework.xd.rest.domain
-
Represents container info model.
- DetailedContainerResource(Map<String, String>, int, List<ModuleMetadataResource>, Map<String, HashMap<String, Double>>) - Constructor for class org.springframework.xd.rest.domain.DetailedContainerResource
-
Construct ContainerResource using the container attributes and
deployed modules.
- DetailedContainerResource.Page - Class in org.springframework.xd.rest.domain
-
Dedicated subclass to workaround type erasure.
- DetailedContainerResource.Page() - Constructor for class org.springframework.xd.rest.domain.DetailedContainerResource.Page
-
- DetailedJobInfo - Class in org.springframework.xd.dirt.job
-
A job info for batch jobs that provides more details than the base
JobInfo
- DetailedJobInfo(String, int, boolean, boolean, JobExecutionInfo, boolean) - Constructor for class org.springframework.xd.dirt.job.DetailedJobInfo
-
Construct detailed job info.
- DetailedJobInfoResource - Class in org.springframework.xd.rest.domain
-
Represents Expanded Batch job info that has more details on batch jobs.
- DetailedJobInfoResource(String, int, boolean, boolean, JobExecutionInfoResource, boolean) - Constructor for class org.springframework.xd.rest.domain.DetailedJobInfoResource
-
- DetailedJobInfoResourceAssembler - Class in org.springframework.xd.dirt.rest
-
Knows how to build a REST resource out of our domain model
DetailedJobInfo
.
- DetailedJobInfoResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.DetailedJobInfoResourceAssembler
-
- DetailedModuleDefinitionResource - Class in org.springframework.xd.rest.domain
-
- DetailedModuleDefinitionResource() - Constructor for class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource
-
Default constructor for serialization frameworks.
- DetailedModuleDefinitionResource(String, String, boolean) - Constructor for class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource
-
- DetailedModuleDefinitionResource.Option - Class in org.springframework.xd.rest.domain
-
- DetailedModuleDefinitionResource.Option(String, String, String, String, boolean) - Constructor for class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource.Option
-
- DetailedModuleDefinitionResource.Page - Class in org.springframework.xd.rest.domain
-
Dedicated subclass to workaround type erasure.
- DetailedModuleDefinitionResource.Page() - Constructor for class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource.Page
-
- DetailedModuleDefinitionResourceAssembler - Class in org.springframework.xd.dirt.rest
-
- DetailedModuleDefinitionResourceAssembler(ModuleOptionsMetadataResolver, ModuleInformationResolver) - Constructor for class org.springframework.xd.dirt.rest.DetailedModuleDefinitionResourceAssembler
-
- details(long, long) - Method in class org.springframework.xd.dirt.rest.BatchStepExecutionsController
-
Inspect the StepExecution with the provided Step Execution Id
- determinePartition(Message<?>, MessageBusSupport.PartitioningMetadata) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Determine the partition to which to send this message.
- dir(String) - Method in class org.springframework.xd.test.fixtures.HdfsJdbcJob
-
Sets the directory where the file will be read from the hdfs.
- dir(String) - Method in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
Sets the directory where the file will be read from the hdfs.
- dir(String) - Method in class org.springframework.xd.test.fixtures.SimpleFileSink
-
Establishes the directory the SimpleFileSink will write the file.
- DIRECT - Static variable in class org.springframework.xd.dirt.integration.bus.Binding
-
- DIRECT_BINDING_ALLOWED - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
If true, the bus will attempt to create a direct binding between the producer and consumer.
- directChannelProvider - Variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Used in the canonical case, when the binding does not involve an alias name.
- directory(String) - Method in class org.springframework.xd.test.fixtures.FilePollHdfsJob
-
Sets the directory that the hdfs will write to.
- directoryName(String) - Method in class org.springframework.xd.test.fixtures.HdfsSink
-
Sets the directory that the file will be written on hdfs
- DirtException - Exception in org.springframework.xd.dirt
-
Root of the hierarchy of exceptions for DIRT (Distributed Integration RunTime).
- DirtException(String) - Constructor for exception org.springframework.xd.dirt.DirtException
-
- DirtException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.DirtException
-
- dispatcher - Variable in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- display(String, DateTime, DateTime, AggregateCountResolution) - Method in class org.springframework.xd.dirt.rest.metrics.AggregateCountersController
-
Retrieve counts for a given time interval, using some precision.
- display(String) - Method in class org.springframework.xd.dirt.rest.metrics.CountersController
-
Retrieve information about a specific counter.
- display(String) - Method in class org.springframework.xd.dirt.rest.metrics.FieldValueCountersController
-
- display(String) - Method in class org.springframework.xd.dirt.rest.metrics.GaugesController
-
- display(String) - Method in class org.springframework.xd.dirt.rest.metrics.RichGaugesController
-
- display(String) - Method in class org.springframework.xd.dirt.rest.XDController
-
Retrieve information about a single ResourceSupport
.
- display(String, String, String, Integer, Integer, AggregateCounterOperations.Resolution, NumberFormat) - Method in class org.springframework.xd.shell.command.AggregateCounterCommands
-
- display(String, NumberFormat) - Method in class org.springframework.xd.shell.command.CounterCommands
-
- display(String, NumberFormat, int) - Method in class org.springframework.xd.shell.command.FieldValueCounterCommands
-
- display(String, NumberFormat) - Method in class org.springframework.xd.shell.command.GaugeCommands
-
- display(long) - Method in class org.springframework.xd.shell.command.JobCommands
-
- display(String, NumberFormat) - Method in class org.springframework.xd.shell.command.RichGaugeCommands
-
- displayBanner(String, String) - Static method in class org.springframework.xd.dirt.util.BannerUtils
-
- displayBeans(Map<String, Object>, String) - Static method in class org.springframework.xd.dirt.server.ApplicationUtils
-
- displayForJobname(String) - Method in class org.springframework.xd.dirt.rest.ModulesMetadataController
-
Will return a collection of
ModuleMetadata
that are associated with
the provided
jobname
request parameter.
- displayJobExecution(long) - Method in class org.springframework.xd.rest.client.impl.JobTemplate
-
- displayJobExecution(long) - Method in interface org.springframework.xd.rest.client.JobOperations
-
Retrieve a specific Job Execution for the provided jobExecutionId
.
- displayJobInstance(long) - Method in class org.springframework.xd.rest.client.impl.JobTemplate
-
- displayJobInstance(long) - Method in interface org.springframework.xd.rest.client.JobOperations
-
Retrieve a specific instance of a job, given its intanceId.
- displayJobInstance(long) - Method in class org.springframework.xd.shell.command.JobCommands
-
- displayMetrics(PagedResources<MetricResource>) - Method in class org.springframework.xd.shell.command.AbstractMetricsCommands
-
Render a table with information about a list of metrics
- displayStepExecution(long, long) - Method in class org.springframework.xd.rest.client.impl.JobTemplate
-
- displayStepExecution(long, long) - Method in interface org.springframework.xd.rest.client.JobOperations
-
- displayStepExecution(long, long) - Method in class org.springframework.xd.shell.command.JobCommands
-
- Disposable - Interface in org.springframework.xd.test.fixtures
-
To be implemented by fixtures that need special cleanup when a test is done.
- DisposableFileSupport<F extends DisposableFileSupport<F>> - Class in org.springframework.xd.test.fixtures
-
Base class for stream elements that deal with file locations.
- DisposableFileSupport() - Constructor for class org.springframework.xd.test.fixtures.DisposableFileSupport
-
- DisposableFileSupport(File) - Constructor for class org.springframework.xd.test.fixtures.DisposableFileSupport
-
- DisposableMailSupport<T extends DisposableMailSupport<T>> - Class in org.springframework.xd.test.fixtures
-
Base class for fixtures that interact with a mail server.
- DisposableMailSupport() - Constructor for class org.springframework.xd.test.fixtures.DisposableMailSupport
-
- DistributedJobLocator - Class in org.springframework.xd.dirt.plugins.job
-
- DistributedJobLocator() - Constructor for class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
- DistributedJobService - Class in org.springframework.xd.dirt.plugins.job
-
SimpleJobService in distributed mode
- DistributedJobService(SearchableJobInstanceDao, XdJdbcSearchableJobExecutionDao, SearchableStepExecutionDao, JobRepository, JobLauncher, DistributedJobLocator, ExecutionContextDao) - Constructor for class org.springframework.xd.dirt.plugins.job.DistributedJobService
-
- DistributedTestSupport - Interface in org.springframework.xd.distributed.util
-
Provides support methods for building distributed system tests.
- doBindDynamicProducer(String, String, Properties) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Create a producer for the named channel and bind it to the bus.
- doBindDynamicPubSubProducer(String, String, Properties) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Create a producer for the named channel and bind it to the bus.
- DocumentParseResult - Class in org.springframework.xd.dirt.stream
-
Represents the result of parsing a multiline document, made of several definitions.
- DocumentParseResult(int) - Constructor for class org.springframework.xd.dirt.stream.DocumentParseResult
-
- DocumentParseResult.Line - Class in org.springframework.xd.dirt.stream
-
The parse result of an individual line.
- DocumentParseResultResource - Class in org.springframework.xd.rest.domain
-
Represents the result of parsing a multiline definition document.
- DocumentParseResultResource() - Constructor for class org.springframework.xd.rest.domain.DocumentParseResultResource
-
- DocumentParseResultResource.Error - Class in org.springframework.xd.rest.domain
-
- DocumentParseResultResource.Error(String) - Constructor for class org.springframework.xd.rest.domain.DocumentParseResultResource.Error
-
- DocumentParseResultResource.Error(String, Integer) - Constructor for class org.springframework.xd.rest.domain.DocumentParseResultResource.Error
-
- DocumentParseResultResource.Line - Class in org.springframework.xd.rest.domain
-
The result of parsing a single line of the input document.
- DocumentParseResultResource.Line() - Constructor for class org.springframework.xd.rest.domain.DocumentParseResultResource.Line
-
- DocumentParseResultResource.ModuleDescriptor - Class in org.springframework.xd.rest.domain
-
- DocumentParseResultResource.ModuleDescriptor(String, String, RESTModuleType, String, String, String, Map<String, String>) - Constructor for class org.springframework.xd.rest.domain.DocumentParseResultResource.ModuleDescriptor
-
- DocumentParseResultResourceAssembler - Class in org.springframework.xd.dirt.rest
-
This class is responsible for creating a REST representation of a DocumentParseResult.
- DocumentParseResultResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.DocumentParseResultResourceAssembler
-
- DomainRepository<T,ID extends java.io.Serializable & java.lang.Comparable<ID>> - Interface in org.springframework.xd.store
-
Implemented by XD repositories, exists mainly as a mean to capture several interfaces into one.
- doManualAck(LinkedList<MessageHeaders>) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Perform manual acknowledgement based on the metadata stored in message bus.
- doManualAck(LinkedList<MessageHeaders>) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- doManualAck(LinkedList<MessageHeaders>) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterParser
-
- doParse(Element, ParserContext, String) - Method in class org.springframework.xd.integration.reactor.config.SyslogInboundChannelAdapterParser
-
- doSendLine(String) - Method in class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter
-
- doSendLine(String) - Method in class org.springframework.integration.x.twitter.TwitterSearchChannelAdapter
-
- doSendLine(String) - Method in class org.springframework.integration.x.twitter.TwitterStreamChannelAdapter
-
- doStart() - Method in class org.springframework.integration.x.http.NettyHttpInboundChannelAdapter
-
- doStart() - Method in class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter
-
- doStart() - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
Subclasses may override this method with the start behaviour.
- doStart() - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistMessageHandler
-
- doStart() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
Subclasses may override this method with the start behaviour.
- doStart() - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapter
-
- doStop() - Method in class org.springframework.integration.x.http.NettyHttpInboundChannelAdapter
-
- doStop() - Method in class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter
-
- doStop() - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
Subclasses may override this method with the stop behaviour.
- doStop() - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistMessageHandler
-
- doStop() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsDataStoreMessageHandler
-
- doStop() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsPartitionDataStoreMessageHandler
-
- doStop() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
Subclasses may override this method with the stop behaviour.
- doStop() - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapter
-
- doWrite(Message<?>) - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
Subclasses need to implement this method to handle Message
in its writer.
- doWrite(Message<?>) - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistMessageHandler
-
- doWrite(Message<?>) - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsDataStoreMessageHandler
-
- doWrite(Message<?>) - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsPartitionDataStoreMessageHandler
-
- doWrite(Message<?>) - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
Subclasses need to implement this method to handle Message
in its writer.
- doWrite(Message<?>) - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsWritingMessageHandler
-
- driverClassName - Variable in class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- dropCollection(String) - Method in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
The drops the collection.
- dropExternalReadableTable(LoadConfiguration, String) - Static method in class org.springframework.xd.greenplum.support.SqlUtils
-
- dropTable(String) - Method in class org.springframework.xd.test.fixtures.JdbcSink
-
- du(String, boolean) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- dummy(String, ModuleType) - Static method in class org.springframework.xd.module.TestModuleDefinitions
-
Create a new definition for a dummy module, for testing purposes only.
- dumpContainerApplicationContextConfiguration(ApplicationContext) - Static method in class org.springframework.xd.dirt.server.ApplicationUtils
-
Dump container context configuration details to stdout
- dumpContextConfiguration() - Method in class org.springframework.xd.dirt.server.container.ContainerServerApplication
-
- DURABLE - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
Durable pub/sub consumer.
- FAIL - Static variable in class org.springframework.xd.dirt.job.dsl.Transition
-
- failedComponentName() - Method in class org.springframework.xd.shell.hadoop.ConfigurationAware
-
- failedComponentName() - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- failure(Exception) - Method in class org.springframework.xd.dirt.stream.DocumentParseResult
-
- fairQueue - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- FETCH_SIZE - Static variable in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- FieldSetConverter - Class in org.springframework.xd.mongodb
-
A converter that maps from the batch FieldSet
world to Mongo's DBObject
.
- FieldSetConverter() - Constructor for class org.springframework.xd.mongodb.FieldSetConverter
-
- FieldSetSqlParameterSourceProvider - Class in org.springframework.xd.batch.item.jdbc
-
An ItemSqlParameterSourceProvider
that will derive parameters from a FieldSet
.
- FieldSetSqlParameterSourceProvider() - Constructor for class org.springframework.xd.batch.item.jdbc.FieldSetSqlParameterSourceProvider
-
- FieldSetType - Enum in org.springframework.xd.tuple.batch
-
Enum used to provide typing information when reading from a file.
- FieldValueCounter - Class in org.springframework.xd.analytics.metrics.core
-
Represents the data stored in a Counter for multiple field-value pairs.
- FieldValueCounter(String) - Constructor for class org.springframework.xd.analytics.metrics.core.FieldValueCounter
-
- FieldValueCounter(String, Map<String, Double>) - Constructor for class org.springframework.xd.analytics.metrics.core.FieldValueCounter
-
- FieldValueCounterCommands - Class in org.springframework.xd.shell.command
-
Commands for interacting with field value counter analytics.
- FieldValueCounterCommands() - Constructor for class org.springframework.xd.shell.command.FieldValueCounterCommands
-
- FieldValueCounterHandler - Class in org.springframework.xd.analytics.metrics.integration
-
Counts the occurrence of values for a set of JavaBean properties or Tuple fields using a FieldValueCounterRepository.
- FieldValueCounterHandler(FieldValueCounterRepository, String, String) - Constructor for class org.springframework.xd.analytics.metrics.integration.FieldValueCounterHandler
-
- FieldValueCounterOperations - Interface in org.springframework.xd.rest.client
-
Interface defining operations available when dealing with Field Value Counters.
- FieldValueCounterRepository - Interface in org.springframework.xd.analytics.metrics.core
-
A repository to save, delete and find FieldValueCounter instances.
- FieldValueCounterResource - Class in org.springframework.xd.rest.domain.metrics
-
A deep representation of a FieldValueCounter
- FieldValueCounterResource() - Constructor for class org.springframework.xd.rest.domain.metrics.FieldValueCounterResource
-
No arg constructor for serialization frameworks.
- FieldValueCounterResource(String, Map<String, Double>) - Constructor for class org.springframework.xd.rest.domain.metrics.FieldValueCounterResource
-
- FieldValueCountersController - Class in org.springframework.xd.dirt.rest.metrics
-
- FieldValueCountersController(FieldValueCounterRepository) - Constructor for class org.springframework.xd.dirt.rest.metrics.FieldValueCountersController
-
- FieldValueCounterSinkOptionsMetadata - Class in org.springframework.xd.analytics.metrics.metadata
-
Captures options for the field-value-counter
sink module.
- FieldValueCounterSinkOptionsMetadata() - Constructor for class org.springframework.xd.analytics.metrics.metadata.FieldValueCounterSinkOptionsMetadata
-
- FieldValueCounterTemplate - Class in org.springframework.xd.rest.client.impl
-
Implementation of the Field Value Counter part of the metrics API.
- FieldValueCounterTemplate(AbstractTemplate) - Constructor for class org.springframework.xd.rest.client.impl.FieldValueCounterTemplate
-
- file(String, String) - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Construct a new fileSink that will write the result to the dir and filename specified.
- file() - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Construct a new fileSink that will write the result to the xd output directory using the stream name as the
filename.
- file(String, String) - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new SimpleFileSource using the provided directory and filename
- file - Variable in class org.springframework.xd.test.fixtures.DisposableFileSupport
-
- FileAsRefMixin - Class in org.springframework.xd.dirt.modules.metadata
-
A mixin that can be used every time a module dealing with Files offers
the choice to pass along the File itself or its contents.
- FileAsRefMixin() - Constructor for class org.springframework.xd.dirt.modules.metadata.FileAsRefMixin
-
- FileAuthenticationConfiguration - Class in org.springframework.xd.dirt.server.security
-
A security configuration that conditionally sets up in-memory users from a file.
- FileAuthenticationConfiguration() - Constructor for class org.springframework.xd.dirt.server.security.FileAuthenticationConfiguration
-
- FileDeletionStepExecutionListener - Class in org.springframework.xd.dirt.plugins.job.support.listener
-
Step listener which can be used to delete files once they have been successfully processed by XD.
- FileDeletionStepExecutionListener() - Constructor for class org.springframework.xd.dirt.plugins.job.support.listener.FileDeletionStepExecutionListener
-
- fileExists(String) - Method in class org.springframework.xd.integration.util.HadoopUtils
-
Verifies that the file exists.
- fileExists(String, String, String) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Verifies the specified path exists on remote machine.
- fileJdbcJob() - Method in class org.springframework.xd.integration.fixtures.Jobs
-
Create an instance of the FileJdbc job with the default target dir, fileName, tableName and column names.
- FileJdbcJob - Class in org.springframework.xd.test.fixtures
-
A test fixture that represents the FileJdbc Job
- FileJdbcJob(String, String, String, String, boolean) - Constructor for class org.springframework.xd.test.fixtures.FileJdbcJob
-
Construct a new FileJdbcJob using the provided directory and file names.
- FileJdbcJobOptionsMetadata - Class in org.springframework.xd.jdbc
-
Captures options for the filejdbc
job.
- FileJdbcJobOptionsMetadata() - Constructor for class org.springframework.xd.jdbc.FileJdbcJobOptionsMetadata
-
- FileLogger - Class in org.springframework.xd.spark.streaming.examples.java
-
- FileLogger() - Constructor for class org.springframework.xd.spark.streaming.examples.java.FileLogger
-
- FileLoggerModuleOptionsMetadata - Class in org.springframework.xd.spark.streaming.examples.java
-
- FileLoggerModuleOptionsMetadata() - Constructor for class org.springframework.xd.spark.streaming.examples.java.FileLoggerModuleOptionsMetadata
-
- fileName(String) - Method in class org.springframework.xd.test.fixtures.FilePollHdfsJob
-
Sets the fileName that the hdfs will write to.
- fileName(String) - Method in class org.springframework.xd.test.fixtures.HdfsJdbcJob
-
Sets the fileName of the file to be read
- fileName(String) - Method in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
Sets the fileName of the file to be read
- fileName(String) - Method in class org.springframework.xd.test.fixtures.HdfsSink
-
Sets the file Name that the hdfs sink will write the data.
- fileName(String) - Method in class org.springframework.xd.test.fixtures.SimpleFileSink
-
Establishes the filename the SimpleFileSink will associate with the file.
- filePollHdfsJob(String) - Method in class org.springframework.xd.integration.fixtures.Jobs
-
Creates an instance of the FilePollHdfsJob using defaults.
- FilePollHdfsJob - Class in org.springframework.xd.test.fixtures
-
Test fixture that creates a File Poll Hdfs Job.
- FilePollHdfsJob(String, String, String) - Constructor for class org.springframework.xd.test.fixtures.FilePollHdfsJob
-
Initializes an instance of FilePollHdfsJob
- FilePollHdfsJobOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Describes the options for the filepollhdfs job.
- FilePollHdfsJobOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.FilePollHdfsJobOptionsMetadata
-
- FileReadingMode - Enum in org.springframework.xd.dirt.modules.metadata
-
Defines the supported modes of reading and processing files for the
File
, FTP
and SFTP
sources.
- fileRegistrar() - Method in class org.springframework.xd.dirt.server.MessageBusExtensionsConfiguration
-
- fileRemove(String) - Method in class org.springframework.xd.integration.util.HadoopUtils
-
Recursively removes files in a directory or if only a file just that file.
- FileSink - Class in org.springframework.xd.test.fixtures
-
Support class to capture output of a sink in a File.
- FileSink() - Constructor for class org.springframework.xd.test.fixtures.FileSink
-
Create a file sink, but make sure that the future file is not present yet, so it can be waited upon with
FileSink.getContents()
.
- FileSink.FileSinkContentsMatcher - Class in org.springframework.xd.test.fixtures
-
A matcher on the String contents of the sink, that delegates to another (String) matcher.
- FileSink.FileSinkContentsMatcher(Matcher<String>) - Constructor for class org.springframework.xd.test.fixtures.FileSink.FileSinkContentsMatcher
-
- FileSink.FileSinkTrimmedContentsMatcher - Class in org.springframework.xd.test.fixtures
-
A matcher on the trimmed String contents of the sink, that delegates to another (String) matcher.
- FileSink.FileSinkTrimmedContentsMatcher(Matcher<String>) - Constructor for class org.springframework.xd.test.fixtures.FileSink.FileSinkTrimmedContentsMatcher
-
- FileSinkOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Holds options to the 'file' sink module.
- FileSinkOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- FileSinkOptionsMetadata.Mode - Enum in org.springframework.xd.dirt.modules.metadata
-
- FileSource - Class in org.springframework.xd.test.fixtures
-
Support class that represents the file source module.
- FileSource() - Constructor for class org.springframework.xd.test.fixtures.FileSource
-
- FileSourceOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Holds module options metadata about the file
source.
- FileSourceOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.FileSourceOptionsMetadata
-
- filesToFetch(String) - Method in interface org.springframework.batch.integration.x.RemoteFilePartitioner.Gateway
-
- filterContainers(ModuleDescriptor, Iterable<Container>) - Method in interface org.springframework.xd.dirt.cluster.ContainerFilter
-
- filterContainers(ModuleDescriptor, Iterable<Container>) - Method in class org.springframework.xd.dirt.spark.SparkStreamingContainerFilter
-
Return the list of containers that can deploy this module.
- finalizeConverter(char) - Method in class org.springframework.xd.dirt.util.logging.VersionPatternParser
-
- find(String, ModuleType) - Method in interface org.springframework.xd.dirt.module.ModuleDependencyRepository
-
Return the set of things that depend on the given module.
- find(String, ModuleType) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleDependencyRepository
-
- findAll() - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- findAll() - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- findAll(Iterable<String>) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- findAll() - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- findAll(Iterable<String>) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- findAll() - Method in interface org.springframework.xd.dirt.container.store.AdminRepository
-
Returns all admin runtime entities.
- findAll() - Method in class org.springframework.xd.dirt.container.store.ZooKeeperAdminRepository
-
Returns all admin runtime entities.
- findAll(Sort) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- findAll(Pageable) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- findAll() - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- findAll(Iterable<String>) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- findAll() - Method in interface org.springframework.xd.dirt.core.ResourceDeployer
-
- findAll(Pageable) - Method in interface org.springframework.xd.dirt.core.ResourceDeployer
-
Return a slice of all definitions.
- findAll(Sort) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- findAll(Pageable) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- findAll() - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- findAll(Iterable<ModuleMetadata.Id>) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- findAll() - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- findAll(Pageable) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- findAll(Sort) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- findAll(Pageable) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- findAll() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- findAll(Iterable<String>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- findAll(Sort) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- findAll(Pageable) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- findAll() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- findAll(Iterable<String>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- findAll(Sort) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- findAll(Pageable) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- findAll() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- findAll(Iterable<String>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- findAll(Sort) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- findAll(Pageable) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- findAll() - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- findAll(Iterable<String>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- findAll() - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
- findAll(Pageable) - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
- findAll(Sort) - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
- findAll() - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- findAll(Iterable<ID>) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- findAll(Pageable) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- findAll(Sort) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- findAll(Iterable<ID>) - Method in class org.springframework.xd.store.AbstractRepository
-
- findAllByContainerId(Pageable, String) - Method in interface org.springframework.xd.dirt.module.store.ModuleMetadataRepository
-
Find paged
ModuleMetadata
for all the modules deployed
into the given container.
- findAllByContainerId(String) - Method in interface org.springframework.xd.dirt.module.store.ModuleMetadataRepository
-
Find all the modules that are deployed into the given container.
- findAllByContainerId(Pageable, String) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
Find paged
ModuleMetadata
for all the modules deployed
into the given container.
- findAllByContainerId(String) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
Find all the modules that are deployed into this container.
- findAllByModuleId(Pageable, String) - Method in interface org.springframework.xd.dirt.module.store.ModuleMetadataRepository
-
- findAllByModuleId(Pageable, String) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- findAllInRange(String, boolean, String, boolean) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
-
Return entities whose ids range between from
and to
.
- findAllInRange(ModuleMetadata.Id, boolean, ModuleMetadata.Id, boolean) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- findAllInRange(String, boolean, String, boolean) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- findAllInRange(String, boolean, String, boolean) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- findAllInRange(String, boolean, String, boolean) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- findAllInRange(String, boolean, String, boolean) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- findAllInRange(ID, boolean, ID, boolean) - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
- findAllInRange(ID, boolean, ID, boolean) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- findAllInRange(ID, boolean, ID, boolean) - Method in interface org.springframework.xd.store.RangeCapableRepository
-
Return entities whose ids range between from
and to
.
- findAllRuntimeContainers(Pageable, boolean) - Method in interface org.springframework.xd.dirt.container.store.ContainerRepository
-
- findAllRuntimeContainers(Pageable, boolean) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
-
- findDefinition(String, ModuleType) - Method in class org.springframework.xd.dirt.module.DelegatingModuleRegistry
-
- findDefinition(String, ModuleType) - Method in interface org.springframework.xd.dirt.module.ModuleRegistry
-
Lookup a module of the given type with the given name.
- findDefinition(String, ModuleType) - Method in class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
- findDefinition(String, ModuleType) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperComposedModuleDefinitionRegistry
-
- findDefinition(String, ModuleType) - Method in class org.springframework.xd.dirt.module.support.ModuleDefinitionService
-
- findDefinition(String, ModuleType) - Method in class org.springframework.xd.dirt.module.SynchronizingModuleRegistry
-
- findDefinition(String, ModuleType) - Method in class org.springframework.xd.dirt.test.SingletonModuleRegistry
-
- findDefinitions(String) - Method in class org.springframework.xd.dirt.module.DelegatingModuleRegistry
-
- findDefinitions(ModuleType) - Method in class org.springframework.xd.dirt.module.DelegatingModuleRegistry
-
- findDefinitions() - Method in class org.springframework.xd.dirt.module.DelegatingModuleRegistry
-
- findDefinitions(String) - Method in interface org.springframework.xd.dirt.module.ModuleRegistry
-
Searches the registry for the name specified and returns all module definitions that match the name regardless of
module type.
- findDefinitions(ModuleType) - Method in interface org.springframework.xd.dirt.module.ModuleRegistry
-
Searches the registry for the type specified and returns all module definitions that match the type.
- findDefinitions() - Method in interface org.springframework.xd.dirt.module.ModuleRegistry
-
Returns all module definitions.
- findDefinitions(String) - Method in class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
- findDefinitions(ModuleType) - Method in class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
- findDefinitions() - Method in class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
- findDefinitions(String) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperComposedModuleDefinitionRegistry
-
- findDefinitions(ModuleType) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperComposedModuleDefinitionRegistry
-
- findDefinitions() - Method in class org.springframework.xd.dirt.module.store.ZooKeeperComposedModuleDefinitionRegistry
-
- findDefinitions(Pageable, String) - Method in class org.springframework.xd.dirt.module.support.ModuleDefinitionService
-
- findDefinitions(Pageable, ModuleType) - Method in class org.springframework.xd.dirt.module.support.ModuleDefinitionService
-
- findDefinitions(Pageable) - Method in class org.springframework.xd.dirt.module.support.ModuleDefinitionService
-
- findDefinitions(String) - Method in class org.springframework.xd.dirt.module.SynchronizingModuleRegistry
-
- findDefinitions(ModuleType) - Method in class org.springframework.xd.dirt.module.SynchronizingModuleRegistry
-
- findDefinitions() - Method in class org.springframework.xd.dirt.module.SynchronizingModuleRegistry
-
- findDefinitions(String) - Method in class org.springframework.xd.dirt.test.SingletonModuleRegistry
-
- findDefinitions(ModuleType) - Method in class org.springframework.xd.dirt.test.SingletonModuleRegistry
-
- findDefinitions() - Method in class org.springframework.xd.dirt.test.SingletonModuleRegistry
-
- findOne(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- findOne(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- findOne(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- findOne(String) - Method in interface org.springframework.xd.dirt.container.store.AdminRepository
-
Retrieves a admin runtime by its id.
- findOne(String) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperAdminRepository
-
Retrieves a admin runtime by its id.
- findOne(String) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- findOne(String) - Method in interface org.springframework.xd.dirt.core.ResourceDeployer
-
Retrieves a single Definition or null if none is found.
- findOne(String, String) - Method in interface org.springframework.xd.dirt.module.store.ModuleMetadataRepository
-
Find
ModuleMetadata
for the module that has the given module id and
deployed into given container.
- findOne(String, String) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
Find
ModuleMetadata
for the module that has the given module id and
deployed into given container.
- findOne(ModuleMetadata.Id) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
- findOne(String) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- findOne(String) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- findOne(String) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- findOne(String) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- findOne(String) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- findOne(ID) - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
- findOne(ID) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- fixedDelay(int) - Method in class org.springframework.xd.test.fixtures.JdbcSource
-
- FixtureUtils - Class in org.springframework.xd.test.fixtures.util
-
Utility to support common tasks done by fixtures.
- FixtureUtils() - Constructor for class org.springframework.xd.test.fixtures.util.FixtureUtils
-
- FlattenedCompositeModuleOptionsMetadata - Class in org.springframework.xd.module.options
-
- FlattenedCompositeModuleOptionsMetadata(List<? extends ModuleOptionsMetadata>) - Constructor for class org.springframework.xd.module.options.FlattenedCompositeModuleOptionsMetadata
-
- Flow - Class in org.springframework.xd.dirt.job.dsl
-
The AST node representing a flow.
- Flow(List<JobNode>) - Constructor for class org.springframework.xd.dirt.job.dsl.Flow
-
- flush() - Method in class org.springframework.integration.x.kafka.WindowingOffsetManager
-
- folder - Variable in class org.springframework.xd.test.fixtures.AbstractMailSource
-
- forConsumer(String, AbstractEndpoint, MessageChannel, AbstractBusPropertiesAccessor) - Static method in class org.springframework.xd.dirt.integration.bus.Binding
-
- forDirectProducer(String, MessageChannel, AbstractEndpoint, AbstractBusPropertiesAccessor) - Static method in class org.springframework.xd.dirt.integration.bus.Binding
-
- format(int) - Method in class org.springframework.xd.dirt.job.dsl.AstNode
-
- format() - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
Pretty print the text for this job specification, including appropriate
newlines and indentation.
- Format - Enum in org.springframework.xd.greenplum.support
-
- format(Date, StringBuffer, FieldPosition) - Method in class org.springframework.xd.rest.domain.util.ISO8601DateFormatWithMilliSeconds
-
- formatDeploymentProperties(Map<String, String>) - Static method in class org.springframework.xd.rest.domain.support.DeploymentPropertiesFormat
-
Returns a String representation of deployment properties as a comma separated list of key=value pairs.
- formatMessage(int, Object...) - Method in enum org.springframework.xd.dirt.job.dsl.JobDSLMessage
-
Produce a complete message including the prefix, the position (if known) and with the inserts applied to the
message.
- formatMessage(int, Object...) - Method in enum org.springframework.xd.dirt.stream.dsl.XDDSLMessages
-
Produce a complete message including the prefix, the position (if known) and with the inserts applied to the
message.
- forProducer(String, MessageChannel, AbstractEndpoint, AbstractBusPropertiesAccessor) - Static method in class org.springframework.xd.dirt.integration.bus.Binding
-
- framing - Variable in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- from - Variable in class org.springframework.xd.dirt.job.dsl.Link
-
- from(String) - Method in class org.springframework.xd.test.fixtures.MailSink
-
- fromBindException(String, ModuleType, BindException) - Static method in exception org.springframework.xd.dirt.plugins.ModuleConfigurationException
-
Construct an exception following a configuration exception on a particular module.
- fromBytes(byte[]) - Method in class org.springframework.xd.dirt.integration.kafka.IntegerEncoderDecoder
-
- fromClassName(String) - Static method in enum org.springframework.xd.dirt.job.StepType
-
- fromClassName(String) - Static method in enum org.springframework.xd.dirt.job.TaskletType
-
- fromMessage(Message<?>, Class<?>) - Method in class org.springframework.integration.x.http.NettyInboundMessageConverter
-
- fromModuleDescriptor(ModuleDescriptor) - Static method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Create a
Builder
object pre-populated with the configuration
for the provided
ModuleDescriptor
.
- FromMongoDbOptionMixin - Class in org.springframework.xd.module.options.mixins
-
An option class to mix-in when reading from MongoDB.
- FromMongoDbOptionMixin(String) - Constructor for class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin
-
Subclasses should provide a default value for collectionName.
- FromMongoDbOptionMixin.Job - Class in org.springframework.xd.module.options.mixins
-
Has collectionName
default to ${xd.job.name}.
- FromMongoDbOptionMixin.Job() - Constructor for class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin.Job
-
- FromMongoDbOptionMixin.Stream - Class in org.springframework.xd.module.options.mixins
-
Has collectionName
default to ${xd.stream.name}.
- FromMongoDbOptionMixin.Stream() - Constructor for class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin.Stream
-
- fromString(String) - Static method in class org.springframework.xd.tuple.TupleBuilder
-
- FromStringCharsetMixin - Class in org.springframework.xd.module.options.mixins
-
A standard mixin for modules that do conversion from String to bytes.
- FromStringCharsetMixin() - Constructor for class org.springframework.xd.module.options.mixins.FromStringCharsetMixin
-
- fromTuple(Tuple) - Method in class org.springframework.xd.tuple.TupleStringMarshaller
-
- FsShellCommands - Class in org.springframework.xd.shell.hadoop
-
HDFS shell commands
- FsShellCommands() - Constructor for class org.springframework.xd.shell.hadoop.FsShellCommands
-
- FtpConnectionMixin - Class in org.springframework.xd.module.options.mixins
-
A mixin that can be used anytime a connection to an FTP server is needed.
- FtpConnectionMixin() - Constructor for class org.springframework.xd.module.options.mixins.FtpConnectionMixin
-
- ftpHdfsJob() - Method in class org.springframework.xd.integration.fixtures.Jobs
-
Create a FtpHdfsJob Fixture using defaults.
- FtpHdfsJob - Class in org.springframework.xd.test.fixtures
-
Test fixture that creates a Ftp Hdfs Job.
- FtpHdfsJob(String, String) - Constructor for class org.springframework.xd.test.fixtures.FtpHdfsJob
-
- FtpHdfsJobOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Describes the options for the ftphdfs job.
- FtpHdfsJobOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.FtpHdfsJobOptionsMetadata
-
- FtpSink - Class in org.springframework.xd.test.fixtures
-
A fixture that helps testing the ftp sink.
- FtpSink() - Constructor for class org.springframework.xd.test.fixtures.FtpSink
-
- FtpSinkOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Module options for the FTP sink module.
- FtpSinkOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- FtpSource - Class in org.springframework.xd.test.fixtures
-
A fixture that helps testing the ftp source.
- FtpSource() - Constructor for class org.springframework.xd.test.fixtures.FtpSource
-
- FtpSourceOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Module options for FTP source module.
- FtpSourceOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- fvcOperations() - Method in class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- fvcOperations() - Method in interface org.springframework.xd.rest.client.SpringXDOperations
-
Returns the portion of the API for interaction with Field Value Counters.
- Gauge - Class in org.springframework.xd.analytics.metrics.core
-
Represents the data stored in a Gauge which can be set to any integral value.
- Gauge(String) - Constructor for class org.springframework.xd.analytics.metrics.core.Gauge
-
Construct a new Gauge given a name
- Gauge(String, long) - Constructor for class org.springframework.xd.analytics.metrics.core.Gauge
-
Construct a new Gauge given a name and a initial value of the value
- GaugeCommands - Class in org.springframework.xd.shell.command
-
Commands for interacting with Gauge analytics.
- GaugeCommands() - Constructor for class org.springframework.xd.shell.command.GaugeCommands
-
- GaugeHandler - Class in org.springframework.xd.analytics.metrics.integration
-
- GaugeHandler(GaugeRepository, String) - Constructor for class org.springframework.xd.analytics.metrics.integration.GaugeHandler
-
- GaugeOperations - Interface in org.springframework.xd.rest.client
-
Interface defining operations available when dealing with Gauge.
- gaugeOperations() - Method in class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- gaugeOperations() - Method in interface org.springframework.xd.rest.client.SpringXDOperations
-
Returns the portion of the API for interaction with Gauge.
- GaugeRepository - Interface in org.springframework.xd.analytics.metrics.core
-
A marker interface for Gauge repositories.
- GaugeResource - Class in org.springframework.xd.rest.domain.metrics
-
The REST representation of a Gauge.
- GaugeResource() - Constructor for class org.springframework.xd.rest.domain.metrics.GaugeResource
-
No-arg constructor for serialization frameworks.
- GaugeResource(String, long) - Constructor for class org.springframework.xd.rest.domain.metrics.GaugeResource
-
- GaugesController - Class in org.springframework.xd.dirt.rest.metrics
-
Exposes representations of
Gauge
s.
- GaugesController(GaugeRepository) - Constructor for class org.springframework.xd.dirt.rest.metrics.GaugesController
-
- GaugeTemplate - Class in org.springframework.xd.rest.client.impl
-
Implementation of the Gauge part of the metrics API.
- GaugeTemplate(AbstractTemplate) - Constructor for class org.springframework.xd.rest.client.impl.GaugeTemplate
-
- gemFireCqSource(String) - Method in class org.springframework.xd.integration.fixtures.Sources
-
- GemFireCQSource - Class in org.springframework.xd.test.fixtures
-
Create a gemfire CQ (continuous query) source.
- GemFireCQSource(String) - Constructor for class org.springframework.xd.test.fixtures.GemFireCQSource
-
Create a Gemfire Sink module.
- GemfireCQSourceOptionsMetadata - Class in org.springframework.xd.gemfire
-
Describes options to the gemfire-cq
source module.
- GemfireCQSourceOptionsMetadata() - Constructor for class org.springframework.xd.gemfire.GemfireCQSourceOptionsMetadata
-
- GemfireHostPortMixin - Class in org.springframework.xd.gemfire
-
- GemfireHostPortMixin() - Constructor for class org.springframework.xd.gemfire.GemfireHostPortMixin
-
- gemfireServer(String) - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Construct a new GemfireServer sink.
- GemFireServerSink - Class in org.springframework.xd.test.fixtures
-
Create a gemfire-server or gemfire-json-server sink.
- GemFireServerSink(String) - Constructor for class org.springframework.xd.test.fixtures.GemFireServerSink
-
Create a Gemfire Sink module.
- GemfireServerSinkModuleOptionsMetadata - Class in org.springframework.xd.gemfire
-
Captures module options for the "gemfire-server" and "gemfire-json-server" sink modules.
- GemfireServerSinkModuleOptionsMetadata() - Constructor for class org.springframework.xd.gemfire.GemfireServerSinkModuleOptionsMetadata
-
- gemFireSource(String) - Method in class org.springframework.xd.integration.fixtures.Sources
-
- GemFireSource - Class in org.springframework.xd.test.fixtures
-
Create a gemfire source
- GemFireSource(String) - Constructor for class org.springframework.xd.test.fixtures.GemFireSource
-
Create a Gemfire Sink module.
- GemfireSourceOptionsMetadata - Class in org.springframework.xd.gemfire
-
Describes options to the gemfire
source module.
- GemfireSourceOptionsMetadata() - Constructor for class org.springframework.xd.gemfire.GemfireSourceOptionsMetadata
-
- generateCode(String, MethodVisitor, CodeFlow) - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor.MessageOptimalPropertyAccessor
-
- generateModuleFromJackson(String, Map<?, ?>) - Static method in class org.springframework.xd.integration.util.jmxresult.Module
-
Retrieves the module data from the key and value data returned from Jackson.
- generateSplunkEvent(Object) - Method in class org.springframework.integration.x.splunk.SplunkTransformer
-
- GeneratorException - Exception in org.springframework.xd.test.generator
-
Core exception for generators.
- GeneratorException(String, Throwable) - Constructor for exception org.springframework.xd.test.generator.GeneratorException
-
Constructs a new GeneratorException
instance.
- get(String) - Method in class org.springframework.integration.x.kafka.NamespaceDelegatingMetadataStore
-
- get(Object) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- get(Object) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- get(Object) - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- get(Object) - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- get(String, String, boolean, boolean) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- getAbandonWhenPercentageFull() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getAccessToken() - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- getAccessTokenSecret() - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- getAckMode() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getAcknowledge() - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- getAckTimeoutOnServer() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getAddresses() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- getAdminServerPort() - Method in class org.springframework.xd.test.RandomConfigurationSupport
-
- getAdminServerUrl() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- getAggregation() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getAllModuleDeploymentRequests() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer
-
Get all the module deployment requests.
- getAllPossibleValues(List<Completion>, Class<?>, String, String, MethodTarget) - Method in class org.springframework.xd.shell.converter.CompletionConverter
-
- getAllPossibleValues(List<Completion>, Class<?>, String, String, MethodTarget) - Method in class org.springframework.xd.shell.converter.ExistingXDEntityConverter
-
- getAllPossibleValues(List<Completion>, Class<?>, String, String, MethodTarget) - Method in class org.springframework.xd.shell.converter.MediaTypeConverter
-
- getAllPossibleValues(List<Completion>, Class<?>, String, String, MethodTarget) - Method in class org.springframework.xd.shell.converter.NumberFormatConverter
-
- getAllPossibleValues(List<Completion>, Class<?>, String, String, MethodTarget) - Method in class org.springframework.xd.shell.converter.QualifiedModuleNameConverter
-
- getAllRestartableJobs() - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
Get all the deployed job names that can be restarted.
- getAlpha() - Method in class org.springframework.xd.analytics.metrics.core.RichGauge
-
- getAlpha() - Method in class org.springframework.xd.analytics.metrics.metadata.RichGaugeSinkOptionsMetadata
-
- getAlpha() - Method in class org.springframework.xd.rest.domain.metrics.RichGaugeResource
-
- getAppJar() - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- getAppJar() - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- getApplicationContext() - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- getApplicationContext() - Method in class org.springframework.xd.dirt.plugins.AbstractPlugin
-
- getApplicationContext() - Method in class org.springframework.xd.module.core.CompositeModule
-
- getApplicationContext() - Method in interface org.springframework.xd.module.core.Module
-
- getApplicationContext() - Method in class org.springframework.xd.module.core.SimpleModule
-
- getArgs() - Method in class org.springframework.xd.sqoop.SqoopOptionsMetadata
-
- getArguments() - Method in class org.springframework.xd.dirt.job.dsl.JobDescriptor
-
- getArguments() - Method in class org.springframework.xd.dirt.stream.dsl.ModuleNode
-
- getArguments() - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- getArgumentsAsProperties() - Method in class org.springframework.xd.dirt.stream.dsl.ModuleNode
-
- getAttribute(String) - Method in class org.springframework.xd.rest.domain.DetailedContainerResource
-
Get the attribute value by given name.
- getAttributes() - Method in class org.springframework.xd.dirt.cluster.Admin
-
- getAttributes() - Method in class org.springframework.xd.dirt.cluster.Container
-
- getAttributes() - Method in class org.springframework.xd.dirt.event.AbstractEvent
-
- getAttributes() - Method in class org.springframework.xd.dirt.plugins.job.support.listener.ChunkContextInfo
-
- getAttributes() - Method in class org.springframework.xd.rest.domain.DetailedContainerResource
-
Get all the container attributes.
- getAuthenticationDatabaseName() - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- getAuthProvider() - Method in class org.springframework.xd.cassandra.CassandraConfiguration
-
- getAutoOffsetReset() - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- getAutoOffsetResetValue() - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- getAvailableContainers(URL) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Creates a map of container Id's and the associated host.
- getAverage() - Method in class org.springframework.xd.analytics.metrics.core.RichGauge
-
Either an exponential weighted moving average or a simple mean, respectively, depending on whether the weight
'alpha' has been set for this gauge.
- getAverage() - Method in class org.springframework.xd.rest.domain.metrics.RichGaugeResource
-
Return the average value for the gauge.
- getBackOffInitialInterval(long) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the 'backOffInitialInterval' property or the default value.
- getBackOffMaxInterval(long) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the 'backOffMaxInterval' property or the default value.
- getBackOffMultiplier(double) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the 'backOffMultiplier' property or the default value.
- getBanner() - Method in class org.springframework.xd.shell.XDShellBannerProvider
-
- getBaseDir() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- getBaseFilename() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- getBaseFilename() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- getBaseFilename() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- getBaseFilename() - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- getBasePath() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- getBasePath() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- getBasePath() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- getBasePath() - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- getBatchBytes() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getBatchCount() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getBatchInterval() - Method in class org.springframework.xd.spark.streaming.DefaultSparkStreamingModuleOptionsMetadata
-
- getBatchPeriod() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getBatchSize(int) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
The batch size.
- getBatchTimeout(long) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
The batch timeout.
- getBatchTimeout() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getBcc() - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- getBean(String, Class<T>) - Method in class org.springframework.xd.dirt.integration.bus.local.LocalMessageBus
-
- getBeanClass(Element) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterParser
-
- getBeanFactory() - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- getBigDecimal(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getBigDecimal(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getBigDecimal(String, BigDecimal) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getBigDecimal(int, BigDecimal) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getBigDecimal(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'BigDecimal
' value at index 'index
'.
- getBigDecimal(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'BigDecimal
' value from column with given 'name
'.
- getBigDecimal(int, BigDecimal) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'BigDecimal
' value at index 'index
'.
- getBigDecimal(String, BigDecimal) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'BigDecimal
' value from column with given 'name
'.
- getBoolean(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getBoolean(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getBoolean(int, String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getBoolean(String, String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getBoolean(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'boolean
' value at index 'index
'.
- getBoolean(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'boolean
' value from field with given 'name
'.
- getBoolean(int, String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'boolean
' value at index 'index
'.
- getBoolean(String, String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'boolean
' value from column with given 'name
'.
- getBrokerAddress() - Method in class org.springframework.xd.test.kafka.KafkaTestSupport
-
- getBrokerList() - Method in class org.springframework.integration.x.kafka.KafkaSinkModuleOptionsMetadata
-
- getBufferMemory() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getBufferSize() - Method in class org.springframework.xd.tcp.encdec.EncoderDecoderMixins.BufferSizeMixin
-
- getByte(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getByte(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getByte(String, byte) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getByte(int, byte) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getByte(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'byte
' value at index 'index
'.
- getByte(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'byte
' value from column with given 'name
'.
- getByte(int, byte) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'byte
' value at index 'index
'.
- getByte(String, byte) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'byte
' value from column with given 'name
'.
- getBytesWritten() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- getBytesWritten() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- getBytesWritten() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- getCacheEventExpression() - Method in class org.springframework.xd.gemfire.GemfireSourceOptionsMetadata
-
- getCandidateTypes() - Method in exception org.springframework.xd.dirt.module.NoSuchModuleException
-
- getCc() - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- getChannel() - Method in class org.springframework.xd.dirt.integration.bus.Binding
-
- getChannelName() - Method in class org.springframework.xd.dirt.stream.dsl.SinkChannelNode
-
- getChannelName() - Method in class org.springframework.xd.dirt.stream.dsl.SourceChannelNode
-
- getChannelNode() - Method in class org.springframework.xd.dirt.stream.dsl.SinkChannelNode
-
- getChannelNode() - Method in class org.springframework.xd.dirt.stream.dsl.SourceChannelNode
-
- getChannelType() - Method in class org.springframework.xd.dirt.stream.dsl.SourceChannelNode
-
- getChar(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getChar(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getChar(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'char
' value at index 'index
'.
- getChar(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'char
' value from field with given 'name
'.
- getCharset() - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- getCharset() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- getCharset() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- getCharset() - Method in class org.springframework.xd.http.HttpClientProcessorOptionsMetadata
-
- getCharset() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- getCharset() - Method in class org.springframework.xd.module.options.mixins.FromStringCharsetMixin
-
- getCharset() - Method in class org.springframework.xd.module.options.mixins.ToStringCharsetMixin
-
- getCheckColumn() - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- getCheckpointPointer() - Method in exception org.springframework.xd.dirt.job.dsl.CheckpointedJobDefinitionException
-
- getCheckpointPointer() - Method in exception org.springframework.xd.dirt.stream.dsl.CheckpointedStreamDefinitionException
-
- getCheckpointPosition() - Method in exception org.springframework.xd.dirt.job.dsl.CheckpointedJobDefinitionException
-
- getCheckpointPosition() - Method in exception org.springframework.xd.dirt.stream.dsl.CheckpointedStreamDefinitionException
-
- getChildJobExecutions(long) - Method in class org.springframework.xd.dirt.job.dao.XdJdbcSearchableJobExecutionDao
-
- getChildJobExecutions(long) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobService
-
Get a list of all JobExecution
s that are direct children to the
provided JobExecution
ID.
- getChildJobExecutions() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getChildren() - Method in class org.springframework.xd.module.CompositeModuleDefinition
-
Return information about the sub-modules that make up this composed module.
- getChildren() - Method in class org.springframework.xd.module.ModuleDescriptor
-
If this is a composite module, this list contains the modules that this
module consists of; otherwise this list is empty.
- getClassLoader() - Method in class org.springframework.xd.module.core.SimpleModule
-
- getClassName() - Method in enum org.springframework.xd.dirt.job.StepType
-
- getClassName() - Method in enum org.springframework.xd.dirt.job.TaskletType
-
- getClient() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentQueue
-
Return the Curator client.
- getClient() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer
-
Return the Curator framework client.
- getClient() - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
Provides access to the underlying CuratorFramework
instance.
- getClientId() - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- getClientId() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- getClientId() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- getClientMode() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- getClientMode() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- getClientPort() - Method in class org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper
-
Returns the port that clients should use to connect to this embedded server.
- getClientTimeZone() - Method in class org.springframework.xd.shell.Configuration
-
- getCodec() - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- getCollectionName() - Method in class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin
-
- getCollectionName() - Method in class org.springframework.xd.module.options.mixins.IntoMongoDbOptionMixin
-
- getCollectionType() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- getColumnDelimiter() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getColumns() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- getColumns() - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- getColumns() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getColumns() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getColumns() - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- getColumns() - Method in class org.springframework.xd.jdbc.JdbcMessagePayloadTransformer
-
- getColumns() - Method in class org.springframework.xd.jdbc.JdbcSinkModuleOptionsMetadata
-
- getCommand() - Method in class org.springframework.xd.extension.process.ShellModuleOptionsMetadata
-
- getCommand() - Method in class org.springframework.xd.sqoop.SqoopOptionsMetadata
-
- getCommandDescription() - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- getCommandDescription() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getCommandDescription() - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- getCommandDisplayString() - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- getCommandDisplayString() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getCommandDisplayString() - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- getCommandName() - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- getCommandName() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getCommandName() - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- getCommitInterval() - Method in class org.springframework.xd.module.options.mixins.BatchJobCommitIntervalOptionMixin
-
- getComponent(Class<T>) - Method in class org.springframework.xd.module.core.CompositeModule
-
- getComponent(String, Class<T>) - Method in class org.springframework.xd.module.core.CompositeModule
-
- getComponent(Class<T>) - Method in interface org.springframework.xd.module.core.Module
-
Get a bean instance by its class.
- getComponent(String, Class<T>) - Method in interface org.springframework.xd.module.core.Module
-
Get a bean instance by its name and class.
- getComponent(Class<T>) - Method in class org.springframework.xd.module.core.SimpleModule
-
- getComponent(String, Class<T>) - Method in class org.springframework.xd.module.core.SimpleModule
-
- getComponentType() - Method in class org.springframework.integration.x.twitter.TwitterSearchChannelAdapter
-
- getComponentType() - Method in class org.springframework.integration.x.twitter.TwitterStreamChannelAdapter
-
- getComponentType() - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapter
-
- getComponentType() - Method in class org.springframework.xd.integration.reactor.syslog.SyslogInboundChannelAdapter
-
- getComposedJobModuleName(String) - Static method in class org.springframework.xd.dirt.job.dsl.ComposedJobUtil
-
Returns the composed module name for the job
- getCompressionCodec() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getCompressionType() - Method in class org.springframework.xd.cassandra.CassandraConfiguration
-
- getCompressionType() - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- getComputedNameExpression() - Method in class org.springframework.xd.analytics.metrics.metadata.MetricNameMixin
-
- getComputedNativeOptions() - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- getConcurrency(int) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the 'concurrency' property or the default value.
- getConcurrency() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getConf() - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- getConf() - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- getConfiguration() - Method in class org.springframework.xd.shell.hadoop.ConfigurationModifiedEvent
-
- getConnectionFactory() - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- getConnectionProperties() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getConnectionTimeout() - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- getConnectString() - Method in class org.springframework.xd.test.kafka.EmbeddedZookeeper
-
- getConnectTimeout() - Method in class org.springframework.integration.x.twitter.TwitterMixin
-
- getConsistencyLevel() - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- getConsumerKey() - Method in class org.springframework.integration.x.twitter.TwitterMixin
-
- getConsumerSecret() - Method in class org.springframework.integration.x.twitter.TwitterMixin
-
- getContactPoints() - Method in class org.springframework.xd.cassandra.CassandraConfiguration
-
- getContactPoints() - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- getContainer() - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Return the container name.
- getContainer() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Return the container name.
- getContainer() - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Return the container name.
- getContainer() - Method in class org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus
-
- getContainerHostForModulePrefix(String, ModuleType) - Method in class org.springframework.xd.integration.fixtures.ContainerResolver
-
Gets the URL of the container where the module
- getContainerHostForSource() - Method in class org.springframework.xd.integration.fixtures.ContainerResolver
-
Gets the host of the container where the source was deployed
- getContainerHostForSource(String) - Method in class org.springframework.xd.integration.fixtures.ContainerResolver
-
Gets the host of the container where the source was deployed
- getContainerId() - Method in class org.springframework.xd.dirt.event.AbstractModuleEvent
-
- getContainerId() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata
-
- getContainerId() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata.Id
-
Return the id for the container the module instance is deployed to.
- getContainerId() - Method in class org.springframework.xd.rest.domain.DetailedContainerResource
-
Get container id.
- getContainerId() - Method in class org.springframework.xd.rest.domain.ModuleMetadataResource
-
- getContainerLogLocation() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- getContainerPidsFromURL(URL, String, String) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Retrieves the container pids for a remote machine.
- getContainerResolver() - Method in class org.springframework.xd.integration.fixtures.ModuleFixture
-
Get the container resolver
- getContainerUrlForProcessor() - Method in class org.springframework.xd.integration.fixtures.ContainerResolver
-
Gets the URL of the container where the processor was deployed
- getContainerUrlForProcessor(String) - Method in class org.springframework.xd.integration.fixtures.ContainerResolver
-
Gets the URL of the container where the processor was deployed
- getContainerUrlForSink() - Method in class org.springframework.xd.integration.fixtures.ContainerResolver
-
Gets the URL of the container for the sink being tested.
- getContainerUrlForSink(String) - Method in class org.springframework.xd.integration.fixtures.ContainerResolver
-
Gets the URL of the container where the sink was deployed using default XD Port.
- getContainerUrlForSource() - Method in class org.springframework.xd.integration.fixtures.ContainerResolver
-
Gets the URL of the container for the source being tested.
- getContainerUrlForSource(String) - Method in class org.springframework.xd.integration.fixtures.ContainerResolver
-
Gets the URL of the container where the source was deployed using default XD Port.
- getContentType() - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- getContext() - Method in class org.springframework.xd.dirt.server.admin.AdminServerApplication
-
- getControlFile() - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- getControlFile() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getControlFile() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getConversionService() - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getConverter(Class<T>) - Method in class org.springframework.xd.module.options.support.StringToEnumIgnoringCaseConverterFactory
-
- getConverter(Class<T>) - Method in class org.springframework.xd.tuple.LocaleAwareStringToNumberConverterFactory
-
- getConverterClass() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSinkOptionsMetadata
-
- getConverterClass() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getCorrelation() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getCount() - Method in class org.springframework.xd.analytics.metrics.core.RichGauge
-
- getCount() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
The module count.
- getCount() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getCount(URL, String) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Retrieves the value for the counter
- getCount() - Method in class org.springframework.xd.module.ModuleDeploymentProperties
-
Return the number of container instances this module should be deployed to.
- getCount() - Method in class org.springframework.xd.rest.domain.metrics.RichGaugeResource
-
- getCounter() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- getCounter() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- getCounter() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- getCounterFromName(String) - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- getCounterFromName(String) - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- getCounterFromName(String) - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- getCounts() - Method in class org.springframework.xd.analytics.metrics.core.AggregateCount
-
- getCounts(String, int, AggregateCountResolution) - Method in interface org.springframework.xd.analytics.metrics.core.AggregateCounterRepository
-
Query function which returns the last 'n' points for a particular resolution.
- getCounts(String, Interval, AggregateCountResolution) - Method in interface org.springframework.xd.analytics.metrics.core.AggregateCounterRepository
-
Query function to allow the counts for a specific interval to be retrieved.
- getCounts(String, int, DateTime, AggregateCountResolution) - Method in interface org.springframework.xd.analytics.metrics.core.AggregateCounterRepository
-
Queries by requesting a number of points, ending on the given date (inclusive).
- getCounts(String, int, AggregateCountResolution) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- getCounts(String, Interval, AggregateCountResolution) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- getCounts(String, int, DateTime, AggregateCountResolution) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- getCounts(String, int, AggregateCountResolution) - Method in class org.springframework.xd.analytics.metrics.redis.RedisAggregateCounterRepository
-
- getCounts(String, int, DateTime, AggregateCountResolution) - Method in class org.springframework.xd.analytics.metrics.redis.RedisAggregateCounterRepository
-
- getCounts(String, Interval, AggregateCountResolution) - Method in class org.springframework.xd.analytics.metrics.redis.RedisAggregateCounterRepository
-
For each query, we need to convert the interval into two variations.
- getCriteria() - Method in class org.springframework.xd.module.ModuleDeploymentProperties
-
Return the criteria expression to evaluate against container attributes to determine deployment candidates for this module.
- getCron() - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- getCronExpression() - Method in class org.springframework.xd.rest.domain.validation.CronValidation
-
- getCustomAttributes() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
Retrieve the custom attributes for this admin.
- getCustomAttributes() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
Retrieve the custom attributes for this container.
- getDatabase() - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- getDatabase() - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- getDatabase() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getDatabase() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getDatabaseName() - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- getDataNodePort() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
The hadoop data node port that is available for this environment.
- getDataSource() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- getDate() - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- getDate(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDate(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDate(String, Date) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDate(int, Date) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDate(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the java.util.Date
value in default format at designated column index
.
- getDate(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the java.util.Date
value in default format at designated column with given name
.
- getDate(int, Date) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the java.util.Date
value in default format at designated column index
using the
supplied defaultValue
if the field value is a zero length string or null.
- getDate(String, Date) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the java.util.Date
value in default format at designated column with given name
.
- getDateFormat() - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- getDateFormat() - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- getDateFormat() - Method in class org.springframework.xd.module.options.mixins.DateFormatMixin
-
- getDateWithPattern(int, String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDateWithPattern(String, String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDateWithPattern(int, String, Date) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDateWithPattern(String, String, Date) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDateWithPattern(int, String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the java.util.Date
value in default format at designated column index
.
- getDateWithPattern(String, String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the java.util.Date
value in given format from column with given name
.
- getDateWithPattern(int, String, Date) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the java.util.Date
value in default format at designated column index
.
- getDateWithPattern(String, String, Date) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the java.util.Date
value in given format from column with given name
.
- getDbHost() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getDbkind() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getDbName() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getDbPassword() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getDbPort() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getDbUser() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getDecoder() - Method in class org.springframework.xd.tcp.encdec.EncoderDecoderMixins.DecoderMixin
-
- getDefaultAddress() - Static method in class org.springframework.xd.greenplum.support.NetworkUtils
-
Gets the main network address.
- getDefaultDateFormat() - Static method in class org.springframework.xd.rest.domain.util.TimeUtils
-
- getDefaultDateTimeFormat() - Static method in class org.springframework.xd.rest.domain.util.TimeUtils
-
- getDefaultDurationFormat() - Static method in class org.springframework.xd.rest.domain.util.TimeUtils
-
- getDefaultMetaVariable() - Method in class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandler
-
- getDefaultProperties() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- getDefaultTimeFormat() - Static method in class org.springframework.xd.rest.domain.util.TimeUtils
-
- getDefaultTimeZone() - Static method in class org.springframework.xd.rest.domain.util.TimeUtils
-
- getDefaultValue() - Method in class org.springframework.xd.module.options.ModuleOption
-
- getDefaultValue() - Method in class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource.Option
-
- getDefinition() - Method in class org.springframework.xd.dirt.core.BaseDefinition
-
Returns a String representation of the desired data flow, expressed in the XD DSL.
- getDefinition() - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- getDefinition() - Method in class org.springframework.xd.dirt.stream.BaseInstance
-
Return the underlying definition.
- getDefinition() - Method in class org.springframework.xd.rest.domain.JobDefinitionResource
-
- getDefinition() - Method in class org.springframework.xd.rest.domain.StreamDefinitionResource
-
- getDefinitionParameters(String) - Static method in class org.springframework.xd.dirt.job.dsl.ComposedJobUtil
-
- getDefinitionRepository() - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- getDelay() - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- getDeleteFiles() - Method in class org.springframework.xd.module.options.mixins.BatchJobDeleteFilesOptionMixin
-
- getDelimiter() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getDelimiter() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- getDelimiter() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getDelimiter() - Method in class org.springframework.xd.module.options.mixins.BatchJobFieldDelimiterOptionMixin
-
- getDeliveryMode() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSinkOptionsMetadata
-
- getDependents() - Method in exception org.springframework.xd.dirt.module.DependencyException
-
- getDeployedModules() - Method in class org.springframework.xd.dirt.container.store.DetailedContainer
-
- getDeployedModules() - Method in class org.springframework.xd.dirt.module.ModuleDeployer
-
Return a read-only map of deployed modules.
- getDeployedModules() - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
Get all currently deployed modules.
- getDeployedModules() - Method in class org.springframework.xd.rest.domain.DetailedContainerResource
-
Get the list of deployed modules.
- getDeploymentAction() - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- getDeploymentOrderIterator() - Method in class org.springframework.xd.dirt.core.Stream
-
Return an iterator that indicates the order of module deployments for this
stream.
- getDeploymentPath(D) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
Return the ZooKeeper path used for deployment requests for the
given definition.
- getDeploymentPath(JobDefinition) - Method in class org.springframework.xd.dirt.stream.JobDeployer
-
- getDeploymentPath(StreamDefinition) - Method in class org.springframework.xd.dirt.stream.StreamDeployer
-
Return the ZooKeeper path used for deployment requests for the
given definition.
- getDeploymentProperties() - Method in interface org.springframework.xd.dirt.core.DeploymentUnit
-
Properties used to indicate deployment information for this deployment unit.
- getDeploymentProperties() - Method in class org.springframework.xd.dirt.core.Job
-
Return the deployment properties for this job.
- getDeploymentProperties() - Method in class org.springframework.xd.dirt.core.Stream
-
Return the deployment properties for this stream.
- getDeploymentProperties() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata
-
Return the module options configured at deployment time.
- getDeploymentProperties() - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- getDeploymentProperties() - Method in class org.springframework.xd.module.core.AbstractModule
-
- getDeploymentProperties() - Method in interface org.springframework.xd.module.core.Module
-
- getDeploymentProperties() - Method in class org.springframework.xd.rest.domain.ModuleMetadataResource
-
- getDeploymentSize() - Method in class org.springframework.xd.dirt.container.store.DetailedContainer
-
- getDeploymentSize() - Method in class org.springframework.xd.rest.domain.DetailedContainerResource
-
Get the number of modules deployed into the container.
- getDeploymentStatus(ID) - Method in interface org.springframework.xd.dirt.core.DeploymentStatusRepository
-
For the given deployment unit id, return the deployment status.
- getDeploymentStatus() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata
-
Return the state of the deployment unit this module instance belongs to.
- getDeploymentStatus(String) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- getDeploymentStatus(String) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- getDeploymentStatus() - Method in class org.springframework.xd.rest.domain.ModuleMetadataResource
-
- getDeploymentUnitName() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Return the deployment unit name.
- getDeploymentUnitName() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Return the deployment unit (Stream/Job) name.
- getDeploymentUnitType() - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- getDescription() - Method in class org.springframework.xd.module.options.ModuleOption
-
- getDescription() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- getDescription() - Method in class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource.Option
-
- getDescriptor() - Method in class org.springframework.xd.module.core.AbstractModule
-
- getDescriptor() - Method in interface org.springframework.xd.module.core.Module
-
- getDescriptors() - Method in class org.springframework.xd.dirt.stream.DocumentParseResult.Line
-
- getDestination() - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- getDir() - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- getDir() - Method in class org.springframework.xd.dirt.modules.metadata.FileSourceOptionsMetadata
-
- getDirectory() - Method in class org.springframework.xd.dirt.modules.metadata.FilePollHdfsJobOptionsMetadata
-
- getDirectory() - Method in class org.springframework.xd.dirt.modules.metadata.TimestampFileJobOptionsMetadata
-
- getDirectory() - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- getDirExpression() - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- getDispatcher() - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- getDisplayableContents() - Method in class org.springframework.xd.shell.Target.Credentials
-
- getDisplayName() - Method in enum org.springframework.xd.dirt.job.StepType
-
- getDisplayName() - Method in enum org.springframework.xd.dirt.job.TaskletType
-
- getDistributedQueue() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentQueue
-
Get the underlying distributed queue.
- getDouble(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDouble(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDouble(String, double) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDouble(int, double) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getDouble(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'double
' value at index 'index
'.
- getDouble(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'double
' value from column with given 'name
'.
- getDouble(int, double) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'double
' value at index 'index
'.
- getDouble(String, double) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'double
' value from column with given 'name
'.
- getDriverClassName() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getDriverClassName() - Method in class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- getDslDefinition() - Method in class org.springframework.xd.module.CompositeModuleDefinition
-
Return the definition (in XD DSL) that was used to create the module).
- getDslName() - Method in class org.springframework.xd.test.fixtures.AbstractMetricSink
-
- getDuration() - Method in class org.springframework.xd.dirt.job.DetailedJobInfo
-
- getDuration() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getDuration() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getDuration() - Method in class org.springframework.xd.dirt.job.StepExecutionProgressInfo
-
- getDuration() - Method in class org.springframework.xd.rest.domain.DetailedJobInfoResource
-
- getDuration() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getDuration() - Method in class org.springframework.xd.rest.domain.StepExecutionProgressInfoResource
-
- getDurationMillis() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- geteBatchBufferLimit(int) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
The batch buffer limit.
- getEC2RunningInstances(String, String, String) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Returns a list of active instances from the specified ec2 region.
- getEncoder() - Method in class org.springframework.xd.tcp.encdec.EncoderDecoderMixins.EncoderMixin
-
- getEncoding() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getEncoding() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- getEndMessage() - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerMessageHandler
-
- getEndMessage() - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerOptionsMetadata
-
- getEndpoint() - Method in class org.springframework.xd.dirt.integration.bus.Binding
-
- getEndPos() - Method in class org.springframework.xd.dirt.job.dsl.AstNode
-
- getEndPos() - Method in class org.springframework.xd.dirt.stream.dsl.AstNode
-
- getEntityBasePackages() - Method in class org.springframework.xd.cassandra.CassandraConfiguration
-
- getEntityBasePackages() - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- getEnvironment() - Method in class org.springframework.xd.extension.process.ShellModuleOptionsMetadata
-
- getEnvironment() - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler
-
Return the environment to use for stream processing operations.
- getErrorDescription() - Method in class org.springframework.xd.dirt.core.DeploymentUnitStatus
-
Return the error description for the deployment unit; may be null.
- getErrorDescription() - Method in class org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus
-
- getErrorMessage() - Method in class org.springframework.xd.rest.domain.validation.CronValidation
-
- getErrors() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.Line
-
- getEscape() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- getEscape() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getEstimatedPercentComplete() - Method in class org.springframework.xd.dirt.job.StepExecutionProgressInfo
-
- getEstimatedPercentCompleteMessage() - Method in class org.springframework.xd.dirt.job.StepExecutionProgressInfo
-
- getEventListenerChannelName(String) - Static method in class org.springframework.xd.dirt.plugins.job.JobEventsListenerPlugin
-
- getEventListenerChannels(String) - Static method in class org.springframework.xd.dirt.plugins.job.JobEventsListenerPlugin
-
- getExceptions() - Method in class org.springframework.xd.dirt.stream.DocumentParseResult.Line
-
- getExchange() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSinkOptionsMetadata
-
- getExecutionCount() - Method in class org.springframework.xd.dirt.job.JobInfo
-
- getExecutionCount() - Method in class org.springframework.xd.rest.domain.JobInfoResource
-
- getExecutionId() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getExecutionId() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getExitCode() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getExitStatus() - Method in class org.springframework.xd.dirt.job.DetailedJobInfo
-
- getExitStatus() - Method in class org.springframework.xd.rest.domain.DetailedJobInfoResource
-
- getExpression() - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Return the expression string converted to tokens.
- getExpression() - Method in class org.springframework.xd.dirt.modules.metadata.LogSinkOptionsMetadata
-
- getExpression() - Method in class org.springframework.xd.dirt.modules.metadata.SplitterProcessorOptionsMetadata
-
- getExpression() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- getExpression() - Method in class org.springframework.xd.module.options.mixins.ExpressionOrScriptMixin
-
- getExpressionString() - Method in exception org.springframework.xd.dirt.job.dsl.JobSpecificationException
-
- getExpressionString() - Method in exception org.springframework.xd.dirt.stream.dsl.StreamDefinitionException
-
- getExpressionStringUntilCheckpoint() - Method in exception org.springframework.xd.dirt.job.dsl.CheckpointedJobDefinitionException
-
Return the parsed expression until the last known, well formed position.
- getExpressionStringUntilCheckpoint() - Method in exception org.springframework.xd.dirt.stream.dsl.CheckpointedStreamDefinitionException
-
Return the parsed expression until the last known, well formed position.
- getExtensionsBasePackages() - Method in class org.springframework.xd.dirt.container.initializer.AbstractComponentScanningBeanDefinitionProvider
-
- getExtensionsBasePackages() - Method in class org.springframework.xd.dirt.container.initializer.PluginContextComponentScanningExtensionsInitializer
-
- getExtensionsLocations() - Method in class org.springframework.xd.dirt.container.initializer.AbstractResourceBeanDefinitionProvider
-
Subclasses implement this to return extensions locations (null is ok).
- getExtensionsLocations() - Method in class org.springframework.xd.dirt.container.initializer.PluginContextResourceExtensionsInitializer
-
- getExtensionsLocations() - Method in class org.springframework.xd.dirt.container.initializer.PluginsInitializer
-
- getExtensionWithDot() - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
Return dot + suffix if suffix is set, or the empty string otherwise.
- getExternalTable() - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- getExternalTable() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getFetchMaxBytes() - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- getFetchMaxWait() - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- getFetchMinBytes() - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- getFieldCount() - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getFieldCount() - Method in interface org.springframework.xd.tuple.Tuple
-
Return the number of fields in this tuple.
- getFieldMappingEntrySplitToken() - Method in class org.springframework.xd.analytics.ml.AbstractFieldMappingAwareDataMapper
-
- getFieldName() - Method in class org.springframework.xd.analytics.metrics.metadata.FieldValueCounterSinkOptionsMetadata
-
- getFieldNames() - Method in class org.springframework.xd.tuple.DefaultTuple
-
Return the values for all the fields in this tuple
- getFieldNames() - Method in interface org.springframework.xd.tuple.Tuple
-
Return the fields names that can reference elements by name in this tuple
- getFieldTypes() - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getFieldTypes() - Method in interface org.springframework.xd.tuple.Tuple
-
Return the Java types of the fields in this tuple.
- getFieldValueCount() - Method in class org.springframework.xd.analytics.metrics.core.FieldValueCounter
-
- getFieldValueCounts() - Method in class org.springframework.xd.rest.domain.metrics.FieldValueCounterResource
-
- getFile() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- getFileContentsFromHdfs(String) - Method in class org.springframework.xd.integration.util.HadoopUtils
-
Retrieves the file from the hdfs file system.
- getFileDelay() - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- getFileExtension() - Method in class org.springframework.xd.dirt.modules.metadata.FilePollHdfsJobOptionsMetadata
-
- getFileExtension() - Method in class org.springframework.xd.dirt.modules.metadata.TimestampFileJobOptionsMetadata
-
- getFileExtension() - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- getFileName() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- getFileName() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- getFileName() - Method in class org.springframework.xd.dirt.modules.metadata.FilePollHdfsJobOptionsMetadata
-
- getFileName() - Method in class org.springframework.xd.dirt.modules.metadata.TimestampFileJobOptionsMetadata
-
- getFileName() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- getFileName() - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- getFilename() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- getFilenamePattern() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- getFiles() - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- getFiles() - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- getFileStatus(String) - Method in class org.springframework.xd.integration.util.HadoopUtils
-
Retrieves the file status for the file path specified.
- getFileSuffix() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- getFileSuffix() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- getFileSuffix() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- getFileSuffix() - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- getFileSystem() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- getFileSystem() - Method in class org.springframework.xd.batch.item.hadoop.HdfsTextItemWriter
-
- getFileSystem() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- getFileSystem() - Method in class org.springframework.xd.batch.item.hadoop.SimpleHdfsTextItemWriter
-
- getFileSystem() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- getFileSystem() - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriter
-
- getFilterLevel() - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- getFinished() - Method in class org.springframework.xd.rest.domain.StepExecutionProgressInfoResource
-
- getFirstExceptionMessage(List<String>, List<String>) - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- getFixedDelay() - Method in class org.springframework.xd.dirt.modules.metadata.FileSourceOptionsMetadata
-
- getFixedDelay() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- getFixedDelay() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getFixedDelay() - Method in class org.springframework.xd.dirt.modules.metadata.TimeSourceOptionsMetadata
-
- getFixedDelay() - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- getFixedDelay() - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- getFixedDelay() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- getFixedDelay() - Method in class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin
-
- getFixedDelay() - Method in class org.springframework.xd.tcp.TcpClientSourceOptionsMetadata
-
- getFloat(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getFloat(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getFloat(String, float) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getFloat(int, float) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getFloat(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'float
' value at index 'index
'.
- getFloat(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'float
' value from column with given 'name
'.
- getFloat(int, float) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'float
' value at index 'index
'.
- getFloat(String, float) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'float
' value from column with given 'name
'.
- getFlushCount() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getFlushTime() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getFolder() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- getFollow() - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- getForceQuote() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- getForceQuote() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getFormat() - Method in class org.springframework.xd.dirt.modules.metadata.TimeSourceOptionsMetadata
-
- getFormat() - Method in class org.springframework.xd.dirt.modules.metadata.TimestampFileJobOptionsMetadata
-
- getFormat() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- getFormat() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getFraming() - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- getFrom() - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- getFromEnd() - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- getFsUri() - Method in class org.springframework.xd.module.options.mixins.HadoopConfigurationMixin
-
- getFullyQualifiedId() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata.Id
-
Return the "fully qualified" id string for the module instance
this metadata object is tracking.
- getGemfireHost() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the Gemfire host.
- getGemfirePort() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the Gemfire port.
- getGeocode() - Method in class org.springframework.integration.x.twitter.TwitterSearchOptionsMetadata
-
- getGlobalOptionsMap() - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
- getGPFDistUri(int) - Static method in class org.springframework.xd.greenplum.support.NetworkUtils
-
- getGploadHome() - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- getGploadHome() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getGploadInputDelimiter() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getGploadOutputMatchColumns() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getGploadOutputMode() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getGploadOutputTable() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getGploadOutputUpdateColumns() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getGploadOutputUpdateCondition() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getGploadSqlAfter() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getGploadSqlBefore() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getGraph(String) - Method in class org.springframework.xd.dirt.job.dsl.JobParser
-
Create a graph suitable for Flo to display.
- getGroup() - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Return name of deployable unit this module instance belongs to
(such as a stream or job).
- getGroup() - Method in class org.springframework.xd.module.ModuleDescriptor
-
Return name of deployable unit this module instance belongs to
(such as a stream or job).
- getGroup() - Method in class org.springframework.xd.module.ModuleDescriptor.Key
-
Return the name of the stream.
- getGroup() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.ModuleDescriptor
-
- getGroupFromPubSub(String) - Static method in class org.springframework.xd.dirt.integration.bus.BusUtils
-
- getGroupId() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getGroupRoleAttribute() - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- getGroups() - Method in class org.springframework.xd.dirt.cluster.Container
-
Return the set of groups this container belongs to.
- getGroups() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- getGroups() - Method in class org.springframework.xd.rest.domain.DetailedContainerResource
-
Get container group(s).
- getGroupSearchBase() - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- getGroupSearchFilter() - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- getHADOOP_DISTRO() - Method in class org.springframework.xd.dirt.server.options.CommonOptions
-
- getHadoopConfiguration() - Method in class org.springframework.xd.shell.hadoop.ConfigurationAware
-
Gets the hadoop configuration.
- getHadoopProperties() - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- getHeaderBorder(Map<Integer, TableHeader>) - Static method in class org.springframework.xd.shell.util.UiUtils
-
Renders the Table header border, based on the map of provided headers.
- getHeaders() - Method in class org.springframework.xd.integration.hadoop.expression.MessageExpressionMethods.MessageWrappedMessage
-
- getHeaders() - Method in class org.springframework.xd.shell.util.Table
-
- getHost() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- getHost() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- getHost() - Method in class org.springframework.xd.dirt.integration.rabbit.LocalizedQueueConnectionFactory
-
- getHost() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getHost() - Static method in class org.springframework.xd.dirt.util.RuntimeUtils
-
Return the name of the host for the machine running this process.
- getHost() - Method in class org.springframework.xd.gemfire.GemfireHostPortMixin
-
- getHost() - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- getHost() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getHost() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getHost() - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- getHost() - Method in class org.springframework.xd.mail.MailServerMixin
-
- getHost() - Method in class org.springframework.xd.module.options.mixins.FtpConnectionMixin
-
- getHost() - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- getHost() - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- getHost() - Method in class org.springframework.xd.tcp.ClientTcpConnectionFactoryOptionsMetadataMixin
-
- getHostname() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getHostname() - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- getHttp(String) - Method in class org.springframework.xd.shell.command.HttpCommands
-
- getHttpMethod() - Method in class org.springframework.xd.http.HttpClientProcessorOptionsMetadata
-
- getHttpPort() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- getId() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- getId() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- getId() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getIdField() - Method in class org.springframework.xd.dirt.modules.metadata.HdfsMongodbJobOptionsMetadata
-
- getIdGenerator() - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- getIncrementExpression() - Method in class org.springframework.xd.analytics.metrics.metadata.AggregateCounterSinkOptionsMetadata
-
- getIndex() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata.Id
-
Return the position in stream/job definition relative to other modules
in the deployment unit.
- getIndex() - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Return position in stream/job definition relative to the other modules in
the definition.
- getIndex() - Method in class org.springframework.xd.module.ModuleDescriptor
-
Return position in stream/job definition relative to the other
modules in the definition.
- getIndexOfLabel(String) - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- getIngestQuery() - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- getInitialDelay() - Method in class org.springframework.xd.module.options.mixins.PeriodicTriggerMixin
-
- getInitializeDatabase() - Method in class org.springframework.xd.jdbc.AbstractImportToJdbcOptionsMetadata
-
- getInitializerScript() - Method in class org.springframework.xd.jdbc.AbstractImportToJdbcOptionsMetadata
-
- getInitialOffsets() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getInitialRetryInterval() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getInitialSize() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getInitScript() - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- getInitSQL() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getInputChannelName(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractJobPlugin
-
- getInputChannelName(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractMessageBusBinderPlugin
-
- getInputChannelName(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractStreamPlugin
-
- getInputMimeType(Module) - Static method in class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionSupport
-
Return MimeType
for the module's input channel.
- getInputSourceFile() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getInputStream() - Method in class org.springframework.xd.dirt.module.UploadedModuleDefinition
-
- getInputStream() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- getInputType() - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler
-
Returns the input type of the stream that is to be processed
- getInserts() - Method in exception org.springframework.xd.dirt.job.dsl.JobSpecificationException
-
- getInserts() - Method in exception org.springframework.xd.dirt.stream.dsl.StreamDefinitionException
-
- getInstanceId() - Method in class org.springframework.xd.dirt.job.JobInstanceInfo
-
- getInstanceId() - Method in class org.springframework.xd.rest.domain.JobInstanceInfoResource
-
- getInt(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getInt(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getInt(String, int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getInt(int, int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getInt(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'int
' value at index 'index
'.
- getInt(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'int
' value from column with given 'name
'.
- getInt(int, int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'int
' value at index 'index
'.
- getInt(String, int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'int
' value from column with given 'name
'.
- getInterval() - Method in class org.springframework.xd.analytics.metrics.core.AggregateCount
-
- getIp() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- getIp() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- getIpAddress() - Static method in class org.springframework.xd.dirt.util.RuntimeUtils
-
Return a non loopback IPv4 address for the machine running this process.
- getJarURI(String) - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
Construct the URI location of the jar
- getJavaTypeForContentType(MimeType, ClassLoader) - Static method in class org.springframework.xd.dirt.integration.bus.converter.MessageConverterUtils
-
Map the contentType to a target class.
- getJdbcInterceptors() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getJdbcTemplate() - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
- getJdbcTemplate() - Method in class org.springframework.xd.test.fixtures.JdbcSink
-
- getJdbcTemplate() - Method in class org.springframework.xd.test.fixtures.JdbcSource
-
- getJmsHost() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- getJmsPort() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- getJmxPort() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- getJob(String) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
Get simple batch job representation for the given job name.
- getJob(String) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobService
-
- getJobChannelName(String) - Static method in class org.springframework.xd.dirt.plugins.AbstractJobPlugin
-
- getJobDefinition(String) - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
- getJobDefinitions() - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
A shortcut (avoiding traversing the tree) that returns the list
of all job definitions inlined somewhere in this AST.
- getJobDefinitionText() - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
- getJobDeployments() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.SupervisorElectedEvent
-
- getJobExecution() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getJobExecution() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getJobExecutionId() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getJobExecutionId() - Method in class org.springframework.xd.rest.domain.StepExecutionInfoResource
-
- getJobExecutionInfo(long) - Method in class org.springframework.xd.dirt.rest.BatchJobExecutionsController
-
- getJobExecutions() - Method in class org.springframework.xd.dirt.job.JobInstanceInfo
-
- getJobExecutions() - Method in class org.springframework.xd.rest.domain.JobInstanceInfoResource
-
- getJobExplorer() - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- getJobId() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getJobId() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getJobInstance() - Method in class org.springframework.xd.dirt.job.JobInstanceInfo
-
- getJobInstance(long) - Method in class org.springframework.xd.dirt.rest.BatchJobInstancesController
-
Return job instance info by the given instance id.
- getJobInstanceId() - Method in class org.springframework.xd.dirt.job.JobInfo
-
- getJobInstanceId() - Method in class org.springframework.xd.rest.domain.JobInfoResource
-
- getJobLauncher() - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- getJobModuleDescriptor() - Method in class org.springframework.xd.dirt.core.Job
-
Return the job module descriptor.
- getJobModuleName() - Method in class org.springframework.xd.dirt.job.dsl.JobDefinition
-
- getJobName() - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Return the job name.
- getJobName() - Method in class org.springframework.xd.dirt.job.dsl.JobDefinition
-
- getJobName() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getJobName() - Method in class org.springframework.xd.rest.domain.JobInstanceInfoResource
-
- getJobNames() - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
Get all the deployed job names.
- getJobNode() - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
- getJobParameters() - Method in class org.springframework.xd.dirt.job.DetailedJobInfo
-
- getJobParameters() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getJobParameters(Properties) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
- getJobParameters() - Method in class org.springframework.xd.dirt.plugins.job.JobParametersBean
-
- getJobParameters() - Method in class org.springframework.xd.rest.domain.DetailedJobInfoResource
-
- getJobParameters() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getJobParametersAsString(JobParameters) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
This method will convert JobParameters
to a JSON String.
- getJobParametersAsString(JobParameters, boolean) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
This method will convert JobParameters
to a JSON String.
- getJobParametersForFile(File) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
Return JobParameters
for the passed-in File
.
- getJobParametersForJsonString(String) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
Converts a String
-based JSON map to JobParameters
.
- getJobParametersForMap(Map<?, ?>) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
Will convert the provided Map
into JobParameters
.
- getJobParametersString() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getJobParametersString() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getJobReferences() - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
A shortcut (avoiding traversing the tree) that returns the list
of all job references somewhere in this AST (references in
transitions do not count).
- getJobRepository() - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- getJobStepNames(String) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
Get all the steps' names of a given job name.
- getJvmTimeZone() - Static method in class org.springframework.xd.rest.domain.util.TimeUtils
-
- getKafkaBrokerList() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the Kafka Broker List.
- getKafkaOffsetTopicBatchBytes() - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- getKafkaOffsetTopicBatchTime() - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- getKafkaOffsetTopicMaxSize() - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- getKafkaOffsetTopicName() - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- getKafkaOffsetTopicRequiredAcks() - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- getKafkaOffsetTopicRetentionTime() - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- getKafkaOffsetTopicSegmentSize() - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- getKafkaZkConnect() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the Kafka ZK Connection String.
- getKeepAliveInterval() - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- getKey() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- getKey() - Method in class org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus
-
- getKeyExpression() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- getKeyExpression() - Method in class org.springframework.xd.gemfire.GemfireServerSinkModuleOptionsMetadata
-
- getKeyspace() - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- getKeyspaceCreations() - Method in class org.springframework.xd.cassandra.CassandraConfiguration
-
- getKeyspaceName() - Method in class org.springframework.xd.cassandra.CassandraConfiguration
-
- getKind() - Method in enum org.springframework.xd.dirt.job.dsl.JobDSLMessage
-
- getKind() - Method in class org.springframework.xd.dirt.job.dsl.Token
-
- getKind() - Method in class org.springframework.xd.dirt.stream.dsl.Token
-
- getKind() - Method in enum org.springframework.xd.dirt.stream.dsl.XDDSLMessages
-
- getKnownHostsExpression() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getLabel() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata
-
- getLabel() - Method in class org.springframework.xd.module.ModuleDescriptor.Key
-
Return the module label.
- getLabel() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.ModuleDescriptor
-
- getLabelName() - Method in class org.springframework.xd.dirt.stream.dsl.LabelNode
-
- getLabelName() - Method in class org.springframework.xd.dirt.stream.dsl.ModuleNode
-
Return the label for this module, that is:
an explicit label if provided
the module name if no label was provided
- getLanguage() - Method in class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter
-
- getLanguage() - Method in class org.springframework.integration.x.twitter.TwitterMixin
-
- getLastException() - Method in class org.springframework.xd.greenplum.support.JdbcCommands
-
- getLastExecutionInfo() - Method in class org.springframework.xd.dirt.job.DetailedJobInfo
-
- getLastJobExecution(String, JobParameters) - Method in class org.springframework.xd.dirt.plugins.job.support.JobLaunchingJobRepository
-
Returns the last JobExecution
for the requested job without
rehydrating the related ExecutionContext
.
- getLastStepExecution(JobInstance, String) - Method in class org.springframework.xd.dirt.plugins.job.support.JobLaunchingJobRepository
-
Returns the last StepExecution
for the
requested step without rehydrating the related
ExecutionContext
.
- getLength() - Method in enum org.springframework.xd.dirt.job.dsl.TokenKind
-
- getLength() - Method in enum org.springframework.xd.dirt.stream.dsl.TokenKind
-
- getLengthFieldLength() - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- getLevel() - Method in class org.springframework.xd.dirt.modules.metadata.LogSinkOptionsMetadata
-
- getLibjars() - Method in class org.springframework.xd.sqoop.SqoopOptionsMetadata
-
- getLike() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- getLike() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getLines() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource
-
- getLinks() - Method in class org.springframework.xd.dirt.job.dsl.Graph
-
- getListeners() - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- getLocalContainerPids(String) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Retrieves the container pids on the local machine.
- getLocalDir() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- getLocalDir() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getLocalPort() - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistServer
-
- getLocalTime(Date) - Method in class org.springframework.xd.shell.Configuration
-
- getLocalTime(Date, TimeZone) - Static method in class org.springframework.xd.shell.util.CommonUtils
-
Return a date/time formatted String for the provided Date
and TimeZone
.
- getLocation() - Method in class org.springframework.xd.module.SimpleModuleDefinition
-
- getLocations() - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- getLocations() - Method in class org.springframework.xd.dirt.container.initializer.AbstractResourceBeanDefinitionProvider
-
This will prepend "classpath*:" to each location if no Resource prefix provided.
- getLocations() - Method in class org.springframework.xd.dirt.container.initializer.PluginsInitializer
-
- getLocations() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- getLocations() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getLocations() - Method in class org.springframework.xd.greenplum.support.RuntimeContext
-
- getLogDir() - Method in class org.springframework.xd.test.kafka.EmbeddedZookeeper
-
- getLogErrorsInto() - Method in class org.springframework.xd.greenplum.support.ReadableTable
-
- getLogErrorsInto() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getLong(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getLong(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getLong(String, long) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getLong(int, long) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getLong(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'long
' value at index 'index
'.
- getLong(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'int
' value from column with given 'name
'.
- getLong(int, long) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'long
' value at index 'index
'.
- getLong(String, long) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'long
' value from column with given 'name
'.
- getMainClass() - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- getMainClass() - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- getMainCommandName() - Method in class org.springframework.xd.yarn.ClientApplication
-
- getManagementPort() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- getManagementPort() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- getManagerDn() - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- getManagerPassword() - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- getMappedRequestHeaders() - Method in class org.springframework.xd.module.options.mixins.MappedRequestHeadersMixin
-
- getMappedResponseHeaders() - Method in class org.springframework.xd.module.options.mixins.MappedResponseHeadersMixin
-
- getMaster() - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- getMaster() - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- getMatchColumns() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getMatchColumns() - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- getMatchColumns() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getMax() - Method in class org.springframework.xd.analytics.metrics.core.RichGauge
-
- getMax() - Method in class org.springframework.xd.rest.domain.metrics.RichGaugeResource
-
- getMaxActive() - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- getMaxActive() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getMaxAge() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getMaxAttempts(int) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the 'maxAttempts' property or the default value.
- getMaxAttempts() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getMaxBufferTime() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getMaxConcurrency(int) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the 'maxConcurrency' property or the default value.
- getMaxConcurrency() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getMaxContentLength() - Method in class org.springframework.xd.dirt.modules.metadata.HttpSourceOptionsMetadata
-
- getMaxIdle() - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- getMaxIdle() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getMaxMessages() - Method in class org.springframework.xd.module.options.mixins.MaxMessagesDefaultOneMixin
-
- getMaxMessages() - Method in class org.springframework.xd.module.options.mixins.MaxMessagesDefaultUnlimitedMixin
-
- getMaxRequestSize() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getMaxRetryInterval() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getMaxRowsPerPoll() - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- getMaxSendDuration() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getMaxSendRetries() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getMaxWait() - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- getMaxWait() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getMaxWidth() - Method in class org.springframework.xd.shell.util.TableHeader
-
- getMbean() - Method in class org.springframework.xd.integration.util.jmxresult.JMXRequest
-
- getMeanErrorRate() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getMeanErrorRatio() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getMeanSendDuration() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getMeanSendRate() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getMessage() - Method in exception org.springframework.xd.dirt.job.dsl.CheckpointedJobDefinitionException
-
- getMessage() - Method in exception org.springframework.xd.dirt.job.dsl.JobSpecificationException
-
- getMessage() - Method in exception org.springframework.xd.dirt.module.NoSuchModuleException
-
- getMessage() - Method in exception org.springframework.xd.dirt.stream.dsl.CheckpointedStreamDefinitionException
-
- getMessage() - Method in exception org.springframework.xd.dirt.stream.dsl.StreamDefinitionException
-
- getMessage() - Method in exception org.springframework.xd.rest.client.impl.SpringXDException
-
- getMessage() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.Error
-
- getMessageCode() - Method in exception org.springframework.xd.dirt.job.dsl.JobSpecificationException
-
- getMessageCode() - Method in exception org.springframework.xd.dirt.stream.dsl.StreamDefinitionException
-
- getMessageConverterClass() - Method in class org.springframework.xd.dirt.modules.metadata.HttpSourceOptionsMetadata
-
- getMessageRates() - Method in class org.springframework.xd.dirt.container.store.DetailedContainer
-
- getMessageRates() - Method in class org.springframework.xd.rest.domain.DetailedContainerResource
-
- getMetricKey(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
Provides the key for a named metric.
- getMetricsEnabled() - Method in class org.springframework.xd.cassandra.CassandraConfiguration
-
- getMin() - Method in class org.springframework.xd.analytics.metrics.core.RichGauge
-
- getMin() - Method in class org.springframework.xd.rest.domain.metrics.RichGaugeResource
-
- getMinEvictableIdleTimeMillis() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getMinIdle() - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- getMinIdle() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getMinSendDuration() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getMode() - Method in class org.springframework.xd.dirt.modules.metadata.FileAsRefMixin
-
- getMode() - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- getMode() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- getMode() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getMode() - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- getMode() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getModule(String) - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
Find the first reference to the named module in the stream.
- getModule(String, String, int) - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
Get a deployed module instance.
- getModuleChannel() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getModuleDefinition() - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
- getModuleDefinition() - Method in class org.springframework.xd.module.ModuleDescriptor
-
- getModuleDefinitions() - Method in class org.springframework.xd.dirt.core.BaseDefinition
-
- getModuleDeploymentRequests() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.SupervisorElectedEvent
-
- getModuleDescriptor(String) - Method in class org.springframework.xd.dirt.core.Stream
-
Return the module descriptor for the provided label and type.
- getModuleDescriptors() - Method in interface org.springframework.xd.dirt.core.DeploymentUnit
-
List of modules that comprise this deployment unit.
- getModuleDescriptors() - Method in class org.springframework.xd.dirt.core.Job
-
List of modules that comprise this deployment unit.
- getModuleDescriptors() - Method in class org.springframework.xd.dirt.core.Stream
-
Return the ordered list of modules for this stream as a List
.
- getModuleDescriptorsAsDeque() - Method in class org.springframework.xd.dirt.core.Stream
-
Return the ordered list of modules for this stream.
- getModuleExecutionFramework() - Method in class org.springframework.xd.spark.streaming.DefaultSparkStreamingModuleOptionsMetadata
-
- getModuleId() - Method in class org.springframework.xd.rest.domain.ModuleMetadataResource
-
- getModuleInstanceAsString() - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Return the string representation of the module instance that has the following dot limited
values.
- getModuleInstanceAsString() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Return the string representation of the module instance that has the following dot limited
values.
- getModuleInstanceAsString() - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Return the string representation of the module instance that has the following dot limited
values.
- getModuleLabel() - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Return the module label.
- getModuleLabel() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Return the module label.
- getModuleLabel() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Return the module label.
- getModuleLabel() - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Return the module label.
- getModuleLabel() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata.Id
-
Return the label for the module instance this metadata object is tracking.
- getModuleLabel() - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Return symbolic name of a module.
- getModuleLabel() - Method in class org.springframework.xd.module.ModuleDescriptor
-
Return symbolic name of a module.
- getModuleName() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getModuleName() - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Return name of module.
- getModuleName() - Method in class org.springframework.xd.module.ModuleDescriptor
-
Return name of module.
- getModuleNodes() - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- getModuleOptions() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata
-
Return the module options configured during stream/job creation.
- getModuleOptions() - Method in class org.springframework.xd.rest.domain.ModuleMetadataResource
-
- getModules() - Method in class org.springframework.xd.integration.util.jmxresult.JMXValue
-
- getModuleSequence() - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Return the module sequence.
- getModuleSequence() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Return the module sequence.
- getModuleSequence() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Return the module sequence.
- getModuleSequence() - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Return the module sequence.
- getModuleSequence() - Method in class org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus
-
- getModuleSequenceAsString() - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Return the module sequence as string.
- getModuleSequenceAsString() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Return the module sequence as string.
- getModuleSequenceAsString() - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Return the module sequence as string.
- getModuleSequenceAsString() - Method in class org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus
-
- getModulesForDeploymentUnit(Collection<ModuleDeploymentRequestsPath>, String) - Static method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Return all the modules for a given deployment unit name.
- getModuleType() - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Return the module type.
- getModuleType() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Return the module type.
- getModuleType() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Return the module type.
- getModuleType() - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Return the module type.
- getModuleType() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata
-
- getModuleType() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata.Id
-
Return the module type for the module instance this metadata object is tracking.
- getModuleType() - Method in class org.springframework.xd.rest.domain.ModuleMetadataResource
-
- getModuleTypeConversionSupport() - Method in class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionPlugin
-
Get the underlying
ModuleTypeConversionSupport
which could be
further used by any other plugin that requires to apply module type conversion explicitly.
- getMongoDbFactory() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
The mongo db factory to be used for the tests.
- getMongoHost() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the host where the mongo server is running.
- getMongoPort() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the port that the mongo server is monitoring.
- getName() - Method in class org.springframework.xd.analytics.metrics.core.AggregateCount
-
- getName() - Method in class org.springframework.xd.analytics.metrics.core.Counter
-
- getName() - Method in class org.springframework.xd.analytics.metrics.core.FieldValueCounter
-
- getName() - Method in class org.springframework.xd.analytics.metrics.core.Gauge
-
- getName() - Method in interface org.springframework.xd.analytics.metrics.core.Metric
-
Return the name of the metric.
- getName() - Method in class org.springframework.xd.analytics.metrics.core.RichGauge
-
- getName() - Method in class org.springframework.xd.dirt.cluster.Admin
-
Return the admin name.
- getName() - Method in class org.springframework.xd.dirt.cluster.Container
-
Return the container name.
- getName() - Method in class org.springframework.xd.dirt.core.BaseDefinition
-
Returns a unique name given to that stream definition.
- getName() - Method in interface org.springframework.xd.dirt.core.DeploymentUnit
-
The name for this deployment unit, typically used as a unique identifier
for this deployment unit type.
- getName() - Method in class org.springframework.xd.dirt.core.Job
-
Return the name of this job.
- getName() - Method in class org.springframework.xd.dirt.core.Stream
-
Return the name of this stream.
- getName() - Method in class org.springframework.xd.dirt.integration.bus.Binding
-
- getName() - Method in class org.springframework.xd.dirt.job.dsl.ArgumentNode
-
- getName() - Method in class org.springframework.xd.dirt.job.dsl.JobDefinition
-
- getName() - Method in class org.springframework.xd.dirt.job.dsl.JobDescriptor
-
- getName() - Method in class org.springframework.xd.dirt.job.dsl.JobReference
-
- getName() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getName() - Method in class org.springframework.xd.dirt.job.JobInfo
-
- getName() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getName() - Method in exception org.springframework.xd.dirt.module.DependencyException
-
- getName() - Method in exception org.springframework.xd.dirt.module.ModuleAlreadyExistsException
-
- getName() - Method in exception org.springframework.xd.dirt.module.NoSuchModuleException
-
- getName() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata
-
Return the name for the module instance this metadata object is tracking.
- getName() - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- getName() - Method in class org.springframework.xd.dirt.modules.metadata.LogSinkOptionsMetadata
-
- getName() - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- getName() - Method in class org.springframework.xd.dirt.stream.dsl.ArgumentNode
-
- getName() - Method in class org.springframework.xd.dirt.stream.dsl.ModuleNode
-
- getName() - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- getName() - Method in class org.springframework.xd.module.core.AbstractModule
-
- getName() - Method in interface org.springframework.xd.module.core.Module
-
- getName() - Method in class org.springframework.xd.module.ModuleDefinition
-
- getName() - Method in class org.springframework.xd.module.options.ModuleOption
-
- getName() - Method in class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource.Option
-
- getName() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.ModuleDescriptor
-
- getName() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getName() - Method in class org.springframework.xd.rest.domain.JobInfoResource
-
- getName() - Method in class org.springframework.xd.rest.domain.ModuleDefinitionResource
-
- getName() - Method in class org.springframework.xd.rest.domain.ModuleMetadataResource
-
- getName() - Method in class org.springframework.xd.rest.domain.NamedResource
-
Return the name of the represented entity.
- getName() - Method in class org.springframework.xd.shell.util.TableHeader
-
- getName() - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- getName() - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- getName() - Method in class org.springframework.xd.test.fixtures.AbstractMetricSink
-
- getNameExpression() - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- getNameNode() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
The hadoop name node that is available for this environment.
- getNames() - Method in class org.springframework.xd.module.options.mixins.BatchJobFieldNamesOptionMixin
-
- getNextExecutionTime() - Method in class org.springframework.xd.rest.domain.validation.CronValidation
-
- getNextModuleCount() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
The next module count for non-sink modules
- getNodes() - Method in class org.springframework.xd.dirt.job.dsl.Graph
-
- getNullString() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- getNullString() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getNumberFormat() - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- getObject() - Method in class org.springframework.integration.x.kafka.InitialOffsetsFactoryBean
-
- getObject() - Method in class org.springframework.integration.x.kafka.KafkaPartitionAllocator
-
- getObject() - Method in class org.springframework.xd.dirt.jdbc.util.DatabaseVendorFriendlyNameFactoryBean
-
- getObject() - Method in class org.springframework.xd.dirt.module.CustomModuleRegistryFactoryBean
-
- getObject() - Method in class org.springframework.xd.dirt.plugins.job.support.JobLaunchingJobRepositoryFactoryBean
-
- getObject() - Method in class org.springframework.xd.greenplum.support.ControlFileFactoryBean
-
- getObject() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getObject() - Method in class org.springframework.xd.greenplum.support.LoadFactoryBean
-
- getObject() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getObject() - Method in class org.springframework.xd.hadoop.fs.DatasetDefinitionFactoryBean
-
- getObject() - Method in class org.springframework.xd.integration.hadoop.config.DatasetWritingMessageHandlerFactoryBean
-
- getObject() - Method in class org.springframework.xd.integration.hadoop.config.HdfsWritingMessageHandlerFactoryBean
-
- getObject() - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- getObject() - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
- getObject() - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- getObjectName(Object, String) - Method in class org.springframework.xd.dirt.module.jmx.ModuleObjectNamingStrategy
-
- getObjectType() - Method in class org.springframework.integration.x.kafka.InitialOffsetsFactoryBean
-
- getObjectType() - Method in class org.springframework.integration.x.kafka.KafkaPartitionAllocator
-
- getObjectType() - Method in class org.springframework.xd.dirt.jdbc.util.DatabaseVendorFriendlyNameFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.dirt.module.CustomModuleRegistryFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.greenplum.support.ControlFileFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.greenplum.support.LoadFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.hadoop.fs.DatasetDefinitionFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.integration.hadoop.config.DatasetWritingMessageHandlerFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.integration.hadoop.config.HdfsWritingMessageHandlerFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
- getObjectType() - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- getOffendingName() - Method in exception org.springframework.xd.dirt.analytics.NoSuchMetricException
-
Return the name that was not found.
- getOffendingName() - Method in exception org.springframework.xd.dirt.stream.AlreadyDeployedException
-
Return the name of the already deployed definition.
- getOffendingName() - Method in exception org.springframework.xd.dirt.stream.DefinitionAlreadyExistsException
-
Return the definition name that was in conflict.
- getOffendingName() - Method in exception org.springframework.xd.dirt.stream.NoSuchDefinitionException
-
Return the name of the definition that could not be found.
- getOffendingName() - Method in exception org.springframework.xd.dirt.stream.NotDeployedException
-
Return the name of the definition that could not be found.
- getOffset(Partition) - Method in class org.springframework.integration.x.kafka.WindowingOffsetManager
-
- getOffsetStorage() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getOffsetUpdateCount() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getOffsetUpdateShutdownTimeout() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getOffsetUpdateTimeWindow() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getOptions() - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- getOptions() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getOptions() - Method in class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource
-
- getOptions() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.ModuleDescriptor
-
- getOrCreate(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryGaugeRepository
-
- getOrCreate(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- getOrCreate(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryRichGaugeRepository
-
- getOrder() - Method in class org.springframework.xd.dirt.container.initializer.AbstractComponentScanningBeanDefinitionProvider
-
- getOrder() - Method in class org.springframework.xd.dirt.container.initializer.PluginContextComponentScanningExtensionsInitializer
-
- getOrder() - Method in class org.springframework.xd.dirt.container.initializer.PluginContextResourceExtensionsInitializer
-
- getOrder() - Method in class org.springframework.xd.dirt.container.initializer.PluginsInitializer
-
- getOrder() - Method in class org.springframework.xd.dirt.plugins.AbstractMessageBusBinderPlugin
-
- getOrder() - Method in class org.springframework.xd.dirt.plugins.AbstractPlugin
-
- getOrder() - Method in class org.springframework.xd.dirt.plugins.job.JobPlugin
-
- getOrder() - Method in class org.springframework.xd.dirt.plugins.stream.StreamPlugin
-
- getOutputChannelName(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractJobPlugin
-
- getOutputChannelName(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractMessageBusBinderPlugin
-
- getOutputChannelName(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractStreamPlugin
-
- getOutputMimeType(Module) - Static method in class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionSupport
-
Return MimeType
for the module's output channel.
- getOwner() - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- getPagedData(Pageable, List<T>) - Method in class org.springframework.xd.dirt.util.PagingUtility
-
Get the paged data of the given list.
- getParameters() - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Return parameters for module.
- getParameters() - Method in class org.springframework.xd.module.ModuleDescriptor
-
Return parameters for module.
- getPartitionColumn() - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- getPartitionCount() - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport.PartitioningMetadata
-
- getPartitionIndex() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
The partition index that this consumer supports.
- getPartitionKeyExpression() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
The expression to determine the partition key, evaluated against the
message as the root object.
- getPartitionKeyExtractorClass() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
A class name for extracting partition keys from messages.
- getPartitionResultsTimeout() - Method in class org.springframework.xd.module.options.mixins.BatchJobSinglestepPartitionSupportOptionMixin
-
- getPartitions() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getPartitions() - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- getPartitionSelectorClass() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
A class name for calculating a partition from a key.
- getPartitionSelectorExpression() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
The expression evaluated against the partition key to determine
the partition to which the message will be sent.
- getPassPhrase() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getPassword() - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- getPassword() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getPassword() - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- getPassword() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- getPassword() - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- getPassword() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getPassword() - Method in class org.springframework.xd.dirt.web.controller.support.AuthenticationRequest
-
- getPassword() - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- getPassword() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getPassword() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getPassword() - Method in class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- getPassword() - Method in class org.springframework.xd.mail.MailServerMixin
-
- getPassword() - Method in class org.springframework.xd.module.options.mixins.FtpConnectionMixin
-
- getPassword() - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- getPassword() - Method in class org.springframework.xd.module.options.types.Password
-
- getPassword() - Method in class org.springframework.xd.shell.Target.Credentials
-
- getPassword() - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- getPasswordFile() - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- getPasswordFile() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getPath() - Method in class org.springframework.xd.spark.streaming.examples.java.FileLoggerModuleOptionsMetadata
-
- getPathWithinContext() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- getPattern() - Method in class org.springframework.xd.dirt.modules.metadata.FileSourceOptionsMetadata
-
- getPattern() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getPayload() - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- getPayload() - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- getPayload() - Method in class org.springframework.xd.integration.hadoop.expression.MessageExpressionMethods.MessageWrappedMessage
-
- getPercentageComplete() - Method in class org.springframework.xd.rest.domain.StepExecutionProgressInfoResource
-
- getPersistence() - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- getPersistenceDirectory() - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- getPhase() - Method in class org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper
- getPhase() - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
- getPhase() - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
- getPhase() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
- getPhase() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsWritingMessageHandler
-
- getPid() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- getPid() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- getPid() - Static method in class org.springframework.xd.dirt.util.RuntimeUtils
-
Return the process id for this process.
- getPort() - Method in class org.springframework.xd.cassandra.CassandraConfiguration
-
- getPort() - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- getPort() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- getPort() - Method in class org.springframework.xd.dirt.integration.rabbit.LocalizedQueueConnectionFactory
-
- getPort() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getPort() - Method in class org.springframework.xd.dirt.modules.metadata.HttpSourceOptionsMetadata
-
- getPort() - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- getPort() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getPORT() - Method in class org.springframework.xd.dirt.server.options.AdminOptions
-
- getPORT() - Method in class org.springframework.xd.dirt.server.options.SingleNodeOptions
-
- getPort() - Method in class org.springframework.xd.gemfire.GemfireHostPortMixin
-
- getPort() - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- getPort() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getPort() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getPort() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getPort() - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- getPort() - Method in class org.springframework.xd.mail.MailServerMixin
-
- getPort() - Method in class org.springframework.xd.module.options.mixins.FtpConnectionMixin
-
- getPort() - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- getPort() - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- getPort() - Method in class org.springframework.xd.syslog.SyslogSourceOptionsMetadata
-
- getPort() - Method in class org.springframework.xd.tcp.ClientTcpConnectionFactoryOptionsMetadataMixin
-
- getPort() - Method in class org.springframework.xd.tcp.ServerTcpConnectionFactoryOptionsMetadataMixin
-
- getPort() - Method in class org.springframework.xd.test.kafka.EmbeddedZookeeper
-
- getPosition() - Method in exception org.springframework.xd.dirt.job.dsl.JobSpecificationException
-
- getPosition() - Method in exception org.springframework.xd.dirt.stream.dsl.StreamDefinitionException
-
- getPosition() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.Error
-
- getPrefetch() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getPrefix() - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- getPrivateKey() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getPrivateKey(String) - Static method in class org.springframework.xd.integration.util.ConfigUtil
-
Retrieves the private key from a file, so we can execute commands on the container.
- getPrivateKey() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- getProcessOutput(File) - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- getProfile() - Method in enum org.springframework.xd.dirt.modules.metadata.FileReadingMode
-
- getProgramArgs() - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- getProgramArgs() - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- getPrompt() - Method in class org.springframework.xd.shell.XDShellPromptProvider
-
- getProperties() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the underlying properties object.
- getProperties() - Method in class org.springframework.xd.dirt.job.dsl.Graph
-
- getProperties() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- getProperties() - Method in class org.springframework.xd.module.core.CompositeModule
-
- getProperties() - Method in interface org.springframework.xd.module.core.Module
-
Get the module's properties.
- getProperties() - Method in class org.springframework.xd.module.core.SimpleModule
-
- getPropertiesAccessor() - Method in class org.springframework.xd.dirt.integration.bus.Binding
-
- getPropertiesFile() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- getPropertiesFromArtifact() - Static method in class org.springframework.xd.integration.util.ConfigUtil
-
This method retrieves the information from the artifact and returns it as Properties.
- getPropertiesLocation() - Method in class org.springframework.xd.module.options.mixins.ScriptMixin
-
- getProperty(String) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the property for the key, or null if it doesn't exist.
- getProperty(String, String) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the property for the key, or the default value if the
property doesn't exist.
- getProperty(String, boolean) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the property for the key, or the default value if the
property doesn't exist.
- getProperty(String, int) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the property for the key, or the default value if the
property doesn't exist.
- getProperty(String, long) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the property for the key, or the default value if the
property doesn't exist.
- getProperty(String, double) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
Return the property for the key, or the default value if the
property doesn't exist.
- getProperty(String) - Method in class org.springframework.xd.dirt.server.options.BeanPropertiesPropertySource
-
- getProperty(String) - Method in class org.springframework.xd.shell.hadoop.ConfigurationCommands
-
- getPropertyDefinition() - Static method in class org.springframework.xd.dirt.job.dsl.ComposedJobUtil
-
- getPropertyNames() - Method in class org.springframework.xd.dirt.server.options.BeanPropertiesPropertySource
-
- getPropertyType() - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor.MessageOptimalPropertyAccessor
-
- getProtocol() - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- getProtocol() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- getProvider() - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- getProviderName() - Method in class org.springframework.xd.shell.XDShellBannerProvider
-
- getProviderName() - Method in class org.springframework.xd.shell.XDShellPromptProvider
-
- getQos() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- getQos() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- getQualifiedId() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata
-
- getQuery() - Method in class org.springframework.integration.x.twitter.TwitterSearchOptionsMetadata
-
- getQuery() - Method in class org.springframework.xd.gemfire.GemfireCQSourceOptionsMetadata
-
- getQuery() - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- getQuery() - Method in class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin
-
- getQueryType() - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- getQueue() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- getQueueExpression() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- getQueues() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getQueueSize() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getQuote() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- getQuote() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getRabbitConnectionFactory() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- getRabbitMQHost() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Default value is the same as the admin server host.
- getRateInterval() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getRawString(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getRawString(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getRawString(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the String
value at index 'index
' including trailing whitespace (don't trim).
- getRawString(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the String
value from column with given 'name
' including trailing whitespace (don't
trim).
- getReadTimeout() - Method in class org.springframework.integration.x.twitter.TwitterMixin
-
- getReceiveBufferBytes() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getReceiveCount() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getReceivedBytes() - Method in class org.springframework.xd.test.fixtures.TcpSink
-
Return the bytes received by the sink
- getReceiveErrorCount() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getReconnectBackoff() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getRecoveryCallback() - Method in class org.springframework.xd.analytics.metrics.redis.RedisRetryTemplate
-
- getRegexPattern() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getRegionName() - Method in class org.springframework.xd.gemfire.GemfireServerSinkModuleOptionsMetadata
-
- getRegionName() - Method in class org.springframework.xd.gemfire.GemfireSourceOptionsMetadata
-
- getRegistrations() - Method in class org.springframework.xd.tuple.serializer.kryo.TupleKryoRegistrar
-
- getRelease() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getRemoteDir() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- getRemoteDir() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- getRemoteDir() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getRemoteFileSeparator() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- getRemoteFileSeparator() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- getRemoteServerDirectory() - Method in class org.springframework.xd.test.fixtures.FtpSink
-
- getRemoteServerDirectory() - Method in class org.springframework.xd.test.fixtures.FtpSource
-
- getRemoveAbandonedTimeout() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getReOpen() - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- getReplyTimeout() - Method in class org.springframework.xd.http.HttpClientProcessorOptionsMetadata
-
- getReplyTo() - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- getRequest() - Method in class org.springframework.xd.integration.util.jmxresult.JMXChannelResult
-
- getRequest() - Method in class org.springframework.xd.integration.util.jmxresult.JMXResult
-
- getRequest() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getRequestId() - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- getRequestRequiredAck() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getResolution() - Method in class org.springframework.xd.analytics.metrics.core.AggregateCount
-
- getResolver() - Method in class org.springframework.xd.dirt.server.MessageBusClassLoaderFactory
-
- getResource(String) - Method in class org.springframework.xd.module.support.ParentLastURLClassLoader
-
- getResource() - Method in class org.springframework.xd.test.AbstractExternalResourceTestSupport
-
- getResourceByPath(String) - Method in class org.springframework.xd.module.support.ArchiveResourceLoader
-
- getResourceManagerHost() - Method in class org.springframework.xd.module.options.mixins.MapreduceConfigurationMixin
-
- getResourceManagerPort() - Method in class org.springframework.xd.module.options.mixins.MapreduceConfigurationMixin
-
- getResources(String, String, String) - Method in class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
- getResources() - Method in class org.springframework.xd.module.options.mixins.BatchJobResourcesOptionMixin
-
- getResources(String) - Method in class org.springframework.xd.module.support.ArchiveResourceLoader
-
- getResources(String) - Method in class org.springframework.xd.module.support.ParentLastURLClassLoader
-
- getRestartable() - Method in class org.springframework.xd.module.options.mixins.BatchJobRestartableOptionMixin
-
- getResult(Message<?>) - Method in class org.springframework.xd.dirt.batch.tasklet.JobLaunchingTasklet
-
- getResultType() - Method in class org.springframework.integration.x.twitter.TwitterSearchOptionsMetadata
-
- getRetryBackoff() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getRetryMultiplier() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getRetryPolicy() - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- getRetryPolicy() - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
Return the Curator retry policy.
- getRfc() - Method in class org.springframework.xd.syslog.SyslogSourceOptionsMetadata
-
- getRingBufferSize() - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler
-
Return the size of the RingBuffer
- getRollover() - Method in class org.springframework.xd.dirt.modules.metadata.FilePollHdfsJobOptionsMetadata
-
- getRollover() - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- getRolloverThresholdInBytes() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- getRolloverThresholdInBytes() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- getRolloverThresholdInBytes() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- getRolloverThresholdInBytes() - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- getRoutingKey() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSinkOptionsMetadata
-
- getRows() - Method in class org.springframework.xd.shell.util.Table
-
- getRules() - Method in class org.springframework.xd.dirt.web.config.SecurityConfiguration.AuthorizationConfig
-
- getRunningContainers(SpringXDTemplate) - Static method in class org.springframework.xd.distributed.util.ServerProcessUtils
-
Return a map of running containers.
- getRuntimeModules(URL) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Return a list of container id's where the module is deployed
- getSampleUnit() - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerMessageHandler
-
- getSampleUnit() - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerOptionsMetadata
-
- getSchemaAction() - Method in class org.springframework.xd.cassandra.CassandraConfiguration
-
- getScript() - Method in class org.springframework.xd.module.options.mixins.ScriptMixin
-
- getSecurityInfo() - Method in class org.springframework.xd.dirt.rest.security.SecurityController
-
Return security information.
- getSegmentRejectLimit() - Method in class org.springframework.xd.greenplum.support.ReadableTable
-
- getSegmentRejectLimit() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getSegmentRejectType() - Method in class org.springframework.xd.greenplum.support.ReadableTable
-
- getSegmentRejectType() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- getSendBufferBytes() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getSendCount() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getSendErrorCount() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getSentinelConfig() - Method in class org.springframework.xd.redis.RedisSinkConfiguration
-
- getSentinelMaster() - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- getSentinelNodes() - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- getSequence() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
The sequence number for this module.
- getSequence() - Method in class org.springframework.xd.module.RuntimeModuleDeploymentProperties
-
Get the module sequence.
- getSequenceAsString() - Method in class org.springframework.xd.module.RuntimeModuleDeploymentProperties
-
Get the module sequence as string.
- getSeries() - Method in class org.springframework.xd.dirt.job.dsl.Flow
-
- getSeries() - Method in class org.springframework.xd.dirt.job.dsl.JobNode
-
For nodes representing a flow or a split, return the series of
elements to run in sequence/parallel.
- getSeries() - Method in class org.springframework.xd.dirt.job.dsl.Split
-
- getSeriesElement(int) - Method in class org.springframework.xd.dirt.job.dsl.Flow
-
- getSeriesElement(int) - Method in class org.springframework.xd.dirt.job.dsl.JobNode
-
For nodes representing a flow or a split, return a specific element in the
series of things that will run either sequentially or in parallel.
- getSeriesElement(int) - Method in class org.springframework.xd.dirt.job.dsl.Split
-
- getSeriesLength() - Method in class org.springframework.xd.dirt.job.dsl.Flow
-
- getSeriesLength() - Method in class org.springframework.xd.dirt.job.dsl.JobNode
-
For nodes representing a flow or split, return how many are in the series of things
to run (so the number to run in sequence or the number to run in parallel).
- getSeriesLength() - Method in class org.springframework.xd.dirt.job.dsl.Split
-
- getServerProperties() - Method in class org.springframework.xd.batch.hsqldb.server.HSQLServerBean
-
- getShort(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getShort(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getShort(String, short) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getShort(int, short) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getShort(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'short
' value at index 'index
'.
- getShort(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'short
' value from column with given 'name
'.
- getShort(int, short) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'short
' value at index 'index
'.
- getShort(String, short) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the 'short
' value from column with given 'name
'.
- getShortDescription() - Method in class org.springframework.xd.module.info.ModuleInformation
-
- getShortDescription() - Method in class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource
-
- getSingleObject(String) - Method in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
Returns a single object from the collection.
- getSinkChannelName() - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Return name of sink channel, if defined by the stream/job definition.
- getSinkChannelName() - Method in class org.springframework.xd.module.ModuleDescriptor
-
Return name of sink channel, if defined by the stream/job definition.
- getSinkChannelName() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.ModuleDescriptor
-
- getSinkChannelNode() - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- getSnapshotDir() - Method in class org.springframework.xd.test.kafka.EmbeddedZookeeper
-
- getSocketBufferBytes() - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- getSocketTimeout() - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- getSocketTimeout() - Method in class org.springframework.xd.tcp.AbstractTcpConnectionFactoryOptionsMetadata
-
- getSource() - Method in class org.springframework.xd.dirt.event.AbstractEvent
-
- getSourceChannelName() - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Return name of source channel, if defined by the stream/job definition.
- getSourceChannelName() - Method in class org.springframework.xd.module.ModuleDescriptor
-
Return name of source channel, if defined by the stream/job definition.
- getSourceChannelName() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.ModuleDescriptor
-
- getSourceChannelNode() - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- getSparkAppJar() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the location of the SparkApp Jar
- getSparkAppJar() - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
- getSparkAppJarSource() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the location of the spark app jar to be used for the test.
- getSparkAppJarSource() - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
- getSparkAppMainClass() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the package.class of the Spark App
- getSparkAppMainClass() - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
- getSparkAppName() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the name associated with the Spark App
- getSparkAppName() - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
- getSparkConfigProperties() - Method in class org.springframework.xd.spark.streaming.examples.java.FileLogger
-
- getSparkConfigProperties() - Method in class org.springframework.xd.spark.streaming.examples.java.WordCount
-
- getSparkMaster() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves URI (spark://host:port or the local setting (local[x]) for the spark master
- getSparkMaster() - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
- getSpecificTargetClasses() - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor
-
- getSpecificTargetClasses() - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor.MessageOptimalPropertyAccessor
-
- getSpecificTargetClasses() - Method in class org.springframework.xd.tuple.spel.TuplePropertyAccessor
-
- getSpringXDOperations() - Method in class org.springframework.xd.shell.XDShell
-
- getSpringXdVersion() - Static method in class org.springframework.xd.dirt.util.XdUtils
-
Returns the Spring XD version using Package.getImplementationVersion()
.
- getSql() - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- getSqlAfter() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getSqlAfter() - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- getSqlAfter() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getSqlBefore() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getSqlBefore() - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- getSqlBefore() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getSslPropertiesLocation() - Method in class org.springframework.xd.dirt.modules.metadata.HttpSourceOptionsMetadata
-
- getSslPropertiesLocation() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- getStackTrace(Throwable) - Static method in class org.springframework.xd.dirt.zookeeper.ZooKeeperUtils
-
Return the full stack trace for a Throwable.
- getStandardDeviationSendDuration() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getStartDate() - Method in class org.springframework.xd.dirt.job.DetailedJobInfo
-
- getStartDate() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getStartDate() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getStartDate() - Method in class org.springframework.xd.rest.domain.DetailedJobInfoResource
-
- getStartDate() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getStartedAt() - Method in class org.springframework.xd.dirt.stream.BaseInstance
-
- getStartMessage() - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerMessageHandler
-
- getStartMessage() - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerOptionsMetadata
-
- getStartPos() - Method in class org.springframework.xd.dirt.job.dsl.AstNode
-
- getStartPos() - Method in class org.springframework.xd.dirt.stream.dsl.AstNode
-
- getStartTime() - Method in class org.springframework.xd.dirt.job.DetailedJobInfo
-
- getStartTime() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getStartTime() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getStartTime() - Method in class org.springframework.xd.rest.domain.DetailedJobInfoResource
-
- getStartTime() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getState() - Method in class org.springframework.xd.dirt.core.DeploymentUnitStatus
-
Return the state of the deployment unit.
- getState() - Method in class org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus
-
- getStatementExpression() - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- getStateName() - Method in class org.springframework.xd.dirt.job.dsl.Transition
-
- getStateNameInDSLForm() - Method in class org.springframework.xd.dirt.job.dsl.Transition
-
Basic names do not need wrapping in quotes but special characters, like
asterisk do.
- getStatus() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getStatus() - Method in class org.springframework.xd.dirt.stream.BaseInstance
-
- getStatus() - Method in class org.springframework.xd.integration.util.jmxresult.JMXChannelResult
-
- getStatus() - Method in class org.springframework.xd.integration.util.jmxresult.JMXResult
-
- getStatus() - Method in class org.springframework.xd.rest.domain.DeployableResource
-
Return status of the underlying deployment unit, or null
if unknown.
- getStatus() - Method in class org.springframework.xd.shell.Target
-
Return the target status, which is either Success or Error.
- getStepExecution() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getStepExecution() - Method in class org.springframework.xd.dirt.job.StepExecutionProgressInfo
-
- getStepExecution() - Method in class org.springframework.xd.dirt.plugins.job.support.listener.ChunkContextInfo
-
- getStepExecution() - Method in class org.springframework.xd.rest.domain.StepExecutionInfoResource
-
- getStepExecution() - Method in class org.springframework.xd.rest.domain.StepExecutionProgressInfoResource
-
- getStepExecutionCount() - Method in class org.springframework.xd.dirt.job.DetailedJobInfo
-
- getStepExecutionCount() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getStepExecutionCount() - Method in class org.springframework.xd.rest.domain.DetailedJobInfoResource
-
- getStepExecutionCount() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getStepExecutionHistory() - Method in class org.springframework.xd.dirt.job.StepExecutionProgressInfo
-
- getStepExecutionHistory() - Method in class org.springframework.xd.rest.domain.StepExecutionProgressInfoResource
-
- getStepExecutionId() - Method in class org.springframework.xd.dirt.job.StepExecutionProgressInfo
-
- getStepType() - Method in class org.springframework.xd.dirt.job.StepExecutionInfo
-
- getStepType() - Method in class org.springframework.xd.rest.domain.StepExecutionInfoResource
-
- getStopTimeout() - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler
-
Return the time to wait when shutting down the processor in millseconds
- getStorageLevel() - Method in class org.springframework.xd.spark.streaming.DefaultSparkStreamingModuleOptionsMetadata
-
- getStore() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getStreamData() - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- getStreamDeployments() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.SupervisorElectedEvent
-
- getStreamName() - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Return the stream name.
- getStreamName() - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- getStreams() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getStreamText() - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- getString(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getString(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getString(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the String
value given the field 'name
'.
- getString(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the String value given the index position
- getStringRepresentation() - Method in enum org.springframework.xd.dirt.stream.dsl.ChannelType
-
- getSubject() - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- getSubscriptionName() - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- getSuccess() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.Line
-
- getSuspectTimeout() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getTable() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getTable() - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- getTable() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getTableName() - Method in class org.springframework.xd.jdbc.AbstractImportToJdbcOptionsMetadata
-
- getTableName() - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- getTarget() - Method in class org.springframework.xd.shell.Configuration
-
Return the
Target
which encapsulates not only the Target URI but also success/error messages + status.
- getTargetConnectionFactory(Object) - Method in class org.springframework.xd.dirt.integration.rabbit.LocalizedQueueConnectionFactory
-
- getTargetCredentials() - Method in class org.springframework.xd.shell.Target
-
Returns the target credentials
- getTargetException() - Method in class org.springframework.xd.shell.Target
-
If during targeting an error occurred, the resulting Exception
is made available for further
introspection.
- getTargetJobName() - Method in class org.springframework.xd.dirt.job.dsl.Transition
-
- getTargetResultMessage() - Method in class org.springframework.xd.shell.Target
-
Provides a result message indicating whether the provide
Target.getTargetUri()
was successfully targeted or
not.
- getTargetUri() - Method in class org.springframework.xd.shell.Target
-
- getTargetUriAsString() - Method in class org.springframework.xd.shell.Target
-
Returns the target URI as a String.
- getTcpClientHost() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the TCP Client host.
- getTcpClientPort() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
Retrieves the TCP Client port.
- getTcpPort() - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- getTemporaryRemoteDir() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- getTickTime() - Method in class org.springframework.xd.test.kafka.EmbeddedZookeeper
-
- getTimeBetweenEvictionRunsMillis() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getTimeField() - Method in class org.springframework.xd.analytics.metrics.metadata.AggregateCounterSinkOptionsMetadata
-
- getTimeout() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getTimeSinceLastSend() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- getTimestamp() - Method in class org.springframework.xd.integration.util.jmxresult.JMXChannelResult
-
- getTimestamp() - Method in class org.springframework.xd.integration.util.jmxresult.JMXResult
-
- getTimeUnit() - Method in class org.springframework.xd.module.options.mixins.PeriodicTriggerMixin
-
- getTimeZone() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- getTimeZone() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- getTimeZoneNameWithOffset(TimeZone) - Static method in class org.springframework.xd.shell.util.CommonUtils
-
Returns the timezone name as well as the UTC offset.
- getTmpFileSuffix() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- getTmpFileSuffix() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- getTmpFileSuffix() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getTo() - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- getTokenChars() - Method in enum org.springframework.xd.dirt.job.dsl.TokenKind
-
- getTokenChars() - Method in enum org.springframework.xd.dirt.stream.dsl.TokenKind
-
- getTokenPointer() - Method in exception org.springframework.xd.dirt.job.dsl.CheckpointedJobDefinitionException
-
- getTokenPointer() - Method in exception org.springframework.xd.dirt.stream.dsl.CheckpointedStreamDefinitionException
-
- getTokens() - Method in exception org.springframework.xd.dirt.job.dsl.CheckpointedJobDefinitionException
-
- getTokens() - Method in exception org.springframework.xd.dirt.stream.dsl.CheckpointedStreamDefinitionException
-
- getTokenStream() - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Return an immutable list of
tokens
- getTokenString() - Method in enum org.springframework.xd.dirt.job.dsl.TokenKind
-
- getTopic() - Method in class org.springframework.integration.x.kafka.KafkaSinkModuleOptionsMetadata
-
- getTopic() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getTopic() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- getTopic() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- getTopicExpression() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- getTopicMetadataFetchTimeout() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getTopicMetadataRefreshInterval() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- getTopics() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- getTopics() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- getTopLevelJobExecutions(int, int) - Method in class org.springframework.xd.dirt.job.dao.XdJdbcSearchableJobExecutionDao
-
- getTopLevelJobExecutions(int, int) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobService
-
Get a list of all JobExecution
s that do not have any parent JobExecution
s.
- getTotal() - Method in class org.springframework.xd.analytics.metrics.core.AggregateCount
-
- getTrack() - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- getTrackHistory() - Method in class org.springframework.xd.module.ModuleDeploymentProperties
-
Return the trackHistory property for this module.
- getTransactionManager() - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- getTransitionName() - Method in class org.springframework.xd.dirt.job.dsl.Link
-
- getTransitions() - Method in class org.springframework.xd.dirt.job.dsl.JobDescriptor
-
- getTtl() - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- getTuple(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getTuple(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getTuple(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the
Tuple
value given the field '
name
'.
- getTuple(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Read the Tuple value given the index position
- getTwitterAccessToken() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
The Twitter Access Token
- getTwitterAccessTokenSecret() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
The Twitter Access Token Secret
- getTwitterConsumerKey() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
The twitter consumer key
- getTwitterConsumerSecretKey() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
The twitter consumer secret key
- getTxSize() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- getType() - Method in class org.springframework.xd.dirt.event.AbstractEvent
-
- getType() - Method in class org.springframework.xd.dirt.integration.bus.Binding
-
- getType() - Method in exception org.springframework.xd.dirt.module.DependencyException
-
- getType() - Method in exception org.springframework.xd.dirt.module.ModuleAlreadyExistsException
-
- getType() - Method in class org.springframework.xd.integration.util.jmxresult.JMXRequest
-
- getType() - Method in class org.springframework.xd.module.core.AbstractModule
-
- getType() - Method in interface org.springframework.xd.module.core.Module
-
- getType() - Method in class org.springframework.xd.module.ModuleDefinition
-
- getType() - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Return the module type.
- getType() - Method in class org.springframework.xd.module.ModuleDescriptor
-
Return the module type.
- getType() - Method in class org.springframework.xd.module.ModuleDescriptor.Key
-
Return the module type.
- getType() - Method in class org.springframework.xd.module.options.ModuleOption
-
- getType() - Method in class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource.Option
-
- getType() - Method in class org.springframework.xd.rest.domain.DocumentParseResultResource.ModuleDescriptor
-
- getType() - Method in class org.springframework.xd.rest.domain.ModuleDefinitionResource
-
- getUnitName() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata
-
- getUnitName() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata.Id
-
Return the deployment unit name (stream or job) for the module instance
this metadata object is tracking.
- getUnitName() - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- getUnitName() - Method in class org.springframework.xd.rest.domain.ModuleMetadataResource
-
- getUpdate() - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- getUpdateColumns() - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- getUpdateColumns() - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- getUpdateColumns() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getUpdateCondition() - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- getUpdateCondition() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- getURI() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- getUrl() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getUrl() - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- getUrl() - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- getUrl() - Method in class org.springframework.xd.http.HttpClientProcessorOptionsMetadata
-
- getUrl() - Method in class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- getURL() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- getUser() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- getUser() - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- getUserDnPattern() - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- getUsername() - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- getUsername() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- getUsername() - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- getUsername() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- getUsername() - Method in class org.springframework.xd.dirt.web.controller.support.AuthenticationRequest
-
- getUsername() - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- getUsername() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- getUsername() - Method in class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- getUsername() - Method in class org.springframework.xd.mail.MailServerMixin
-
- getUsername() - Method in class org.springframework.xd.module.options.mixins.FtpConnectionMixin
-
- getUsername() - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- getUsername() - Method in class org.springframework.xd.rest.domain.security.SecurityInfoResource
-
- getUsername() - Method in class org.springframework.xd.shell.Target.Credentials
-
- getUsername() - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- getUsers() - Method in class org.springframework.xd.dirt.server.security.FileAuthenticationConfiguration
-
- getUserSearchBase() - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- getUserSearchFilter() - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- getUseSSL() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- getValidationInterval() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getValidationQuery() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getValidatorClassName() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- getValue() - Method in class org.springframework.xd.analytics.metrics.core.Counter
-
- getValue() - Method in class org.springframework.xd.analytics.metrics.core.Gauge
-
- getValue() - Method in class org.springframework.xd.analytics.metrics.core.RichGauge
-
- getValue() - Method in class org.springframework.xd.dirt.job.dsl.ArgumentNode
-
- getValue() - Method in class org.springframework.xd.dirt.stream.dsl.ArgumentNode
-
- getValue(Expression, Message<?>, Class<T>) - Method in class org.springframework.xd.integration.hadoop.expression.MessageExpressionMethods
-
Gets the value.
- getValue() - Method in class org.springframework.xd.integration.util.jmxresult.JMXChannelResult
-
- getValue() - Method in class org.springframework.xd.integration.util.jmxresult.JMXResult
-
- getValue() - Method in class org.springframework.xd.rest.domain.metrics.CounterResource
-
Return the value for the counter.
- getValue() - Method in class org.springframework.xd.rest.domain.metrics.GaugeResource
-
Return the value for the gauge.
- getValue() - Method in class org.springframework.xd.rest.domain.metrics.RichGaugeResource
-
Return the value for the gauge.
- getValue(Integer) - Method in class org.springframework.xd.shell.util.TableRow
-
Return a value from this row.
- getValue() - Method in enum org.springframework.xd.test.fixtures.SimpleFileSource.Mode
-
- getValue(String) - Method in class org.springframework.xd.tuple.batch.TupleSqlParameterSource
-
- getValue(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getValue(int) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getValue(String, Class<T>) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getValue(int, Class<T>) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- getValue(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Return the value of the field given the name
- getValue(int) - Method in interface org.springframework.xd.tuple.Tuple
-
Return the value of the field given the index position
- getValue(String, Class<T>) - Method in interface org.springframework.xd.tuple.Tuple
-
Return the value of the field given the name
- getValue(int, Class<T>) - Method in interface org.springframework.xd.tuple.Tuple
-
Return the value of the field given the index position
- getValues() - Method in class org.springframework.xd.jdbc.JdbcMessagePayloadTransformer
-
- getValues() - Method in class org.springframework.xd.rest.domain.metrics.AggregateCountsResource
-
Returns a date-sorted view of counts.
- getValues() - Method in class org.springframework.xd.tuple.DefaultTuple
-
Return the values for all the fields in this tuple
- getValues() - Method in interface org.springframework.xd.tuple.Tuple
-
Return the values for all the fields in this tuple
- getVariables() - Method in class org.springframework.xd.module.options.mixins.ScriptMixin
-
- getVersion() - Method in class org.springframework.xd.dirt.rest.meta.VersionController
-
Return version control information.
- getVersion() - Static method in class org.springframework.xd.dirt.util.BannerUtils
-
- getVersion() - Method in class org.springframework.xd.rest.domain.meta.VersionResource
-
- getVersion() - Method in class org.springframework.xd.shell.XDShellBannerProvider
-
Returns the version information as found in the manifest file (set during release).
- getVhost() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- getVirtualHost() - Method in class org.springframework.xd.dirt.integration.rabbit.LocalizedQueueConnectionFactory
-
- getWelcomeMessage() - Method in class org.springframework.xd.shell.XDShellBannerProvider
-
- getWidth() - Method in class org.springframework.xd.shell.util.TableHeader
-
- getWithMarkers() - Method in class org.springframework.xd.dirt.modules.metadata.FileAsRefMixin
-
- getWorkingDir() - Method in class org.springframework.xd.extension.process.ShellModuleOptionsMetadata
-
- getWriteConcern() - Method in class org.springframework.xd.module.options.mixins.IntoMongoDbOptionMixin
-
- getXD_ANALYTICS() - Method in class org.springframework.xd.dirt.server.options.CommonDistributedOptions
-
- getXD_ANALYTICS() - Method in class org.springframework.xd.dirt.server.options.SingleNodeOptions
-
- getXD_CONTAINER_GROUPS() - Method in class org.springframework.xd.dirt.server.options.ContainerOptions
-
- getXD_CONTAINER_HOSTNAME() - Method in class org.springframework.xd.dirt.server.options.ContainerOptions
-
- getXD_CONTAINER_IP() - Method in class org.springframework.xd.dirt.server.options.ContainerOptions
-
- getXD_MGMT_PORT() - Method in class org.springframework.xd.dirt.server.options.CommonOptions
-
- getXD_TRANSPORT() - Method in class org.springframework.xd.dirt.server.options.SingleNodeOptions
-
- getXML(String, String) - Method in class org.springframework.xd.dirt.job.dsl.JobParser
-
Create an XML representation of the JobSpec.
- getZkClient() - Method in class org.springframework.xd.test.kafka.KafkaTestSupport
-
- getZkconnect() - Method in class org.springframework.integration.x.kafka.KafkaZKOptionMixin
-
- getZkconnectionTimeout() - Method in class org.springframework.integration.x.kafka.KafkaZKOptionMixin
-
- getZkConnectString() - Method in class org.springframework.xd.test.kafka.KafkaTestSupport
-
- getZksessionTimeout() - Method in class org.springframework.integration.x.kafka.KafkaZKOptionMixin
-
- getZksyncTime() - Method in class org.springframework.integration.x.kafka.KafkaZKOptionMixin
-
- getZookeeper() - Method in class org.springframework.xd.test.kafka.EmbeddedZookeeper
-
- getZooKeeperConnection() - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
Return the ZooKeeper connection.
- getZSetData(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- GPFDistCodec - Class in org.springframework.xd.greenplum.gpfdist
-
- GPFDistCodec() - Constructor for class org.springframework.xd.greenplum.gpfdist.GPFDistCodec
-
- GPFDistMessageHandler - Class in org.springframework.xd.greenplum.gpfdist
-
- GPFDistMessageHandler(int, int, int, int, int, int, String) - Constructor for class org.springframework.xd.greenplum.gpfdist.GPFDistMessageHandler
-
- GPFDistServer - Class in org.springframework.xd.greenplum.gpfdist
-
- GPFDistServer(Processor<Buffer, Buffer>, int, int, int, int, int) - Constructor for class org.springframework.xd.greenplum.gpfdist.GPFDistServer
-
- GPFDistSinkOptionsMetadata - Class in org.springframework.xd.greenplum.config
-
Config options for gpfdist sink.
- GPFDistSinkOptionsMetadata() - Constructor for class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- GploadEnvironmentProvider - Class in org.springframework.xd.gpload
-
Class that sets environment variables for gpload
- GploadEnvironmentProvider(String, boolean, String) - Constructor for class org.springframework.xd.gpload.GploadEnvironmentProvider
-
- GploadOptionsMetadata - Class in org.springframework.xd.gpload
-
Module options for Gpload batch job module.
- GploadOptionsMetadata() - Constructor for class org.springframework.xd.gpload.GploadOptionsMetadata
-
- GploadTasklet - Class in org.springframework.xd.gpload
-
Tasklet used for running gpload tool.
- GploadTasklet() - Constructor for class org.springframework.xd.gpload.GploadTasklet
-
- Graph - Class in org.springframework.xd.dirt.job.dsl
-
Represents a Graph that Flo will display.
- greenMail - Variable in class org.springframework.xd.test.fixtures.DisposableMailSupport
-
- GreenplumDataSourceFactoryBean - Class in org.springframework.xd.greenplum.support
-
Factory bean for configuring a DataSource
.
- GreenplumDataSourceFactoryBean() - Constructor for class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- GreenplumLoad - Interface in org.springframework.xd.greenplum.support
-
- GROUP_INDEX_DELIMITER - Static variable in class org.springframework.xd.dirt.integration.bus.BusUtils
-
The delimiter between a group and index when constructing a bus consumer/producer.
- GROUPS_KEY - Static variable in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- groupsToValidate() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- groupsToValidate() - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- groupsToValidate() - Method in interface org.springframework.xd.module.options.spi.ValidationGroupsProvider
-
- id - Variable in class org.springframework.xd.dirt.job.dsl.Node
-
- idField(String) - Method in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
Sets the idField for the data that will be inserted by this job
- idFromRedisKey(String) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- include(String...) - Method in class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandler
-
- increment(String, long, DateTime) - Method in interface org.springframework.xd.analytics.metrics.core.AggregateCounterRepository
-
Increments the named counter by a specific amount for the given instant.
- increment(long) - Method in class org.springframework.xd.analytics.metrics.core.Counter
-
Increment this counter by a given amount.
- increment(String) - Method in interface org.springframework.xd.analytics.metrics.core.CounterRepository
-
Increment the given counter by one, creating it if it did not exist.
- increment(String, long) - Method in interface org.springframework.xd.analytics.metrics.core.CounterRepository
-
Increment the given counter by the specified amount, creating it if it did not exist.
- increment(String, String) - Method in interface org.springframework.xd.analytics.metrics.core.FieldValueCounterRepository
-
Increment the FieldValueCounter for a given field name by one, creating missing counters.
- increment(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- increment(String, long) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- increment(String, long, DateTime) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- increment(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryCounterRepository
-
- increment(String, long) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryCounterRepository
-
- increment(String, String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryFieldValueCounterRepository
-
- increment(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisAggregateCounterRepository
-
- increment(String, long) - Method in class org.springframework.xd.analytics.metrics.redis.RedisAggregateCounterRepository
-
- increment(String, long, DateTime) - Method in class org.springframework.xd.analytics.metrics.redis.RedisAggregateCounterRepository
-
- increment(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisCounterRepository
-
- increment(String, long) - Method in class org.springframework.xd.analytics.metrics.redis.RedisCounterRepository
-
- increment(String, String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- increment(String, String, double) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- IncrementalColumnRangePartitioner - Class in org.springframework.batch.integration.x
-
Provides the ability to partition a job and append additional conditions to support
incremental imports.
- IncrementalColumnRangePartitioner() - Constructor for class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
- incrementalJdbcHdfsJob() - Method in class org.springframework.xd.integration.fixtures.Jobs
-
Create an instance of the JdbcHdfs job with the default hdfs target dir, fileName and source sql statement.
- IncrementalJdbcHdfsJob - Class in org.springframework.xd.test.fixtures
-
A test fixture that represents the JdbcHdfs Job
- IncrementalJdbcHdfsJob(String, String, String, String, String, int, String, int) - Constructor for class org.springframework.xd.test.fixtures.IncrementalJdbcHdfsJob
-
Construct a new jdbchdfs fixture using the provided dir, file and sql.
- incrementBytesWritten(long) - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- incrementBytesWritten(long) - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- incrementBytesWritten(long) - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- incrementCounter() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- incrementCounter() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- incrementCounter() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- indexOf(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
Find the index in the names collection for the given name.
- info() - Method in class org.springframework.xd.dirt.rest.AdminController
-
- info(ModuleType, String) - Method in class org.springframework.xd.dirt.rest.ModulesController
-
Retrieve detailed module definition about a particular module.
- info(String, RESTModuleType) - Method in class org.springframework.xd.rest.client.impl.ModuleTemplate
-
- info(String, RESTModuleType) - Method in interface org.springframework.xd.rest.client.ModuleOperations
-
Retrieve information about a particular module.
- info() - Method in class org.springframework.xd.shell.command.ConfigCommands
-
- info() - Method in class org.springframework.xd.shell.hadoop.ConfigurationCommands
-
- init() - Method in class org.springframework.xd.cassandra.CassandraConfiguration
-
- init(AuthenticationManagerBuilder) - Method in class org.springframework.xd.dirt.server.security.FileAuthenticationConfiguration
-
- init(AuthenticationManagerBuilder) - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- init() - Method in class org.springframework.xd.integration.hadoop.config.HadoopNamespaceHandler
-
- init() - Method in class org.springframework.xd.integration.reactor.config.ReactorNamespaceHandler
-
- init() - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- initalizeEc2Environment() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
If not running tests on a local XD Instance it will retrieve the information from the artifact and setup the
environment to test against a remote XD.
- initialize() - Method in class org.springframework.xd.batch.XdBatchDatabaseInitializer
-
- initialize() - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- initialize() - Method in class org.springframework.xd.module.core.CompositeModule
-
- initialize() - Method in interface org.springframework.xd.module.core.Module
-
- initialize() - Method in class org.springframework.xd.module.core.SimpleModule
-
Initialize this module by creating its application context, and provide it with a special
Environment
that knows how to resolve module options placeholders.
- initialize(CronExpression) - Method in class org.springframework.xd.module.options.validation.CronExpression.CronValidator
-
- initialize(DateFormat) - Method in class org.springframework.xd.module.options.validation.DateFormat.DateFormatValidator
-
- initialize(DateWithCustomFormat) - Method in class org.springframework.xd.module.options.validation.DateWithCustomFormat.DateWithCustomFormatValidator
-
- initializeCounterIfNecessary() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- initializeCounterIfNecessary() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- initializeCounterIfNecessary() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- initializeDatabase - Variable in class org.springframework.xd.jdbc.AbstractImportToJdbcOptionsMetadata
-
- initializeDB(boolean) - Method in class org.springframework.xd.test.fixtures.JdbcSink
-
- initializerScript - Variable in class org.springframework.xd.jdbc.AbstractImportToJdbcOptionsMetadata
-
- InitialOffsetsFactoryBean - Class in org.springframework.integration.x.kafka
-
Parses the list of initial offsets and creates a map to initialize the OffsetManager
- InitialOffsetsFactoryBean(String, String) - Constructor for class org.springframework.integration.x.kafka.InitialOffsetsFactoryBean
-
- initialSize - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- initSQL - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- InMemoryAggregateCounterRepository - Class in org.springframework.xd.analytics.metrics.memory
-
In-memory aggregate counter with minute resolution.
- InMemoryAggregateCounterRepository() - Constructor for class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- InMemoryCounterRepository - Class in org.springframework.xd.analytics.metrics.memory
-
Memory backed implementation of Counter repository that uses a ConcurrentMap.
- InMemoryCounterRepository() - Constructor for class org.springframework.xd.analytics.metrics.memory.InMemoryCounterRepository
-
- InMemoryFieldValueCounterRepository - Class in org.springframework.xd.analytics.metrics.memory
-
Memory backed implementation of FieldValueCounterRepository that uses a ConcurrentMap
- InMemoryFieldValueCounterRepository() - Constructor for class org.springframework.xd.analytics.metrics.memory.InMemoryFieldValueCounterRepository
-
- InMemoryGaugeRepository - Class in org.springframework.xd.analytics.metrics.memory
-
Memory backed Gauge repository that uses a ConcurrentMap
- InMemoryGaugeRepository() - Constructor for class org.springframework.xd.analytics.metrics.memory.InMemoryGaugeRepository
-
- InMemoryMetricRepository<M extends Metric> - Class in org.springframework.xd.analytics.metrics.memory
-
Memory backed implementation of MetricRepository that uses a ConcurrentMap
- InMemoryMetricRepository() - Constructor for class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- InMemoryRichGaugeRepository - Class in org.springframework.xd.analytics.metrics.memory
-
Memory backed implementation of GaugeRepository that uses a ConcurrentMap
- InMemoryRichGaugeRepository() - Constructor for class org.springframework.xd.analytics.metrics.memory.InMemoryRichGaugeRepository
-
- input() - Method in class org.springframework.xd.cassandra.CassandraSinkConfiguration
-
- InputMapper<I,A,MI> - Interface in org.springframework.xd.analytics.ml
-
An InputMapper
maps a given domain input I
to an appropriate model input MI
for the given
analytic A
.
- inserts - Variable in exception org.springframework.xd.dirt.job.dsl.JobSpecificationException
-
- inserts - Variable in exception org.springframework.xd.dirt.stream.dsl.StreamDefinitionException
-
- installMessageConverters(List<HttpMessageConverter<?>>) - Static method in class org.springframework.xd.rest.domain.support.RestTemplateMessageConverterUtil
-
Install message converters we're interested in, with json coming before xml.
- instanceRepository - Variable in class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
- instancesForJob(String, int, int) - Method in class org.springframework.xd.dirt.rest.BatchJobInstancesController
-
Return a paged collection of job instances for a given job.
- instantiateResource(DetailedJobInfo) - Method in class org.springframework.xd.dirt.rest.DetailedJobInfoResourceAssembler
-
- instantiateResource(ModuleDefinition) - Method in class org.springframework.xd.dirt.rest.DetailedModuleDefinitionResourceAssembler
-
- instantiateResource(JobDefinition) - Method in class org.springframework.xd.dirt.rest.JobDefinitionResourceAssembler
-
- instantiateResource(JobExecutionInfo) - Method in class org.springframework.xd.dirt.rest.JobExecutionInfoResourceAssembler
-
- instantiateResource(JobInfo) - Method in class org.springframework.xd.dirt.rest.JobInfoResourceAssembler
-
- instantiateResource(JobInstanceInfo) - Method in class org.springframework.xd.dirt.rest.JobInstanceInfoResourceAssembler
-
- instantiateResource(AggregateCount) - Method in class org.springframework.xd.dirt.rest.metrics.DeepAggregateCountResourceAssembler
-
- instantiateResource(Counter) - Method in class org.springframework.xd.dirt.rest.metrics.DeepCounterResourceAssembler
-
- instantiateResource(FieldValueCounter) - Method in class org.springframework.xd.dirt.rest.metrics.DeepFieldValueCounterResourceAssembler
-
- instantiateResource(M) - Method in class org.springframework.xd.dirt.rest.metrics.ShallowMetricResourceAssembler
-
- instantiateResource(ModuleDefinition) - Method in class org.springframework.xd.dirt.rest.ModuleDefinitionResourceAssembler
-
- instantiateResource(ModuleMetadata) - Method in class org.springframework.xd.dirt.rest.ModuleMetadataResourceAssembler
-
- instantiateResource(DetailedContainer) - Method in class org.springframework.xd.dirt.rest.RuntimeContainerResourceAssembler
-
- instantiateResource(StepExecutionInfo) - Method in class org.springframework.xd.dirt.rest.StepExecutionInfoResourceAssembler
-
- instantiateResource(StepExecutionProgressInfo) - Method in class org.springframework.xd.dirt.rest.StepExecutionProgressInfoResourceAssembler
-
- instantiateResource(StreamDefinition) - Method in class org.springframework.xd.dirt.rest.StreamDefinitionResourceAssembler
-
- IntegerEncoderDecoder - Class in org.springframework.xd.dirt.integration.kafka
-
A Kafka encoder / decoder used to serialize a single int, used as the kafka partition key.
- IntegerEncoderDecoder() - Constructor for class org.springframework.xd.dirt.integration.kafka.IntegerEncoderDecoder
-
- IntegerEncoderDecoder(VerifiableProperties) - Constructor for class org.springframework.xd.dirt.integration.kafka.IntegerEncoderDecoder
-
- IntegrationHadoopNamespaceUtils - Class in org.springframework.xd.integration.hadoop.config
-
Utility methods for namespace.
- IntegrationHadoopSystemConstants - Class in org.springframework.xd.integration.hadoop
-
Various constants throughout the spring integration hadoop libraries.
- integrationSupport - Variable in class org.springframework.xd.dirt.test.process.AbstractSingleNodeProcessingChain
-
- interpolate(Map<String, String>) - Method in class org.springframework.xd.module.options.FlattenedCompositeModuleOptionsMetadata
-
- interpolate(Map<String, String>) - Method in class org.springframework.xd.module.options.HierarchicalCompositeModuleOptionsMetadata
-
- interpolate(Map<String, String>) - Method in interface org.springframework.xd.module.options.ModuleOptionsMetadata
-
Derive information about the module behavior once it is part of a stream and user provided values for the module
options are known.
- interpolate(Map<String, String>) - Method in class org.springframework.xd.module.options.PassthruModuleOptionsMetadata
-
- interpolate(Map<String, String>) - Method in class org.springframework.xd.module.options.PojoModuleOptionsMetadata
-
- interpolate(Map<String, String>) - Method in class org.springframework.xd.module.options.SimpleModuleOptionsMetadata
-
- IntoMongoDbOptionMixin - Class in org.springframework.xd.module.options.mixins
-
An option class to mix-in when writing to MongoDB.
- IntoMongoDbOptionMixin(String) - Constructor for class org.springframework.xd.module.options.mixins.IntoMongoDbOptionMixin
-
Subclasses should provide a default value for collectionName.
- IntoMongoDbOptionMixin.Job - Class in org.springframework.xd.module.options.mixins
-
Has collectionName
default to ${xd.job.name}.
- IntoMongoDbOptionMixin.Job() - Constructor for class org.springframework.xd.module.options.mixins.IntoMongoDbOptionMixin.Job
-
- IntoMongoDbOptionMixin.Stream - Class in org.springframework.xd.module.options.mixins
-
Has collectionName
default to ${xd.stream.name}.
- IntoMongoDbOptionMixin.Stream() - Constructor for class org.springframework.xd.module.options.mixins.IntoMongoDbOptionMixin.Stream
-
- IntoMongoDbOptionMixin.WriteConcern - Enum in org.springframework.xd.module.options.mixins
-
- InvalidResultException - Exception in org.springframework.xd.integration.util
-
- InvalidResultException(String) - Constructor for exception org.springframework.xd.integration.util.InvalidResultException
-
- invoke(MethodInvocation) - Method in class org.springframework.xd.dirt.module.support.ThreadContextClassLoaderSetterAdvice
-
- invokeProcessor(Message<?>, RingBufferProcessor<Object>) - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler
-
- IP_ADDRESS_KEY - Static variable in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- IP_ADDRESS_KEY - Static variable in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- IS_RESTART_JOB_PARAMETER_KEY - Static variable in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
- isAbandonable() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- isAbandonable() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- isAllowUnknownKeys() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- isAlternateUsernameAllowed() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- isAsync() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- isAuthenticated() - Method in class org.springframework.xd.rest.domain.security.SecurityInfoResource
-
- isAuthenticationEnabled() - Method in class org.springframework.xd.rest.domain.security.SecurityInfoResource
-
- isAutoCreateDir() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- isAutoCreateLocalDir() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- isAutoCreateLocalDir() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- isAutoStartup() - Method in class org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper
- isAutoStartup() - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
- isAutoStartup() - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
- isAutoStartup() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
- isAutoStartup() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsWritingMessageHandler
-
- isBatchingEnabled(boolean) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
If true, enable batching.
- isBinary() - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- isBinary() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- isBlockOnBufferFull() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- isCapable(MessageBus.Capability) - Method in interface org.springframework.xd.dirt.integration.bus.MessageBus
-
Return true if the bus supports the capability.
- isCapable(MessageBus.Capability) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- isCapable(MessageBus.Capability) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- isCapable(MessageBus.Capability) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- isChannelPubSub(String) - Static method in class org.springframework.xd.dirt.integration.bus.BusUtils
-
Determine whether the provided channel name represents a pub/sub channel (i.e.
- isCleanSession() - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- isClose() - Method in class org.springframework.xd.tcp.ClientTcpConnectionFactoryOptionsMetadataMixin
-
- isCollectionTypeValid() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- isCompilable() - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor.MessageOptimalPropertyAccessor
-
- isComplete() - Method in class org.springframework.xd.dirt.plugins.job.support.listener.ChunkContextInfo
-
- isComposed() - Method in class org.springframework.xd.dirt.module.UploadedModuleDefinition
-
- isComposed() - Method in class org.springframework.xd.module.CompositeModuleDefinition
-
- isComposed() - Method in class org.springframework.xd.module.ModuleDefinition
-
Determine if this a composed module
- isComposed() - Method in class org.springframework.xd.module.ModuleDescriptor
-
Return true if this is a composed module.
- isComposed() - Method in class org.springframework.xd.module.SimpleModuleDefinition
-
- isComposed() - Method in class org.springframework.xd.rest.domain.ModuleDefinitionResource
-
- isComposedJob() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
Is this a composed Job? ?
- isComposedJobDefinition(String) - Static method in class org.springframework.xd.dirt.job.dsl.ComposedJobUtil
-
Is this definition a composed job definition
- isComposedJobExecution(long) - Method in class org.springframework.xd.dirt.job.dao.XdJdbcSearchableJobExecutionDao
-
- isComposedJobExecution(long) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobService
-
Determines, if the Job Execution represents a composed job.
- isCompress(boolean) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
If true, messages will be compressed.
- isConnected() - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
Checks whether the underlying connection is established.
- isDefinition() - Method in class org.springframework.xd.dirt.job.dsl.JobDefinition
-
- isDefinition() - Method in class org.springframework.xd.dirt.job.dsl.JobDescriptor
-
- isDelete() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- isDeleted() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
Check if the job definition is deleted/destroyed.
- isDeleteRemoteFiles() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- isDeleteRemoteFiles() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- isDelimited() - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- isDeployed() - Method in class org.springframework.xd.dirt.job.JobInfo
-
Return the deployment status from job info.
- isDeployed() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
Check if the job is deployed.
- isDeployed() - Method in class org.springframework.xd.rest.domain.JobInfoResource
-
Return the deployment status from job info resource.
- isDeployments() - Method in class org.springframework.xd.dirt.rest.XDController.QueryOptions
-
Whether to also return deployment status when listing definitions.
- isDirectBindingAllowed() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
If true, the bus can attempt a direct binding.
- isDiscardDeletes() - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- isDurable(boolean) - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
If true, subscriptions to taps/topics will be durable.
- isDurableSubscription() - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- isEitherGeocodeOrQueryRequired() - Method in class org.springframework.integration.x.twitter.TwitterSearchOptionsMetadata
-
- isEmpty() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- isEmpty() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- isEmpty() - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- isEmpty() - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- isEnableRetry() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- isEnableTap() - Method in class org.springframework.xd.spark.streaming.DefaultSparkStreamingModuleOptionsMetadata
-
- isEnd() - Method in class org.springframework.xd.dirt.job.dsl.Node
-
- isEndTransition() - Method in class org.springframework.xd.dirt.job.dsl.Transition
-
- isFail() - Method in class org.springframework.xd.dirt.job.dsl.Node
-
- isFailTransition() - Method in class org.springframework.xd.dirt.job.dsl.Transition
-
- isFairQueue() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- isFinished() - Method in class org.springframework.xd.dirt.job.StepExecutionProgressInfo
-
- isFormatHeader() - Method in class org.springframework.xd.greenplum.support.ReadableTable
-
- isHidden() - Method in class org.springframework.xd.module.options.ModuleOption
-
- isHidden() - Method in class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource.Option
-
- isHttps() - Method in class org.springframework.xd.dirt.modules.metadata.HttpSourceOptionsMetadata
-
- isIdentifier() - Method in class org.springframework.xd.dirt.job.dsl.Token
-
- isIdentifier() - Method in class org.springframework.xd.dirt.stream.dsl.Token
-
- isIncludeEntities() - Method in class org.springframework.integration.x.twitter.TwitterSearchOptionsMetadata
-
- isIncrementable() - Method in class org.springframework.xd.dirt.job.JobInfo
-
- isIncrementable(String) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
- isIncrementable(String) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobService
-
- isIncrementable() - Method in class org.springframework.xd.rest.domain.JobInfoResource
-
- isInitializeDatabase() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- isInitializeDB() - Method in class org.springframework.xd.test.fixtures.JdbcSink
-
- isInitialOffsetsValid() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- isInvalidAlpha() - Method in class org.springframework.xd.analytics.metrics.metadata.RichGaugeSinkOptionsMetadata
-
- isJmxEnabled() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- isJobDescriptor() - Method in class org.springframework.xd.dirt.job.dsl.JobDescriptor
-
- isJobDescriptor() - Method in class org.springframework.xd.dirt.job.dsl.JobNode
-
- isKeeptable() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- isKind(TokenKind) - Method in class org.springframework.xd.dirt.job.dsl.Token
-
- isKind(TokenKind) - Method in class org.springframework.xd.dirt.stream.dsl.Token
-
- isLaunchable() - Method in class org.springframework.xd.dirt.job.JobInfo
-
- isLaunchable() - Method in class org.springframework.xd.rest.domain.JobInfoResource
-
- isListenersListValid() - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- isLogAbandoned() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- isMakeUnique() - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- isMarkAsRead() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- isMetricsEnabled() - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- isNamedChannel(String) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- isNextAdjacent() - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Return true
if the first character of the token at the current position
is the same as the last character of the token at the previous position.
- isNio() - Method in class org.springframework.xd.syslog.SyslogTcpSourceOptionsMetadata
-
- isNio() - Method in class org.springframework.xd.tcp.AbstractTcpConnectionFactoryOptionsMetadata
-
- ISO8601DateFormatWithMilliSeconds - Class in org.springframework.xd.rest.domain.util
-
Improved version of the ISO8601DateFormat
that also serializes milliseconds.
- ISO8601DateFormatWithMilliSeconds() - Constructor for class org.springframework.xd.rest.domain.util.ISO8601DateFormatWithMilliSeconds
-
- isOnEc2() - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- isOpen() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- isOptionMutuallyExclusive() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
User can't explicitly set mutually exclusive values together.
- isOptionRequired() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- isPartitionedModule() - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport.PartitioningMetadata
-
- isPartitionsOptionValid() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- isPreserveTimestamp() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- isPreventDuplicates() - Method in class org.springframework.xd.dirt.modules.metadata.FileSourceOptionsMetadata
-
- isPubSub() - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- isReadable() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- isReady() - Method in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
Checks to see if the default mongo port 2000 is available on the configured host waiting up to 2 seconds
- isReady() - Method in class org.springframework.xd.test.fixtures.JdbcSink
-
Determines if a connection to the designated database can be made.
- isRedirectErrorStream() - Method in class org.springframework.xd.extension.process.ShellModuleOptionsMetadata
-
- isReference() - Method in class org.springframework.xd.dirt.job.dsl.JobDescriptor
-
- isReference() - Method in class org.springframework.xd.dirt.job.dsl.JobReference
-
- isRemoveAbandoned() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- isRequestRequiredAckValid() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- isRequeue() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- isRestartable() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- isRestartable(String) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
- isRestartable() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- isRetained() - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- isReverseLookup() - Method in class org.springframework.xd.tcp.AbstractTcpConnectionFactoryOptionsMetadata
-
- isRunning() - Method in class org.springframework.xd.dirt.integration.bus.Binding
-
- isRunning() - Method in class org.springframework.xd.dirt.plugins.job.ModuleJobLauncher
-
- isRunning() - Method in class org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper
- isRunning() - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
Check whether this client is running.
- isRunning() - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
- isRunning() - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
- isRunning() - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- isRunning() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
- isRunning() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsWritingMessageHandler
-
- isRunning() - Method in class org.springframework.xd.module.core.CompositeModule
-
- isRunning() - Method in class org.springframework.xd.module.core.SimpleModule
-
- isRunning() - Method in class org.springframework.xd.spark.streaming.SparkMessageSender
-
Check if the message sender is running
- isShowHelp() - Method in class org.springframework.xd.dirt.server.options.CommonOptions
-
- isSingleton() - Method in class org.springframework.integration.x.kafka.InitialOffsetsFactoryBean
-
- isSingleton() - Method in class org.springframework.integration.x.kafka.KafkaPartitionAllocator
-
- isSingleton() - Method in class org.springframework.xd.dirt.jdbc.util.DatabaseVendorFriendlyNameFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.dirt.module.CustomModuleRegistryFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.greenplum.support.ControlFileFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.greenplum.support.LoadFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.hadoop.fs.DatasetDefinitionFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.integration.hadoop.config.DatasetWritingMessageHandlerFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.integration.hadoop.config.HdfsWritingMessageHandlerFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
- isSingleton() - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- isSparkStorageValid() - Method in class org.springframework.xd.spark.streaming.DefaultSparkStreamingModuleOptionsMetadata
-
- isSpecialTransition() - Method in class org.springframework.xd.dirt.job.dsl.Transition
-
Some target names for a transition are 'well known' like $FAIL and $END - these
do not indicate a following job step, they instead indicate a termination state.
- isSplit() - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- isSplit() - Method in class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin
-
- isStale(SimpleModuleDefinition, SimpleModuleDefinition) - Method in class org.springframework.xd.dirt.module.MD5StalenessCheck
-
- isStale(SimpleModuleDefinition, SimpleModuleDefinition) - Method in interface org.springframework.xd.dirt.module.StalenessCheck
-
Return whether the target definition (which may be null
) is stale compared to the source definition.
- isStallWarnings() - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- isStart() - Method in class org.springframework.xd.dirt.job.dsl.Node
-
- isStoppable() - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- isStoppable() - Method in class org.springframework.xd.dirt.job.JobExecutionInfo
-
- isStoppable() - Method in class org.springframework.xd.gpload.GploadTasklet
-
- isStoppable() - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- isStoppable() - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- isStreamDeployed(String, URL) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Checks to see if the specified stream is deployed on the XD cluster.
- isSync() - Method in class org.springframework.xd.dirt.job.dsl.Node
-
- isTap() - Method in enum org.springframework.xd.dirt.stream.dsl.ChannelType
-
- isTestOnBorrow() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- isTestOnReturn() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- isTestWhileIdle() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- isTopicOptionValid() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- isTransacted() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- isUseDirectBuffers() - Method in class org.springframework.xd.tcp.AbstractTcpConnectionFactoryOptionsMetadata
-
- isUseEquals() - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- isUseLocator() - Method in class org.springframework.xd.gemfire.GemfireHostPortMixin
-
- isUsePolling() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- isUseTemporaryFilename() - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- isValid() - Method in class org.springframework.xd.module.options.mixins.ExpressionOrScriptMixin
-
User can't explicitly set both script and expression.
- isValid() - Method in class org.springframework.xd.module.options.mixins.ScriptMixin
-
Validates the configuration meets expected conditions.
- isValid(CharSequence, ConstraintValidatorContext) - Method in class org.springframework.xd.module.options.validation.CronExpression.CronValidator
-
- isValid(CharSequence, ConstraintValidatorContext) - Method in class org.springframework.xd.module.options.validation.DateFormat.DateFormatValidator
-
- isValid(Object, ConstraintValidatorContext) - Method in class org.springframework.xd.module.options.validation.DateWithCustomFormat.DateWithCustomFormatValidator
-
- isValid() - Method in class org.springframework.xd.rest.domain.validation.CronValidation
-
- isValidCompressionCodec() - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- isValidEmail(String) - Static method in class org.springframework.xd.shell.util.CommonUtils
-
- isValidStreamName(String) - Static method in class org.springframework.xd.dirt.stream.dsl.StreamConfigParser
-
Verify the supplied name is a valid stream name.
- isVerbose() - Method in class org.springframework.xd.dirt.server.options.CommonOptions
-
- isVersionAvailable() - Method in class org.springframework.xd.rest.domain.meta.VersionResource
-
- isWithMarkersValid() - Method in class org.springframework.xd.dirt.modules.metadata.FileAsRefMixin
-
- ITEM_EVENTS_SUFFIX - Static variable in interface org.springframework.xd.dirt.plugins.job.support.listener.XDJobListenerConstants
-
- iterator() - Method in class org.springframework.xd.dirt.stream.DocumentParseResult
-
- iterator() - Method in class org.springframework.xd.module.options.FlattenedCompositeModuleOptionsMetadata
-
- iterator() - Method in class org.springframework.xd.module.options.HierarchicalCompositeModuleOptionsMetadata
-
- iterator() - Method in class org.springframework.xd.module.options.PassthruModuleOptionsMetadata
-
- iterator() - Method in class org.springframework.xd.module.options.PojoModuleOptionsMetadata
-
- iterator() - Method in class org.springframework.xd.module.options.SimpleModuleOptionsMetadata
-
- JavaConfiguredModule - Class in org.springframework.xd.module.core
-
- JavaConfiguredModule(ModuleDescriptor, ModuleDeploymentProperties) - Constructor for class org.springframework.xd.module.core.JavaConfiguredModule
-
- JavaConfiguredModule(ModuleDescriptor, ModuleDeploymentProperties, ClassLoader, ModuleOptions) - Constructor for class org.springframework.xd.module.core.JavaConfiguredModule
-
- JavaMailPropertiesFactoryBean - Class in org.springframework.xd.mail
-
PropertiesFactoryBean
that
reads comma separated (ex: key1=value1,key2=value2) values and make them as properties.
- JavaMailPropertiesFactoryBean() - Constructor for class org.springframework.xd.mail.JavaMailPropertiesFactoryBean
-
- javaObjectMimeType(Class<?>) - Static method in class org.springframework.xd.dirt.integration.bus.converter.MessageConverterUtils
-
Build the conventional MimeType
for a java object
- JavaToSerializedMessageConverter - Class in org.springframework.xd.dirt.integration.bus.converter
-
A MessageConverter
to convert from a POJO to byte[] with Java.io serialization if any.
- JavaToSerializedMessageConverter() - Constructor for class org.springframework.xd.dirt.integration.bus.converter.JavaToSerializedMessageConverter
-
- jdbc() - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Construct a new jdbcSink that will write the output to a table .
- JdbcCommands - Class in org.springframework.xd.greenplum.support
-
Utility class helping to execute jdbc operations within a load session.
- JdbcCommands(JdbcTemplate) - Constructor for class org.springframework.xd.greenplum.support.JdbcCommands
-
- JdbcConnectionMixin - Class in org.springframework.xd.jdbc
-
Basic JDBC module/job options.
- JdbcConnectionMixin() - Constructor for class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- JdbcConnectionPoolMixin - Class in org.springframework.xd.jdbc
-
Basic JDBC module/job connection pool options.
- JdbcConnectionPoolMixin() - Constructor for class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- jdbcHdfsJob() - Method in class org.springframework.xd.integration.fixtures.Jobs
-
Create an instance of the JdbcHdfs job with the default hdfs target dir, fileName and source sql statement.
- JdbcHdfsJob - Class in org.springframework.xd.test.fixtures
-
A test fixture that represents the JdbcHdfs Job
- JdbcHdfsJob(String, String, String, String, String) - Constructor for class org.springframework.xd.test.fixtures.JdbcHdfsJob
-
Construct a new jdbchdfs fixture using the provided dir, file and sql.
- JdbcHdfsOptionsMetadata - Class in org.springframework.xd.jdbc
-
Captures options for the jdbchdfs
job.
- JdbcHdfsOptionsMetadata() - Constructor for class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- jdbcInterceptors - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- JdbcMessagePayloadTransformer - Class in org.springframework.xd.jdbc
-
Transforms a payload to a Map representation based on provided column names.
- JdbcMessagePayloadTransformer() - Constructor for class org.springframework.xd.jdbc.JdbcMessagePayloadTransformer
-
- JdbcSink - Class in org.springframework.xd.test.fixtures
-
Represents the jdbc
sink module.
- JdbcSink(DataSource) - Constructor for class org.springframework.xd.test.fixtures.JdbcSink
-
Initializes a JdbcSink with the DataSource
.
- JdbcSinkModuleOptionsMetadata - Class in org.springframework.xd.jdbc
-
Captures module options for the "jdbc" sink module.
- JdbcSinkModuleOptionsMetadata() - Constructor for class org.springframework.xd.jdbc.JdbcSinkModuleOptionsMetadata
-
- JdbcSinkModuleOptionsMetadata.JdbcSinkImportToJdbcMixin - Class in org.springframework.xd.jdbc
-
- JdbcSinkModuleOptionsMetadata.JdbcSinkImportToJdbcMixin() - Constructor for class org.springframework.xd.jdbc.JdbcSinkModuleOptionsMetadata.JdbcSinkImportToJdbcMixin
-
Sets default values that are appropriate for the jdbc sink.
- JdbcSource - Class in org.springframework.xd.test.fixtures
-
Represents the jdbc
source module.
- JdbcSource(DataSource) - Constructor for class org.springframework.xd.test.fixtures.JdbcSource
-
- JdbcSourceModuleOptionsMetadata - Class in org.springframework.xd.jdbc
-
Captures options for the jdbc
source module.
- JdbcSourceModuleOptionsMetadata() - Constructor for class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- jms() - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new JmsSource using the default JMS Broker host and port as specified in the environment
- JmsSource - Class in org.springframework.xd.test.fixtures
-
A test fixture that allows testing of the 'jms' source module.
- JmsSource(String, int) - Constructor for class org.springframework.xd.test.fixtures.JmsSource
-
- JmsSourceModuleOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Captures options for the jms
source module.
- JmsSourceModuleOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- JMXChannelResult - Class in org.springframework.xd.integration.util.jmxresult
-
The Module/Channel that is returned when a JMX Query is exected against XD.
- JMXChannelResult() - Constructor for class org.springframework.xd.integration.util.jmxresult.JMXChannelResult
-
- jmxEnabled - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- JMXRequest - Class in org.springframework.xd.integration.util.jmxresult
-
The request to retrieve the Module MBean.
- JMXRequest() - Constructor for class org.springframework.xd.integration.util.jmxresult.JMXRequest
-
- JMXResult - Class in org.springframework.xd.integration.util.jmxresult
-
The Object that is returned when a JMX Query is exected against XD.
- JMXResult() - Constructor for class org.springframework.xd.integration.util.jmxresult.JMXResult
-
- JMXValue - Class in org.springframework.xd.integration.util.jmxresult
-
The JMXValue returned from JMX Request.
- JMXValue() - Constructor for class org.springframework.xd.integration.util.jmxresult.JMXValue
-
- Job - Class in org.springframework.xd.dirt.core
-
Domain model for Job runtime module.
- JOB - Static variable in class org.springframework.xd.dirt.plugins.job.BatchJobRegistryBeanPostProcessor
-
- Job - Class in org.springframework.xd.dirt.stream
-
- Job(JobDefinition) - Constructor for class org.springframework.xd.dirt.stream.Job
-
- Job.Builder - Class in org.springframework.xd.dirt.core
-
Builder object for
Job
that supports fluent style configuration.
- Job.Builder() - Constructor for class org.springframework.xd.dirt.core.Job.Builder
-
- JOB_CHANNEL_PREFIX - Static variable in class org.springframework.xd.dirt.plugins.AbstractMessageBusBinderPlugin
-
- JOB_CHANNEL_TYPE_PREFIX - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- JOB_DEPLOYMENTS - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of job deployments node.
- JOB_EXECUTION_EVENTS_SUFFIX - Static variable in interface org.springframework.xd.dirt.plugins.job.support.listener.XDJobListenerConstants
-
- JOB_PARAMETERS_KEY - Static variable in class org.springframework.xd.dirt.plugins.job.JobPlugin
-
- JobCommands - Class in org.springframework.xd.shell.command
-
Job commands.
- JobCommands() - Constructor for class org.springframework.xd.shell.command.JobCommands
-
- JobCommandsUtils - Class in org.springframework.xd.shell.command.support
-
Provides helper methods for the
JobCommands
class, e.g.
- JobDefinition - Class in org.springframework.xd.dirt.job.dsl
-
Represents an inlined job definition in a job specification.
- JobDefinition(Token, Token, ArgumentNode[]) - Constructor for class org.springframework.xd.dirt.job.dsl.JobDefinition
-
- JobDefinition - Class in org.springframework.xd.dirt.stream
-
Represents a job in the system.
- JobDefinition(String, String) - Constructor for class org.springframework.xd.dirt.stream.JobDefinition
-
Create a new JobDefinition.
- JobDefinitionRepository - Interface in org.springframework.xd.dirt.stream
-
- jobDefinitionRepository() - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
- JobDefinitionResource - Class in org.springframework.xd.rest.domain
-
Represents a Job Definition.
- JobDefinitionResource(String, String) - Constructor for class org.springframework.xd.rest.domain.JobDefinitionResource
-
- JobDefinitionResource.Page - Class in org.springframework.xd.rest.domain
-
Dedicated subclass to workaround type erasure.
- JobDefinitionResource.Page() - Constructor for class org.springframework.xd.rest.domain.JobDefinitionResource.Page
-
- JobDefinitionResourceAssembler - Class in org.springframework.xd.dirt.rest
-
Knows how to build a REST resource out of our domain model
JobDefinition
.
- JobDefinitionResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.JobDefinitionResourceAssembler
-
- JobDeployer - Class in org.springframework.xd.dirt.stream
-
- JobDeployer(ZooKeeperConnection, JobDefinitionRepository, JobRepository, XDParser, MessageBus, DeploymentHandler) - Constructor for class org.springframework.xd.dirt.stream.JobDeployer
-
- jobDeploymentHandler() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- jobDeployments - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.ContainerMatchingModuleRedeployer
-
Cache of children under the job deployment path.
- JobDeploymentsPath - Class in org.springframework.xd.dirt.core
-
- JobDeploymentsPath() - Constructor for class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Construct a JobDeploymentsPath
.
- JobDeploymentsPath(String) - Constructor for class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Construct a JobDeploymentsPath
.
- JobDescriptor - Class in org.springframework.xd.dirt.job.dsl
-
Common AST base class for nodes representing job definitions or job references.
- JobDescriptor(int, int, ArgumentNode[]) - Constructor for class org.springframework.xd.dirt.job.dsl.JobDescriptor
-
- JobDSLMessage - Enum in org.springframework.xd.dirt.job.dsl
-
Contains all the messages that can be produced during Spring XD Job DSL parsing.
- JobDSLMessage.Kind - Enum in org.springframework.xd.dirt.job.dsl
-
- JobEventsListenerPlugin - Class in org.springframework.xd.dirt.plugins.job
-
Plugin to enable the registration of out of the box job listeners.
- JobEventsListenerPlugin(MessageBus) - Constructor for class org.springframework.xd.dirt.plugins.job.JobEventsListenerPlugin
-
- JobException - Exception in org.springframework.xd.dirt.job
-
Root of the hierarchy of exceptions for Job processing in DIRT.
- JobException(String) - Constructor for exception org.springframework.xd.dirt.job.JobException
-
- JobException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.job.JobException
-
- JobExecutionAlreadyRunningException - Exception in org.springframework.xd.dirt.job
-
Exception that is raised when JobExecution
is already running.
- JobExecutionAlreadyRunningException(String) - Constructor for exception org.springframework.xd.dirt.job.JobExecutionAlreadyRunningException
-
- JobExecutionAlreadyRunningException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.job.JobExecutionAlreadyRunningException
-
- JobExecutionInfo - Class in org.springframework.xd.dirt.job
-
Represents Batch job execution info.
- JobExecutionInfo(JobExecution, TimeZone) - Constructor for class org.springframework.xd.dirt.job.JobExecutionInfo
-
- JobExecutionInfoResource - Class in org.springframework.xd.rest.domain
-
Represents job execution info resource.
- JobExecutionInfoResource() - Constructor for class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- JobExecutionInfoResource(JobExecution, TimeZone) - Constructor for class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
- JobExecutionInfoResource.Page - Class in org.springframework.xd.rest.domain
-
Dedicated subclass to workaround type erasure.
- JobExecutionInfoResource.Page() - Constructor for class org.springframework.xd.rest.domain.JobExecutionInfoResource.Page
-
- jobExecutionInfoResourceAssembler - Variable in class org.springframework.xd.dirt.rest.AbstractBatchJobsController
-
- JobExecutionInfoResourceAssembler - Class in org.springframework.xd.dirt.rest
-
- JobExecutionInfoResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.JobExecutionInfoResourceAssembler
-
- JobExecutionJacksonMixIn - Class in org.springframework.xd.rest.client.impl.support
-
Jackson MixIn for JobExecution
de-serialization.
- JobExecutionNotRunningException - Exception in org.springframework.xd.dirt.job
-
Exception for the job execution that is not running.
- JobExecutionNotRunningException(Long) - Constructor for exception org.springframework.xd.dirt.job.JobExecutionNotRunningException
-
- JobFactory - Class in org.springframework.xd.dirt.job
-
Factory class that builds
Job
instances.
- JobFactory(JobDefinitionRepository, ModuleRegistry, ModuleOptionsMetadataResolver) - Constructor for class org.springframework.xd.dirt.job.JobFactory
-
Construct a JobFactory to create
Job
domain model instances.
- jobFactory - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.DefaultDeploymentStateRecalculator
-
Factory to construct
Job
instance
- jobFactory() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- jobFactory - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer
-
Job factory.
- JobInfo - Class in org.springframework.xd.dirt.job
-
Represents Batch job info.
- JobInfo(String, int, boolean) - Constructor for class org.springframework.xd.dirt.job.JobInfo
-
Construct JobInfo
- JobInfo(String, int, boolean, boolean) - Constructor for class org.springframework.xd.dirt.job.JobInfo
-
Construct JobInfo
- JobInfo(String, int, boolean, boolean, boolean) - Constructor for class org.springframework.xd.dirt.job.JobInfo
-
Construct JobInfo
- JobInfo(String, int, Long, boolean, boolean, boolean) - Constructor for class org.springframework.xd.dirt.job.JobInfo
-
Construct JobInfo
- jobinfo(String) - Method in class org.springframework.xd.dirt.rest.BatchJobsController
-
- JobInfoResource - Class in org.springframework.xd.rest.domain
-
Represents Batch job info.
- JobInfoResource() - Constructor for class org.springframework.xd.rest.domain.JobInfoResource
-
Default constructor for serialization frameworks.
- JobInfoResource(String, int, Long, boolean, boolean, boolean) - Constructor for class org.springframework.xd.rest.domain.JobInfoResource
-
- jobInfoResourceAssembler - Variable in class org.springframework.xd.dirt.rest.AbstractBatchJobsController
-
- JobInfoResourceAssembler - Class in org.springframework.xd.dirt.rest
-
Knows how to build a REST resource out of our domain model
JobInfo
.
- JobInfoResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.JobInfoResourceAssembler
-
- JobInstanceAlreadyCompleteException - Exception in org.springframework.xd.dirt.job
-
Exception thrown when the JobInstance
is already complete.
- JobInstanceAlreadyCompleteException(String) - Constructor for exception org.springframework.xd.dirt.job.JobInstanceAlreadyCompleteException
-
- JobInstanceAlreadyCompleteException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.job.JobInstanceAlreadyCompleteException
-
- JobInstanceInfo - Class in org.springframework.xd.dirt.job
-
Represents Batch job instance info.
- JobInstanceInfo(JobInstance, List<JobExecutionInfo>) - Constructor for class org.springframework.xd.dirt.job.JobInstanceInfo
-
- JobInstanceInfoResource - Class in org.springframework.xd.rest.domain
-
Represents JobInstance info resource.
- JobInstanceInfoResource() - Constructor for class org.springframework.xd.rest.domain.JobInstanceInfoResource
-
Default constructor for serialization frameworks.
- JobInstanceInfoResource(JobInstance, List<JobExecutionInfoResource>) - Constructor for class org.springframework.xd.rest.domain.JobInstanceInfoResource
-
- jobInstanceInfoResourceAssembler - Variable in class org.springframework.xd.dirt.rest.AbstractBatchJobsController
-
- JobInstanceInfoResourceAssembler - Class in org.springframework.xd.dirt.rest
-
- JobInstanceInfoResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.JobInstanceInfoResourceAssembler
-
- JobInstanceJacksonMixIn - Class in org.springframework.xd.rest.client.impl.support
-
Jackson MixIn for JobInstance
de-serialization.
- JobLaunchingJobRepository - Class in org.springframework.xd.dirt.plugins.job.support
-
This JobRepository
implementation
provides the same functionality as Spring Batch's
SimpleJobRepository
however
it does not re-hydrate a ExecutionContext
when
querying for a JobExecution
or a
StepExecution
.
- JobLaunchingJobRepository(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.xd.dirt.plugins.job.support.JobLaunchingJobRepository
-
- JobLaunchingJobRepositoryFactoryBean - Class in org.springframework.xd.dirt.plugins.job.support
-
- JobLaunchingJobRepositoryFactoryBean() - Constructor for class org.springframework.xd.dirt.plugins.job.support.JobLaunchingJobRepositoryFactoryBean
-
- JobLaunchingTasklet - Class in org.springframework.xd.dirt.batch.tasklet
-
A
Tasklet
implementation that uses the Spring XD
MessageBus
to launch
jobs deployed within the same Spring XD cluster.
- JobLaunchingTasklet(MessageBus, JobDefinitionRepository, DomainRepository, String, Long) - Constructor for class org.springframework.xd.dirt.batch.tasklet.JobLaunchingTasklet
-
- JobLaunchingTasklet(MessageBus, JobDefinitionRepository, DomainRepository, String, Long, MessageChannel, PollableChannel) - Constructor for class org.springframework.xd.dirt.batch.tasklet.JobLaunchingTasklet
-
Provided for testing to be able to inject the channels for mocking.
- JobLaunchRequestTransformer - Class in org.springframework.xd.dirt.plugins.job
-
Executes all jobs defined within a given stream once the context has been started.
- JobLaunchRequestTransformer(JobRegistry, String) - Constructor for class org.springframework.xd.dirt.plugins.job.JobLaunchRequestTransformer
-
- JobNode - Class in org.springframework.xd.dirt.job.dsl
-
AST node base type for all elements in an AST parsed from a job specification.
- JobNode(int, int) - Constructor for class org.springframework.xd.dirt.job.dsl.JobNode
-
- jobOperations() - Method in class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- JobOperations - Interface in org.springframework.xd.rest.client
-
Interface defining operations available against jobs.
- jobOperations() - Method in interface org.springframework.xd.rest.client.SpringXDOperations
-
Returns the portion of the API for interaction with Jobs.
- JobParameterJacksonDeserializer - Class in org.springframework.xd.rest.client.impl.support
-
Jackson Deserializer for JobParameter
de-serialization.
- JobParameterJacksonDeserializer() - Constructor for class org.springframework.xd.rest.client.impl.support.JobParameterJacksonDeserializer
-
- JobParameterJacksonMixIn - Class in org.springframework.xd.rest.client.impl.support
-
Jackson MixIn for JobParameter
de-serialization.
- JobParameterJacksonMixIn() - Constructor for class org.springframework.xd.rest.client.impl.support.JobParameterJacksonMixIn
-
- JobParametersBean - Class in org.springframework.xd.dirt.plugins.job
-
Prepares the JobParameters
for the Spring Bach Jobs.
- JobParametersBean(String) - Constructor for class org.springframework.xd.dirt.plugins.job.JobParametersBean
-
- JobParametersInvalidException - Exception in org.springframework.xd.dirt.job
-
Exception thrown when the job parameters are invalid.
- JobParametersInvalidException(String) - Constructor for exception org.springframework.xd.dirt.job.JobParametersInvalidException
-
- JobParametersInvalidException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.job.JobParametersInvalidException
-
- JobParametersJacksonMixIn - Class in org.springframework.xd.rest.client.impl.support
-
Jackson MixIn for JobParameters
de-serialization.
- JobParametersJacksonMixIn() - Constructor for class org.springframework.xd.rest.client.impl.support.JobParametersJacksonMixIn
-
- JobParser - Class in org.springframework.xd.dirt.job.dsl
-
Parse a Batch DSL Job specification.
- JobParser() - Constructor for class org.springframework.xd.dirt.job.dsl.JobParser
-
- JobPartitionerPlugin - Class in org.springframework.xd.dirt.plugins.job
-
Plugin to enable job partitioning.
- JobPartitionerPlugin(MessageBus) - Constructor for class org.springframework.xd.dirt.plugins.job.JobPartitionerPlugin
-
- JobPlugin - Class in org.springframework.xd.dirt.plugins.job
-
Plugin to enable the registration of jobs in a central registry.
- JobPlugin(MessageBus) - Constructor for class org.springframework.xd.dirt.plugins.job.JobPlugin
-
- JobPluginMetadataResolver - Class in org.springframework.xd.dirt.plugins.job
-
- JobPluginMetadataResolver() - Constructor for class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver
-
- JobPluginMetadataResolver.JobOptionsMetadata - Class in org.springframework.xd.dirt.plugins.job
-
- JobPluginMetadataResolver.JobOptionsMetadata() - Constructor for class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- JobReference - Class in org.springframework.xd.dirt.job.dsl
-
Represents a simple job reference.
- JobReference(Token, ArgumentNode[]) - Constructor for class org.springframework.xd.dirt.job.dsl.JobReference
-
- JobRepository - Interface in org.springframework.xd.dirt.stream
-
A repository for persisting
Job
instances.
- jobRepository() - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
- JobRestartException - Exception in org.springframework.xd.dirt.job
-
Exception thrown where the batch job is not restartable.
- JobRestartException(String) - Constructor for exception org.springframework.xd.dirt.job.JobRestartException
-
- JobRestartException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.job.JobRestartException
-
- jobs(Pageable, PagedResourcesAssembler<DetailedJobInfo>) - Method in class org.springframework.xd.dirt.rest.BatchJobsController
-
- JOBS - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of jobs node.
- Jobs - Class in org.springframework.xd.integration.fixtures
-
A factory that provides fully instantiated job fixtures using default values.
- Jobs(XdEnvironment) - Constructor for class org.springframework.xd.integration.fixtures.Jobs
-
Initializes the instance with xdEnvironment
- JobsController - Class in org.springframework.xd.dirt.rest
-
Handles all Job related interactions.
- JobsController(JobDeployer, ModuleDefinitionService) - Constructor for class org.springframework.xd.dirt.rest.JobsController
-
- JobSeries - Class in org.springframework.xd.dirt.job.dsl
-
Common AST base class for nodes representing splits or flows.
- JobSeries(int, int) - Constructor for class org.springframework.xd.dirt.job.dsl.JobSeries
-
- jobService - Variable in class org.springframework.xd.dirt.rest.AbstractBatchJobsController
-
- JobSpecification - Class in org.springframework.xd.dirt.job.dsl
-
The root AST node for any AST parsed from a job specification.
- JobSpecification(String, JobNode, ArgumentNode[]) - Constructor for class org.springframework.xd.dirt.job.dsl.JobSpecification
-
- JobSpecificationException - Exception in org.springframework.xd.dirt.job.dsl
-
Root exception for Job Flow DSL parsing related exceptions.
- JobSpecificationException(String, int, JobDSLMessage, Object...) - Constructor for exception org.springframework.xd.dirt.job.dsl.JobSpecificationException
-
- JobSpecificationVisitor<T> - Class in org.springframework.xd.dirt.job.dsl
-
very basic visitor pattern for a JobSpecVisitor.
- JobSpecificationVisitor() - Constructor for class org.springframework.xd.dirt.job.dsl.JobSpecificationVisitor
-
- jobStateVerifier() - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
- JobTemplate - Class in org.springframework.xd.rest.client.impl
-
Implementation of the Job-related part of the API.
- json(boolean) - Method in class org.springframework.xd.test.fixtures.GemFireServerSink
-
Configure this to use GemFire JSON representation, i.e., create a gemfire-json-server sink.
- JsonBytesToTupleConverter - Class in org.springframework.xd.tuple
-
- JsonBytesToTupleConverter() - Constructor for class org.springframework.xd.tuple.JsonBytesToTupleConverter
-
- JsonNodeToTupleConverter - Class in org.springframework.xd.tuple
-
- JsonNodeToTupleConverter() - Constructor for class org.springframework.xd.tuple.JsonNodeToTupleConverter
-
- JsonStringToObjectTransformer - Class in org.springframework.integration.x.gemfire
-
- JsonStringToObjectTransformer() - Constructor for class org.springframework.integration.x.gemfire.JsonStringToObjectTransformer
-
- JsonStringToTupleConverter - Class in org.springframework.xd.tuple
-
- JsonStringToTupleConverter() - Constructor for class org.springframework.xd.tuple.JsonStringToTupleConverter
-
- JsonToPojoMessageConverter - Class in org.springframework.xd.dirt.integration.bus.converter
-
- JsonToPojoMessageConverter() - Constructor for class org.springframework.xd.dirt.integration.bus.converter.JsonToPojoMessageConverter
-
- JsonToTupleMessageConverter - Class in org.springframework.xd.dirt.integration.bus.converter
-
A
MessageConverter
to convert from a JSON (byte[] or String) to a
Tuple
.
- JsonToTupleMessageConverter() - Constructor for class org.springframework.xd.dirt.integration.bus.converter.JsonToTupleMessageConverter
-
- JsonToTupleTransformer - Class in org.springframework.xd.tuple.integration
-
Converts from a json string into a tuple data structure.
- JsonToTupleTransformer() - Constructor for class org.springframework.xd.tuple.integration.JsonToTupleTransformer
-
- JsonUtil - Class in org.springframework.xd.shell.util
-
Some JSON helper utilities.
- MailProtocol - Enum in org.springframework.xd.mail
-
The list of supported mail protocols.
- MailServerMixin - Class in org.springframework.xd.mail
-
Typical options for configuring connection to a mail server.
- MailServerMixin() - Constructor for class org.springframework.xd.mail.MailServerMixin
-
- MailSink - Class in org.springframework.xd.test.fixtures
-
A fixture to help test the mail
sink module.
- MailSink() - Constructor for class org.springframework.xd.test.fixtures.MailSink
-
- MailSinkOptionsMetadata - Class in org.springframework.xd.mail
-
Captures options for the mail
sink module.
- MailSinkOptionsMetadata() - Constructor for class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- MailSourceOptionsMetadata - Class in org.springframework.xd.mail
-
Captures options for the mail
source module.
- MailSourceOptionsMetadata() - Constructor for class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- main(String[]) - Static method in class org.springframework.xd.batch.hsqldb.server.HsqlServerApplication
-
- main(String[]) - Static method in class org.springframework.xd.dirt.server.admin.AdminServerApplication
-
- main(String[]) - Static method in class org.springframework.xd.dirt.server.container.ContainerServerApplication
-
- main(String[]) - Static method in class org.springframework.xd.dirt.server.singlenode.SingleNodeApplication
-
- main(String[]) - Static method in class org.springframework.xd.dirt.web.StandAloneUiApp
-
- main(String[]) - Static method in class org.springframework.xd.documentation.AsciidocLinkChecker
-
- main(String...) - Static method in class org.springframework.xd.documentation.ModuleOptionsReferenceDoc
-
- main(String[]) - Static method in class org.springframework.xd.gemfire.server.CacheServer
-
- main(String[]) - Static method in class org.springframework.xd.sqoop.SqoopRunner
-
- main(String[]) - Static method in class org.springframework.xd.yarn.AppmasterApplication
-
- main(String...) - Static method in class org.springframework.xd.yarn.ClientApplication
-
- main(String[]) - Static method in class spark.SparkPi
-
- makeInstance(D) - Method in class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
Create an running instance out of the given definition;
- makeInstance(JobDefinition) - Method in class org.springframework.xd.dirt.stream.JobDeployer
-
- makeInstance(StreamDefinition) - Method in class org.springframework.xd.dirt.stream.StreamDeployer
-
Create an running instance out of the given definition;
- makeTempDir() - Static method in class org.springframework.xd.test.fixtures.DisposableFileSupport
-
Utility method to create an empty directory.
- mapFieldSet(FieldSet) - Method in class org.springframework.xd.tuple.batch.TupleFieldSetMapper
-
- mapInput(A, I) - Method in interface org.springframework.xd.analytics.ml.InputMapper
-
Maps the given input
I
into an appropriate model-input
MI
for the given
Analytic
A
.
- mapOutput(A, I, MO) - Method in interface org.springframework.xd.analytics.ml.OutputMapper
-
Maps the model-output MO
to an appropriate output O
.
- MappedAnalytic<I,O,MI,MO,A extends MappedAnalytic<I,O,MI,MO,A>> - Class in org.springframework.xd.analytics.ml
-
An
Analytic
that supports the mapping of
input
and
output
to and from internal representations by applying the given
InputMapper
and
OutputMapper
respectively.
- MappedAnalytic(InputMapper<I, A, MI>, OutputMapper<I, O, A, MO>) - Constructor for class org.springframework.xd.analytics.ml.MappedAnalytic
-
- MappedRequestHeadersMixin - Class in org.springframework.xd.module.options.mixins
-
Base class for mixins that add the mappedRequestHeaders
option.
- MappedRequestHeadersMixin(String) - Constructor for class org.springframework.xd.module.options.mixins.MappedRequestHeadersMixin
-
- MappedRequestHeadersMixin.Amqp - Class in org.springframework.xd.module.options.mixins
-
- MappedRequestHeadersMixin.Amqp() - Constructor for class org.springframework.xd.module.options.mixins.MappedRequestHeadersMixin.Amqp
-
- MappedRequestHeadersMixin.Http - Class in org.springframework.xd.module.options.mixins
-
- MappedRequestHeadersMixin.Http() - Constructor for class org.springframework.xd.module.options.mixins.MappedRequestHeadersMixin.Http
-
- MappedResponseHeadersMixin - Class in org.springframework.xd.module.options.mixins
-
Base class for mixins that add the mappedResponseHeaders
option.
- MappedResponseHeadersMixin(String) - Constructor for class org.springframework.xd.module.options.mixins.MappedResponseHeadersMixin
-
- MappedResponseHeadersMixin.Http - Class in org.springframework.xd.module.options.mixins
-
- MappedResponseHeadersMixin.Http() - Constructor for class org.springframework.xd.module.options.mixins.MappedResponseHeadersMixin.Http
-
- Mapper - Interface in org.springframework.xd.analytics.ml
-
- MapreduceConfigurationMixin - Class in org.springframework.xd.module.options.mixins
-
Factors out common configuration options for Hadoop MapReduce.
- MapreduceConfigurationMixin() - Constructor for class org.springframework.xd.module.options.mixins.MapreduceConfigurationMixin
-
- mapRow(ResultSet, int) - Method in class org.springframework.xd.tuple.batch.TupleRowMapper
-
- mapToBytes(Map<String, String>) - Static method in class org.springframework.xd.dirt.zookeeper.ZooKeeperUtils
-
Convert a map of string key/value pairs to a JSON string in a byte array.
- MapToTupleTransformer - Class in org.springframework.xd.tuple.integration
-
Converts from a Map to the Tuple data structure.
- MapToTupleTransformer() - Constructor for class org.springframework.xd.tuple.integration.MapToTupleTransformer
-
- MASK_CHARACTER - Static variable in class org.springframework.xd.dirt.rest.PasswordUtils
-
- maskPassword(String) - Static method in class org.springframework.xd.shell.util.CommonUtils
-
Simple method to replace characters in a String with asterisks to mask the password.
- maskPasswordsInDefinition(String) - Static method in class org.springframework.xd.dirt.rest.PasswordUtils
-
This method takes a definition String as input parameter.
- maskPropertiesIfNecessary(Properties) - Static method in class org.springframework.xd.dirt.rest.PasswordUtils
-
- maskString(String) - Static method in class org.springframework.xd.dirt.rest.PasswordUtils
-
- match(ModuleDescriptor, ModuleDeploymentProperties, Iterable<Container>) - Method in class org.springframework.xd.dirt.server.admin.deployment.ContainerMatcher
-
Matches the provided module against one of the candidate containers.
- matcher - Variable in class org.springframework.xd.test.fixtures.FileSink.FileSinkContentsMatcher
-
- matches(Object, Description) - Method in class org.springframework.xd.test.fixtures.EventuallyMatcher
-
- matches(Object, Description) - Method in class org.springframework.xd.test.fixtures.FileSink.FileSinkContentsMatcher
-
- matches(Object, Description) - Method in class org.springframework.xd.test.fixtures.FileSink.FileSinkTrimmedContentsMatcher
-
- matches(Object, Description) - Method in class org.springframework.xd.test.fixtures.MetricHasSimpleValueMatcher
-
- MAX_ATTEMPTS - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
The maximum delivery attempts when a delivery fails.
- MAX_CONCURRENCY - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
The maximum number of concurrent deliveries.
- maxActive - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- maxAge - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- maxIdle - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- MaxMessagesDefaultOneMixin - Class in org.springframework.xd.module.options.mixins
-
Mixin for polled sources where the default is 1 message per poll.
- MaxMessagesDefaultOneMixin() - Constructor for class org.springframework.xd.module.options.mixins.MaxMessagesDefaultOneMixin
-
- MaxMessagesDefaultUnlimitedMixin - Class in org.springframework.xd.module.options.mixins
-
Mixin for polled sources where the default is unlimited messages per poll.
- MaxMessagesDefaultUnlimitedMixin() - Constructor for class org.springframework.xd.module.options.mixins.MaxMessagesDefaultUnlimitedMixin
-
- maxWait - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- maybeEat(TokenKind) - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Consume the next token if it matches the desired token kind and return true; otherwise
return false.
- MBeanExportingPlugin - Class in org.springframework.xd.dirt.plugins
-
Exports MBeans from a module using a unique domain name xd.[group].[module].
- MBeanExportingPlugin() - Constructor for class org.springframework.xd.dirt.plugins.MBeanExportingPlugin
-
- mbeanServer() - Method in class org.springframework.xd.dirt.server.ParentConfiguration
-
- MD5StalenessCheck - Class in org.springframework.xd.dirt.module
-
A
StalenessCheck
that expects to find a
.md5
file next to a
module archive and returns true if the computed hashes differ.
- MD5StalenessCheck() - Constructor for class org.springframework.xd.dirt.module.MD5StalenessCheck
-
- MediaTypeConverter - Class in org.springframework.xd.shell.converter
-
Knows how to parse String representations of MediaType
.
- MediaTypeConverter() - Constructor for class org.springframework.xd.shell.converter.MediaTypeConverter
-
- MEDIATYPES_MEDIATYPE_ALL - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- mergeApplicationListeners(ApplicationListener<?>, ApplicationListener<?>[]) - Static method in class org.springframework.xd.dirt.server.ApplicationUtils
-
- message - Variable in exception org.springframework.xd.dirt.job.dsl.JobSpecificationException
-
- message - Variable in exception org.springframework.xd.dirt.stream.dsl.StreamDefinitionException
-
- MESSAGE_BUS_JARS_LOCATION - Static variable in class org.springframework.xd.dirt.server.MessageBusClassLoaderFactory
-
- MessageBus - Interface in org.springframework.xd.dirt.integration.bus
-
A strategy interface used to bind a MessageChannel
to a logical name.
- messageBus - Variable in class org.springframework.xd.dirt.plugins.AbstractMessageBusBinderPlugin
-
- messageBus - Variable in class org.springframework.xd.dirt.test.AbstractSingleNodeNamedChannelModule
-
- messageBus - Variable in class org.springframework.xd.dirt.test.AbstractSingleNodeNamedChannelModuleFactory
-
- messageBus() - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
- MessageBus.Capability - Enum in org.springframework.xd.dirt.integration.bus
-
- MessageBusAwareChannelResolver - Class in org.springframework.xd.dirt.integration.bus
-
A
DestinationResolver
implementation that first checks for any channel
whose name begins with a colon in the
MessageBus
.
- MessageBusAwareChannelResolver(MessageBus, Properties) - Constructor for class org.springframework.xd.dirt.integration.bus.MessageBusAwareChannelResolver
-
- MessageBusAwareRouterBeanPostProcessor - Class in org.springframework.xd.dirt.integration.bus
-
- MessageBusAwareRouterBeanPostProcessor(MessageBus, Properties) - Constructor for class org.springframework.xd.dirt.integration.bus.MessageBusAwareRouterBeanPostProcessor
-
- MessageBusClassLoaderFactory - Class in org.springframework.xd.dirt.server
-
An ApplicationListener which tracks which MessageBus implementation ought to be used so that it exposes a ClassLoader
that knows about the correct jar files for that bus.
- MessageBusClassLoaderFactory() - Constructor for class org.springframework.xd.dirt.server.MessageBusClassLoaderFactory
-
- MessageBusException - Exception in org.springframework.xd.dirt.integration.bus
-
Exception thrown to indicate a message bus error (most
likely a configuration error).
- MessageBusException(String) - Constructor for exception org.springframework.xd.dirt.integration.bus.MessageBusException
-
- MessageBusException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.integration.bus.MessageBusException
-
- MessageBusExtensionsConfiguration - Class in org.springframework.xd.dirt.server
-
Configuration class for Codec and possibly other MessageBus extensions
- MessageBusExtensionsConfiguration() - Constructor for class org.springframework.xd.dirt.server.MessageBusExtensionsConfiguration
-
- MessageBusSupport - Class in org.springframework.xd.dirt.integration.bus
-
- MessageBusSupport() - Constructor for class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- MessageBusSupport.DirectHandler - Class in org.springframework.xd.dirt.integration.bus
-
- MessageBusSupport.DirectHandler(MessageChannel) - Constructor for class org.springframework.xd.dirt.integration.bus.MessageBusSupport.DirectHandler
-
- MessageBusSupport.PartitioningMetadata - Class in org.springframework.xd.dirt.integration.bus
-
- MessageBusSupport.PartitioningMetadata(AbstractBusPropertiesAccessor, int) - Constructor for class org.springframework.xd.dirt.integration.bus.MessageBusSupport.PartitioningMetadata
-
- MessageBusSupport.SetBuilder - Class in org.springframework.xd.dirt.integration.bus
-
- MessageBusSupport.SetBuilder() - Constructor for class org.springframework.xd.dirt.integration.bus.MessageBusSupport.SetBuilder
-
- MessageBusSupport.SharedChannelProvider<T extends org.springframework.messaging.MessageChannel> - Class in org.springframework.xd.dirt.integration.bus
-
Looks up or optionally creates a new channel to use.
- MessageBusSupport.SharedChannelProvider(Class<T>) - Constructor for class org.springframework.xd.dirt.integration.bus.MessageBusSupport.SharedChannelProvider
-
- messageChannel - Variable in class org.springframework.xd.dirt.test.AbstractSingleNodeNamedChannelModule
-
- MessageConverterUtils - Class in org.springframework.xd.dirt.integration.bus.converter
-
Message conversion utility methods.
- MessageConverterUtils() - Constructor for class org.springframework.xd.dirt.integration.bus.converter.MessageConverterUtils
-
- MessageCounterHandler - Class in org.springframework.xd.analytics.metrics.integration
-
- MessageCounterHandler(CounterRepository, String) - Constructor for class org.springframework.xd.analytics.metrics.integration.MessageCounterHandler
-
- MessageExpressionMethods - Class in org.springframework.xd.integration.hadoop.expression
-
Helper class to work with a spel expressions resolving values
from a Message
.
- MessageExpressionMethods(StandardEvaluationContext) - Constructor for class org.springframework.xd.integration.hadoop.expression.MessageExpressionMethods
-
Instantiates a new message expression methods with
a StandardEvaluationContext
.
- MessageExpressionMethods(StandardEvaluationContext, boolean, boolean) - Constructor for class org.springframework.xd.integration.hadoop.expression.MessageExpressionMethods
-
Instantiates a new message expression methods with
a StandardEvaluationContext
.
- MessageExpressionMethods.MessageWrappedMessage - Class in org.springframework.xd.integration.hadoop.expression
-
- MessageExpressionMethods.MessageWrappedMessage(Message<?>) - Constructor for class org.springframework.xd.integration.hadoop.expression.MessageExpressionMethods.MessageWrappedMessage
-
- MessagePartitionKeyMethodResolver - Class in org.springframework.xd.integration.hadoop.expression
-
A Message
specific MethodResolver
.
- MessagePartitionKeyMethodResolver() - Constructor for class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyMethodResolver
-
- MessagePartitionKeyPropertyAccessor - Class in org.springframework.xd.integration.hadoop.expression
-
A PropertyAccessor
reading values from a backing Message
used by a
partition key.
- MessagePartitionKeyPropertyAccessor() - Constructor for class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor
-
- MessagePartitionKeyPropertyAccessor.MessageOptimalPropertyAccessor - Class in org.springframework.xd.integration.hadoop.expression
-
- MessagePartitionKeyPropertyAccessor.MessageOptimalPropertyAccessor(String) - Constructor for class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor.MessageOptimalPropertyAccessor
-
- MessagePartitionStrategy<T> - Class in org.springframework.xd.integration.hadoop.partition
-
A PartitionStrategy
which is used to provide a generic partitioning support using Spring SpEL.
- MessagePartitionStrategy(Expression, StandardEvaluationContext) - Constructor for class org.springframework.xd.integration.hadoop.partition.MessagePartitionStrategy
-
Instantiates a new message partition strategy with
EvaluationContext
.
- MessagePartitionStrategy(String, StandardEvaluationContext) - Constructor for class org.springframework.xd.integration.hadoop.partition.MessagePartitionStrategy
-
Instantiates a new message partition strategy with
EvaluationContext
.
- MessagePartitionStrategy(String, StandardEvaluationContext, ExpressionParser) - Constructor for class org.springframework.xd.integration.hadoop.partition.MessagePartitionStrategy
-
Instantiates a new message partition strategy with
EvaluationContext
.
- MessageValues - Class in org.springframework.xd.dirt.integration.bus
-
A mutable type for allowing
MessageBus
implementations to transform and enrich message content more
efficiently.
- MessageValues(Message<?>) - Constructor for class org.springframework.xd.dirt.integration.bus.MessageValues
-
Create an instance from a Message
.
- MessageValues(Object, Map<String, Object>) - Constructor for class org.springframework.xd.dirt.integration.bus.MessageValues
-
- metadata - Variable in class org.springframework.xd.dirt.job.dsl.Node
-
- METADATA - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of metadata node.
- METADATA_VERIFICATION_MAX_INTERVAL - Static variable in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- METADATA_VERIFICATION_RETRY_ATTEMPTS - Static variable in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- METADATA_VERIFICATION_RETRY_BACKOFF_MULTIPLIER - Static variable in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- METADATA_VERIFICATION_RETRY_INITIAL_INTERVAL - Static variable in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- METADATAKEY_JOBMODULENAME - Static variable in class org.springframework.xd.dirt.job.dsl.Node
-
- Metric - Interface in org.springframework.xd.analytics.metrics.core
-
Super interface for all metrics.
- MetricHasSimpleValueMatcher<U,T extends AbstractMetricSink & HasDisplayValue<U>> - Class in org.springframework.xd.test.fixtures
-
A matcher that will assert that the <metric type> display xxx
shell command displays the expected value.
- MetricHasSimpleValueMatcher(U) - Constructor for class org.springframework.xd.test.fixtures.MetricHasSimpleValueMatcher
-
- MetricNameMixin - Class in org.springframework.xd.analytics.metrics.metadata
-
Adds a name
option, intended to capture the name of the metric.
- MetricNameMixin() - Constructor for class org.springframework.xd.analytics.metrics.metadata.MetricNameMixin
-
- MetricRepository<M extends Metric> - Interface in org.springframework.xd.analytics.metrics.core
-
A repository to save, delete and find Metric instances.
- MetricResource - Class in org.springframework.xd.rest.domain.metrics
-
Base class for resources that adhere to the Metric interface.
- MetricResource(String) - Constructor for class org.springframework.xd.rest.domain.metrics.MetricResource
-
Construct a new resource.
- MetricResource() - Constructor for class org.springframework.xd.rest.domain.metrics.MetricResource
-
No arg constructor for serialization frameworks.
- MetricResource.Page - Class in org.springframework.xd.rest.domain.metrics
-
Dedicated subclass to workaround type erasure.
- MetricResource.Page() - Constructor for class org.springframework.xd.rest.domain.metrics.MetricResource.Page
-
- MetricUtils - Class in org.springframework.xd.analytics.metrics.core
-
Utility class, primarily to avoid exposing mutable objects beyond the core package.
- MetricUtils() - Constructor for class org.springframework.xd.analytics.metrics.core.MetricUtils
-
- MGMT_PORT_KEY - Static variable in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- MGMT_PORT_KEY - Static variable in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- MIN_PARTITION_COUNT - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
Minimum partition count, if the transport supports partitioning natively (e.g.
- minEvictableIdleTimeMillis - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- minIdle - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- minus(DateTime, int) - Method in enum org.springframework.xd.analytics.metrics.core.AggregateCountResolution
-
Subtracts this resolution a given number of times from a supplied date.
- Mixin - Annotation Type in org.springframework.xd.module.options.spi
-
Instructs the runtime to mix in other POJO bases module option metadata classes into the one that is annotated with
this annotation.
- mkdir(String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- mkdirs() - Method in class org.springframework.xd.dirt.module.ExtendedResource.FileSystemExtendedResource
-
- mkdirs() - Method in class org.springframework.xd.dirt.module.ExtendedResource.HdfsExtendedResource
-
- mkdirs() - Method in class org.springframework.xd.dirt.module.ExtendedResource
-
Makes sure that the resource and all its parent "directories" exist, creating them if necessary.
- MOCK_AC - Static variable in class org.springframework.xd.dirt.integration.bus.BusTestUtils
-
- MOCK_BF - Static variable in class org.springframework.xd.dirt.integration.bus.BusTestUtils
-
- Mode - Enum in org.springframework.xd.greenplum.support
-
- mode(String) - Method in class org.springframework.xd.test.fixtures.SimpleFileSink
-
Establishes the mode in which the SimpleFileSink.
- mode(SimpleFileSource.Mode) - Method in class org.springframework.xd.test.fixtures.SimpleFileSource
-
Determines if the file object or the content of the file should be sent to the output channel.
- Module - Class in org.springframework.xd.integration.util.jmxresult
-
Represents an XD Module that is returned from a JMX Query.
- Module() - Constructor for class org.springframework.xd.integration.util.jmxresult.Module
-
- Module - Interface in org.springframework.xd.module.core
-
- MODULE_DEPLOYMENTS - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of module deployments node.
- MODULE_EXECUTION_FRAMEWORK - Static variable in interface org.springframework.xd.spark.streaming.SparkStreamingSupport
-
The module execution framework is used by XD runtime to determine the module as
the spark streaming module.
- MODULE_EXECUTION_FRAMEWORK_KEY - Static variable in class org.springframework.xd.module.core.ModuleFactory
-
This key is used by the module to define the execution framework(spark streaming, reactor etc.,) to be used when
deploying it.
- MODULE_INPUT_CHANNEL - Static variable in class org.springframework.xd.dirt.plugins.AbstractMessageBusBinderPlugin
-
- MODULE_OUTPUT_CHANNEL - Static variable in class org.springframework.xd.dirt.plugins.AbstractMessageBusBinderPlugin
-
- MODULE_SUFFIX - Static variable in class org.springframework.xd.dirt.job.dsl.ComposedJobUtil
-
- ModuleAlreadyExistsException - Exception in org.springframework.xd.dirt.module
-
Thrown when trying to create a new module with the given name and type, but one already exists.
- ModuleAlreadyExistsException(String, String, ModuleType) - Constructor for exception org.springframework.xd.dirt.module.ModuleAlreadyExistsException
-
Construct a new exception with the given parameters.
- ModuleAlreadyExistsException(String, ModuleType) - Constructor for exception org.springframework.xd.dirt.module.ModuleAlreadyExistsException
-
- ModuleCommands - Class in org.springframework.xd.shell.command
-
Commands for working with modules.
- ModuleCommands() - Constructor for class org.springframework.xd.shell.command.ModuleCommands
-
- ModuleCommands.QualifiedModuleName - Class in org.springframework.xd.shell.command
-
- ModuleCommands.QualifiedModuleName(String, RESTModuleType) - Constructor for class org.springframework.xd.shell.command.ModuleCommands.QualifiedModuleName
-
- ModuleConfigurationException - Exception in org.springframework.xd.dirt.plugins
-
Thrown when something is wrong with options passed to a module.
- ModuleConfigurationException(String) - Constructor for exception org.springframework.xd.dirt.plugins.ModuleConfigurationException
-
- ModuleConfigurationException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.plugins.ModuleConfigurationException
-
- ModuleDefinition - Class in org.springframework.xd.module
-
An instance of ModuleDefinition reflects the fact that a given module (identified by its type and name) is
'available', i.e. that it can be used in a job or stream definition.
- ModuleDefinition() - Constructor for class org.springframework.xd.module.ModuleDefinition
-
- ModuleDefinition(String, ModuleType) - Constructor for class org.springframework.xd.module.ModuleDefinition
-
- ModuleDefinitionRepositoryUtils - Class in org.springframework.xd.dirt.module.support
-
Encapsulate shared functionality between implementations of ModuleDefinitionRepository that can't be done using
inheritance
- ModuleDefinitionRepositoryUtils() - Constructor for class org.springframework.xd.dirt.module.support.ModuleDefinitionRepositoryUtils
-
- ModuleDefinitionResource - Class in org.springframework.xd.rest.domain
-
Represents a Module Definition.
- ModuleDefinitionResource() - Constructor for class org.springframework.xd.rest.domain.ModuleDefinitionResource
-
Default constructor for serialization frameworks.
- ModuleDefinitionResource(String, String, boolean) - Constructor for class org.springframework.xd.rest.domain.ModuleDefinitionResource
-
- ModuleDefinitionResource.Page - Class in org.springframework.xd.rest.domain
-
Dedicated subclass to workaround type erasure.
- ModuleDefinitionResource.Page() - Constructor for class org.springframework.xd.rest.domain.ModuleDefinitionResource.Page
-
- ModuleDefinitionResourceAssembler - Class in org.springframework.xd.dirt.rest
-
- ModuleDefinitionResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.ModuleDefinitionResourceAssembler
-
- ModuleDefinitions - Class in org.springframework.xd.module
-
Factory class to create ModuleDefinition
s.
- ModuleDefinitionService - Class in org.springframework.xd.dirt.module.support
-
A service that knows how to handle registration of new module definitions, be it through composition or
upload of actual 'bytecode'.
- ModuleDefinitionService(WritableModuleRegistry, XDStreamParser, ModuleDependencyRepository) - Constructor for class org.springframework.xd.dirt.module.support.ModuleDefinitionService
-
- ModuleDependencyRepository - Interface in org.springframework.xd.dirt.module
-
Used to track usage of modules from streams and composed modules.
- ModuleDeployedEvent - Class in org.springframework.xd.dirt.event
-
- ModuleDeployedEvent(Module, String) - Constructor for class org.springframework.xd.dirt.event.ModuleDeployedEvent
-
- ModuleDeployer - Class in org.springframework.xd.dirt.module
-
Handles the creation, deployment, and un-deployment of
modules
.
- ModuleDeployer(ModuleFactory) - Constructor for class org.springframework.xd.dirt.module.ModuleDeployer
-
Construct a ModuleDeployer.
- moduleDeployer() - Method in class org.springframework.xd.dirt.server.container.ContainerConfiguration
-
- ModuleDeploymentProperties - Class in org.springframework.xd.module
-
Deployment properties for a module.
- ModuleDeploymentProperties() - Constructor for class org.springframework.xd.module.ModuleDeploymentProperties
-
Create a map to hold module deployment properties.
- ModuleDeploymentPropertiesProvider<P extends ModuleDeploymentProperties> - Interface in org.springframework.xd.dirt.server.admin.deployment
-
- moduleDeploymentRequests - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer
-
Cache of children under the module deployment requests path.
- moduleDeploymentRequests - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.ZKDeploymentHandler
-
Cache of children under the module deployment requests path.
- ModuleDeploymentRequestsPath - Class in org.springframework.xd.dirt.core
-
- ModuleDeploymentRequestsPath() - Constructor for class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Construct a ModuleDeploymentRequestsPath
.
- ModuleDeploymentRequestsPath(String) - Constructor for class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Construct a ModuleDeploymentRequestsPath
.
- ModuleDeploymentsPath - Class in org.springframework.xd.dirt.core
-
- ModuleDeploymentsPath() - Constructor for class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Construct a DeploymentsPath
.
- ModuleDeploymentsPath(String) - Constructor for class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Construct a DeploymentsPath
.
- ModuleDeploymentStatus - Class in org.springframework.xd.dirt.server.admin.deployment
-
Status of a module deployment for a container.
- ModuleDeploymentStatus(String, int, ModuleDescriptor.Key, ModuleDeploymentStatus.State, String) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus
-
Construct a ModuleDeploymentStatus
.
- ModuleDeploymentStatus(String, int, ModuleDescriptor.Key, Map<String, String>) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus
-
Construct a ModuleDeploymentStatus
.
- ModuleDeploymentStatus.State - Enum in org.springframework.xd.dirt.server.admin.deployment
-
Module deployment states.
- moduleDeploymentWriter() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- ModuleDeploymentWriter - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
Utility class to write module deployment requests under /xd/deployments/modules
.
- ModuleDeploymentWriter() - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleDeploymentWriter
-
- moduleDescriptor - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer.ModuleDeployment
-
- ModuleDescriptor - Class in org.springframework.xd.module
-
Representation of a module in the context of a defined stream or job.
- ModuleDescriptor.Builder - Class in org.springframework.xd.module
-
- ModuleDescriptor.Builder() - Constructor for class org.springframework.xd.module.ModuleDescriptor.Builder
-
- ModuleDescriptor.Key - Class in org.springframework.xd.module
-
Key to be used in Map of ModuleDescriptors.
- ModuleDescriptor.Key(String, ModuleType, String) - Constructor for class org.springframework.xd.module.ModuleDescriptor.Key
-
Construct a key.
- ModuleEnvironment - Class in org.springframework.xd.module.core
-
A dedicated Environment
for a module, which restricts the values exposed to the
PropertySourcesPlaceholderConfigurer
living in the module context.
- ModuleEnvironment(EnumerablePropertySource<?>, ConfigurableEnvironment) - Constructor for class org.springframework.xd.module.core.ModuleEnvironment
-
- ModuleException - Exception in org.springframework.xd.dirt.module
-
Root of the hierarchy of exceptions for Module processing in DIRT.
- ModuleException(String) - Constructor for exception org.springframework.xd.dirt.module.ModuleException
-
- ModuleException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.module.ModuleException
-
- ModuleExecutor - Class in org.springframework.xd.spark.streaming.java
-
Invokes the process method of a
Processor
and handles the output DStream if present.
- ModuleExecutor() - Constructor for class org.springframework.xd.spark.streaming.java.ModuleExecutor
-
- moduleFactory() - Method in class org.springframework.xd.dirt.server.container.ContainerConfiguration
-
- ModuleFactory - Class in org.springframework.xd.module.core
-
Determines the type of
Module
to create from the Module's metadata and creates a module instance.
- ModuleFactory(ModuleOptionsMetadataResolver) - Constructor for class org.springframework.xd.module.core.ModuleFactory
-
- ModuleFixture - Class in org.springframework.xd.integration.fixtures
-
Establishes the base behavior for Acceptance Test Module Factories.
- ModuleFixture() - Constructor for class org.springframework.xd.integration.fixtures.ModuleFixture
-
- moduleInfo(ModuleCommands.QualifiedModuleName, boolean) - Method in class org.springframework.xd.shell.command.ModuleCommands
-
- ModuleInfoPlugin - Class in org.springframework.xd.dirt.plugins
-
A plugin that exposes information such as the module name, index, sequence or count to be available inside the
environment.
- ModuleInfoPlugin() - Constructor for class org.springframework.xd.dirt.plugins.ModuleInfoPlugin
-
- ModuleInformation - Class in org.springframework.xd.module.info
-
Holder object for various bits of information about a module, such as description, etc.
- ModuleInformation() - Constructor for class org.springframework.xd.module.info.ModuleInformation
-
- ModuleInformationResolver - Interface in org.springframework.xd.module.info
-
- ModuleJobLauncher - Class in org.springframework.xd.dirt.plugins.job
-
Executes all jobs defined within a given stream once the context has been started.
- ModuleJobLauncher(JobLauncher, JobRegistry, boolean, JobParametersBean) - Constructor for class org.springframework.xd.dirt.plugins.job.ModuleJobLauncher
-
- ModuleMessageRateNotFoundException - Exception in org.springframework.xd.dirt.cluster
-
Exception thrown when getting message rate for
deployed modules.
- ModuleMessageRateNotFoundException() - Constructor for exception org.springframework.xd.dirt.cluster.ModuleMessageRateNotFoundException
-
Construct a ModuleMessageRateNotFoundException
.
- ModuleMessageRateNotFoundException(String) - Constructor for exception org.springframework.xd.dirt.cluster.ModuleMessageRateNotFoundException
-
Construct a ModuleMessageRateNotFoundException
with a description.
- ModuleMetadata - Class in org.springframework.xd.dirt.module.store
-
Metadata class for modules at runtime.
- ModuleMetadata(ModuleMetadata.Id, Properties, Properties, DeploymentUnitStatus.State) - Constructor for class org.springframework.xd.dirt.module.store.ModuleMetadata
-
Construct a ModuleMetadata instance.
- ModuleMetadata.Id - Class in org.springframework.xd.dirt.module.store
-
- ModuleMetadata.Id(String, String, ModuleType, String, int) - Constructor for class org.springframework.xd.dirt.module.store.ModuleMetadata.Id
-
- ModuleMetadata.Id(String, String) - Constructor for class org.springframework.xd.dirt.module.store.ModuleMetadata.Id
-
- ModuleMetadataRepository - Interface in org.springframework.xd.dirt.module.store
-
- ModuleMetadataResource - Class in org.springframework.xd.rest.domain
-
Represents a runtime module.
- ModuleMetadataResource(String, String, String, RESTModuleType, String, Properties, Properties, RESTDeploymentState) - Constructor for class org.springframework.xd.rest.domain.ModuleMetadataResource
-
- ModuleMetadataResource.Page - Class in org.springframework.xd.rest.domain
-
Dedicated subclass to workaround type erasure.
- ModuleMetadataResource.Page() - Constructor for class org.springframework.xd.rest.domain.ModuleMetadataResource.Page
-
- ModuleMetadataResourceAssembler - Class in org.springframework.xd.dirt.rest
-
- ModuleMetadataResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.ModuleMetadataResourceAssembler
-
- moduleName(String) - Method in class org.springframework.xd.test.fixtures.Transform
-
Sets the groovy script the user wants to transform the input.
- ModuleNode - Class in org.springframework.xd.dirt.stream.dsl
-
- ModuleNode(LabelNode, String, int, int, ArgumentNode[]) - Constructor for class org.springframework.xd.dirt.stream.dsl.ModuleNode
-
- ModuleNotDeployedException - Exception in org.springframework.xd.dirt.module
-
Exception thrown when a module doesn't exist in the container.
- ModuleNotDeployedException(String, String) - Constructor for exception org.springframework.xd.dirt.module.ModuleNotDeployedException
-
- ModuleObjectNamingStrategy - Class in org.springframework.xd.dirt.module.jmx
-
Object naming strategy for XD module.
- ModuleObjectNamingStrategy(String, Properties) - Constructor for class org.springframework.xd.dirt.module.jmx.ModuleObjectNamingStrategy
-
- moduleOperations() - Method in class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- ModuleOperations - Interface in org.springframework.xd.rest.client
-
Interface defining operations available against Module.
- moduleOperations() - Method in interface org.springframework.xd.rest.client.SpringXDOperations
-
Returns the portion of the API for interaction with Modules' definitions.
- ModuleOption - Class in org.springframework.xd.module.options
-
Provides information about an option that a user can set to customize the behavior of a module.
- ModuleOption(String, String) - Constructor for class org.springframework.xd.module.options.ModuleOption
-
- ModuleOption - Annotation Type in org.springframework.xd.module.options.spi
-
Used to annotate the setter methods of a POJO Module Options class to provide the framework with additional option
information.
- ModuleOptions - Class in org.springframework.xd.module.options
-
Represents runtime information about a module once user provided values are known.
- ModuleOptions() - Constructor for class org.springframework.xd.module.options.ModuleOptions
-
- ModuleOptionsMetadata - Interface in org.springframework.xd.module.options
-
Encapsulates metadata about the accepted options for a module.
- ModuleOptionsMetadataResolver - Interface in org.springframework.xd.module.options
-
- ModuleOptionsReferenceDoc - Class in org.springframework.xd.documentation
-
A class that generates asciidoc snippets for each module's options.
- ModuleOptionsReferenceDoc() - Constructor for class org.springframework.xd.documentation.ModuleOptionsReferenceDoc
-
- ModulePlaceholders - Class in org.springframework.xd.module.options.spi
-
Defines constants for well known XD keys that are available at runtime for a module.
- ModulePlaceholders() - Constructor for class org.springframework.xd.module.options.spi.ModulePlaceholders
-
- modulePropertiesFile(SimpleModuleDefinition) - Static method in class org.springframework.xd.module.options.ModuleUtils
-
Return a resource that can be used to load the module '.properties' file (containing e.g. information
about module options, or null if no such file exists.
- ModuleRedeployer - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
Abstract ModuleRedeployer that deploy/re-deploys the unallocated/orphaned modules.
- ModuleRedeployer(ZooKeeperConnection, ContainerRepository, StreamFactory, JobFactory, PathChildrenCache, ContainerMatcher, ModuleDeploymentWriter, DeploymentUnitStateCalculator) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer
-
Constructs ModuleRedeployer
- ModuleRedeployer.ModuleDeployment - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
Holds information about a module that needs to be re-deployed.
- ModuleRegistry - Interface in org.springframework.xd.dirt.module
-
A module registry is used to lookup modules by name and/or type.
- MODULES - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of modules node.
- ModulesAfterPipeRecoveryStrategy - Class in org.springframework.xd.dirt.stream.completion
-
Provides completions for the case where the user has entered a pipe symbol and a module reference is expected next.
- ModulesAfterPipeRecoveryStrategy(XDParser, ModuleRegistry) - Constructor for class org.springframework.xd.dirt.stream.completion.ModulesAfterPipeRecoveryStrategy
-
Construct a new ExpandOneDashToTwoDashesRecoveryStrategy given the parser.
- ModulesController - Class in org.springframework.xd.dirt.rest
-
Handles all Module related interactions.
- ModulesController(ModuleDefinitionService, DetailedModuleDefinitionResourceAssembler) - Constructor for class org.springframework.xd.dirt.rest.ModulesController
-
- ModulesMetadataController - Class in org.springframework.xd.dirt.rest
-
Controller that handles the interaction with the deployed modules.
- ModulesMetadataController(ModuleMetadataRepository) - Constructor for class org.springframework.xd.dirt.rest.ModulesMetadataController
-
- ModuleTemplate - Class in org.springframework.xd.rest.client.impl
-
Implementation of the Module-related part of the API.
- ModuleType - Enum in org.springframework.xd.integration.fixtures
-
Enumeration of different module types
- ModuleType - Enum in org.springframework.xd.module
-
Represents the kind of modules that make up a stream or job.
- ModuleTypeConversionPlugin - Class in org.springframework.xd.dirt.plugins.stream
-
A
Plugin
for processing module message conversion parameters (inputType and outputType).
- ModuleTypeConversionPlugin(Collection<AbstractFromMessageConverter>, Collection<AbstractFromMessageConverter>) - Constructor for class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionPlugin
-
- ModuleTypeConversionPluginMetadataResolver - Class in org.springframework.xd.dirt.plugins.stream
-
- ModuleTypeConversionPluginMetadataResolver() - Constructor for class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionPluginMetadataResolver
-
- ModuleTypeConversionSupport - Class in org.springframework.xd.dirt.plugins.stream
-
Support class that configures the message converters for the module input/output channel.
- ModuleTypeConversionSupport(CompositeMessageConverterFactory) - Constructor for class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionSupport
-
- ModuleUndeployedEvent - Class in org.springframework.xd.dirt.event
-
- ModuleUndeployedEvent(Module, String) - Constructor for class org.springframework.xd.dirt.event.ModuleUndeployedEvent
-
- ModuleUtils - Class in org.springframework.xd.module.options
-
Contains utility methods for accessing a module's properties and dealing with ClassLoaders.
- ModuleUtils() - Constructor for class org.springframework.xd.module.options.ModuleUtils
-
- MongoDbConnectionMixin - Class in org.springframework.xd.module.options.mixins
-
A mixin to add anytime a connection to MongoDB is required.
- MongoDbConnectionMixin() - Constructor for class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- moveFromLocal(String, String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- mqtt() - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Construct a new Mqttsink using the default RabbitMQ (MQTT-enbaled) broker host as specified in the environment.
- mqtt() - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new MqttSource using the default RabbitMQ (MQTT-enbaled) broker host as specified in the
environment.
- MqttConnectionMixin - Class in org.springframework.xd.dirt.modules.metadata
-
Factors out common options about configuring a connection to an MQTT broker.
- MqttConnectionMixin() - Constructor for class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- MqttSink - Class in org.springframework.xd.test.fixtures
-
Test fixture that creates a mqtt sink.
- MqttSink(String, int) - Constructor for class org.springframework.xd.test.fixtures.MqttSink
-
- MqttSinkOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Describes options to the mqtt
sink module.
- MqttSinkOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- MqttSource - Class in org.springframework.xd.test.fixtures
-
A test fixture that allows testing of the mqtt source module.
- MqttSource(String) - Constructor for class org.springframework.xd.test.fixtures.MqttSource
-
- MqttSource(String, int) - Constructor for class org.springframework.xd.test.fixtures.MqttSource
-
- MqttSourceOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Describes options to the mqtt
source module.
- MqttSourceOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- MqttTestSupport - Class in org.springframework.xd.test.mqtt
-
- MqttTestSupport() - Constructor for class org.springframework.xd.test.mqtt.MqttTestSupport
-
- MultipleBroadcasterMessageHandler - Class in org.springframework.xd.reactor
-
Adapts the item at a time delivery of a MessageHandler
by delegating processing to a Stream based on a partitionExpression.
- MultipleBroadcasterMessageHandler(Processor, String) - Constructor for class org.springframework.xd.reactor.MultipleBroadcasterMessageHandler
-
Construct a new MessageHandler given the reactor based Processor to delegate
processing to and a partition expression.
- MultipleSubjectMessageHandler - Class in org.springframework.xd.rxjava
-
Adapts the item at a time delivery of a MessageHandler
by delegating processing to an Observable based on a partitionExpression.
- MultipleSubjectMessageHandler(Processor, String) - Constructor for class org.springframework.xd.rxjava.MultipleSubjectMessageHandler
-
- mv(String, String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- obtainResource() - Method in class org.springframework.xd.test.AbstractExternalResourceTestSupport
-
Try to obtain and validate a resource.
- obtainResource() - Method in class org.springframework.xd.test.kafka.KafkaTestSupport
-
- obtainResource() - Method in class org.springframework.xd.test.mqtt.MqttTestSupport
-
- obtainResource() - Method in class org.springframework.xd.test.rabbit.RabbitAdminTestSupport
-
- obtainResource() - Method in class org.springframework.xd.test.rabbit.RabbitTestSupport
-
- obtainResource() - Method in class org.springframework.xd.test.redis.RedisTestSupport
-
- of(int, int) - Static method in enum org.springframework.xd.dirt.stream.ParsingContext.Position
-
Return the position instance for a module appearing at index
inside a stream made of [0..lastIndex]
(inclusive).
- of(String, Object) - Method in class org.springframework.xd.tuple.TupleBuilder
-
- of(String, Object, String, Object) - Method in class org.springframework.xd.tuple.TupleBuilder
-
- of(String, Object, String, Object, String, Object) - Method in class org.springframework.xd.tuple.TupleBuilder
-
- of(String, Object, String, Object, String, Object, String, Object) - Method in class org.springframework.xd.tuple.TupleBuilder
-
- ofNamesAndValues(List<String>, List<Object>) - Method in class org.springframework.xd.tuple.TupleBuilder
-
- onAlreadyDeployedException(AlreadyDeployedException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
Handles the case where client tried to deploy something that is already deployed.
- onApplicationEvent(ApplicationPreparedEvent) - Method in class org.springframework.xd.dirt.container.initializer.AbstractComponentScanningBeanDefinitionProvider
-
- onApplicationEvent(ApplicationPreparedEvent) - Method in class org.springframework.xd.dirt.container.initializer.AbstractResourceBeanDefinitionProvider
-
- onApplicationEvent(ApplicationEvent) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- onApplicationEvent(ApplicationEvent) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentSupervisor
- onApplicationEvent(ApplicationEvent) - Method in class org.springframework.xd.dirt.server.container.ContainerRegistrar
- onApplicationEvent(ApplicationEnvironmentPreparedEvent) - Method in class org.springframework.xd.dirt.server.MessageBusClassLoaderFactory
-
- onApplicationEvent(ApplicationEnvironmentPreparedEvent) - Method in class org.springframework.xd.dirt.server.options.CommandLinePropertySourceOverridingListener
-
- onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.xd.dirt.util.XdConfigLoggingInitializer
-
Logger config info upon admin or container server context refresh.
- onApplicationEvent(ConfigurationModifiedEvent) - Method in class org.springframework.xd.shell.hadoop.ConfigurationAware
-
- onBadCredentialsException(BadCredentialsException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onBatchJobAlreadyExists(BatchJobAlreadyExistsException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onComplete() - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler.ChannelForwardingSubscriber
-
- onConnect(CuratorFramework) - Method in class org.springframework.xd.dirt.stream.zookeeper.RepositoryConnectionListener
-
Called when the Curator ConnectionStateListener
receives a
ConnectionState.CONNECTED
event.
- onConnect(CuratorFramework) - Method in interface org.springframework.xd.dirt.zookeeper.ZooKeeperConnectionListener
-
Called when the Curator ConnectionStateListener
receives a
ConnectionState.CONNECTED
event.
- onContainerLaunchCommands(Container, ContainerCluster, List<String>) - Method in class org.springframework.xd.yarn.XdAppmaster
-
- onContainerShutdownException(ContainerShutdownException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onDefinitionAlreadyExistsException(DefinitionAlreadyExistsException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
Handles the case where client referenced an entity that already exists.
- onDisconnect(CuratorFramework) - Method in class org.springframework.xd.dirt.stream.zookeeper.RepositoryConnectionListener
-
Called when the Curator ConnectionStateListener
receives a
ConnectionState.LOST
event.
- onDisconnect(CuratorFramework) - Method in interface org.springframework.xd.dirt.zookeeper.ZooKeeperConnectionListener
-
Called when the Curator ConnectionStateListener
receives a
ConnectionState.LOST
event.
- onError(Throwable) - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler.ChannelForwardingSubscriber
-
- onException(Exception) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
Handles the general error case.
- onInit() - Method in class org.springframework.integration.x.http.NettyHttpInboundChannelAdapter
-
- onInit() - Method in class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter
-
- onInit() - Method in class org.springframework.xd.dirt.integration.bus.local.LocalMessageBus
-
- onInit() - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- onInit() - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- onInit() - Method in class org.springframework.xd.dirt.integration.redis.RedisMessageBus
-
- onInit() - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistMessageHandler
-
- onInit() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsDataStoreMessageHandler
-
- onInit() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsPartitionDataStoreMessageHandler
-
- onInit() - Method in class org.springframework.xd.reactor.BroadcasterMessageHandler
-
- onInit() - Method in class org.springframework.xd.reactor.MultipleBroadcasterMessageHandler
-
- onInit() - Method in class org.springframework.xd.rxjava.MultipleSubjectMessageHandler
-
- onInvalidDefinition(StreamDefinitionException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
Handles the case where client tried to deploy something that is has an invalid definition.
- onJobExecutionAlreadyRunningException(JobExecutionAlreadyRunningException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onJobExecutionNotRunningException(JobExecutionNotRunningException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onJobInstanceAlreadyCompleteException(JobInstanceAlreadyCompleteException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onJobParametersInvalidException(JobParametersInvalidException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onJobRestartException(JobRestartException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onLogoutSuccess(HttpServletRequest, HttpServletResponse, Authentication) - Method in class org.springframework.xd.dirt.web.controller.support.RestLogoutSuccessHandler
-
- onMissingServletRequestParameterException(MissingServletRequestParameterException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
Handles the case where client submitted an ill valued request (missing parameter).
- onModuleAlreadyExistsException(ModuleAlreadyExistsException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onModuleMessageRateNotFoundException(ModuleMessageRateNotFoundException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onModuleNotDeployedException(ModuleNotDeployedException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onNext(Object) - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler.ChannelForwardingSubscriber
-
- onNoSuchContainerException(NoSuchContainerException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onNoSuchDefinitionException(NoSuchDefinitionException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
Handles the case where client referenced an unknown entity.
- onNoSuchJobException(NoSuchBatchJobException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onNoSuchJobExecutionException(NoSuchJobExecutionException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onNoSuchJobInstanceException(NoSuchBatchJobInstanceException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onNoSuchMetricException(NoSuchMetricException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onNoSuchModuleException(NoSuchModuleException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onNoSuchPageException(PageNotFoundException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onNoSuchStepExecutionException(NoSuchStepExecutionException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onNotDeployedException(NotDeployedException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
Handles the case where client tried to un-deploy something that is not currently deployed.
- onNothingToDeleteException(NothingToDeleteException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onProcessError(I, Exception) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdItemListener
-
- onRabbitAdminException(RabbitAdminException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onReadError(Exception) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdItemListener
-
- onResume(CuratorFramework) - Method in class org.springframework.xd.dirt.stream.zookeeper.RepositoryConnectionListener
-
Called when the Curator ConnectionStateListener
receives a
ConnectionState.RECONNECTED
event.
- onResume(CuratorFramework) - Method in interface org.springframework.xd.dirt.zookeeper.ZooKeeperConnectionListener
-
Called when the Curator ConnectionStateListener
receives a
ConnectionState.RECONNECTED
event.
- onSkipInProcess(Object, Throwable) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdSkipListener
-
- onSkipInRead(Throwable) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdSkipListener
-
- onSkipInWrite(Object, Throwable) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdSkipListener
-
- onSubscribe(Subscription) - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler.ChannelForwardingSubscriber
-
- onSupervisorElected(SupervisorElectedEvent) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DefaultDeploymentStateRecalculator
-
- onSupervisorElected(SupervisorElectedEvent) - Method in interface org.springframework.xd.dirt.server.admin.deployment.zk.SupervisorElectionListener
-
The action to perform after the admin leader is elected.
- onSupervisorElected(SupervisorElectedEvent) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ZKDeploymentHandler
-
- onSuspend(CuratorFramework) - Method in class org.springframework.xd.dirt.stream.zookeeper.RepositoryConnectionListener
-
Called when the Curator ConnectionStateListener
receives a
ConnectionState.SUSPENDED
event.
- onSuspend(CuratorFramework) - Method in interface org.springframework.xd.dirt.zookeeper.ZooKeeperConnectionListener
-
Called when the Curator ConnectionStateListener
receives a
ConnectionState.SUSPENDED
event.
- onUnsatisfiedServletRequestParameterException(UnsatisfiedServletRequestParameterException) - Method in class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- onWriteError(Exception, List<? extends Object>) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdItemListener
-
- OPTION_SEPARATOR - Static variable in class org.springframework.xd.module.core.CompositeModule
-
- OptionNameAfterDashDashRecoveryStrategy - Class in org.springframework.xd.dirt.stream.completion
-
Provides completion proposals when the user has typed the two dashes that precede a module option name.
- OptionNameAfterDashDashRecoveryStrategy(XDParser, ModuleRegistry, ModuleOptionsMetadataResolver) - Constructor for class org.springframework.xd.dirt.stream.completion.OptionNameAfterDashDashRecoveryStrategy
-
Construct a new ExpandOneDashToTwoDashesRecoveryStrategy given the parser,
- OPTIONS_CLASS - Static variable in class org.springframework.xd.module.options.DefaultModuleOptionsMetadataResolver
-
- OrderedContextInitializer - Interface in org.springframework.xd.dirt.container.initializer
-
Allows any necessary changes to the Target Context.
- org.springframework.batch.integration.x - package org.springframework.batch.integration.x
-
Package for Batch integration extensions.
- org.springframework.batch.step.tasklet.x - package org.springframework.batch.step.tasklet.x
-
- org.springframework.integration.x.gemfire - package org.springframework.integration.x.gemfire
-
Package for Gemfire integration extensions.
- org.springframework.integration.x.http - package org.springframework.integration.x.http
-
Package for batch integration classes.
- org.springframework.integration.x.kafka - package org.springframework.integration.x.kafka
-
Package for kafka integration extensions.
- org.springframework.integration.x.splunk - package org.springframework.integration.x.splunk
-
Package for Splunk integration extensions.
- org.springframework.integration.x.twitter - package org.springframework.integration.x.twitter
-
Package for twitter integration extensions.
- org.springframework.xd.analytics.metrics.core - package org.springframework.xd.analytics.metrics.core
-
Package for core metrics.
- org.springframework.xd.analytics.metrics.integration - package org.springframework.xd.analytics.metrics.integration
-
Package for metrics integration.
- org.springframework.xd.analytics.metrics.memory - package org.springframework.xd.analytics.metrics.memory
-
Package for in-memory metrics.
- org.springframework.xd.analytics.metrics.metadata - package org.springframework.xd.analytics.metrics.metadata
-
Package for metrics' options metadata.
- org.springframework.xd.analytics.metrics.redis - package org.springframework.xd.analytics.metrics.redis
-
Package for Redis based metrics support.
- org.springframework.xd.analytics.ml - package org.springframework.xd.analytics.ml
-
Package with core abstractions for Machine Learning Support.
- org.springframework.xd.batch - package org.springframework.xd.batch
-
Package for XD batch database support.
- org.springframework.xd.batch.hsqldb.server - package org.springframework.xd.batch.hsqldb.server
-
Package for HSQL database server.
- org.springframework.xd.batch.item.hadoop - package org.springframework.xd.batch.item.hadoop
-
Package for batch item writer for hadoop.
- org.springframework.xd.batch.item.jdbc - package org.springframework.xd.batch.item.jdbc
-
Package for JDBC item provider.
- org.springframework.xd.cassandra - package org.springframework.xd.cassandra
-
- org.springframework.xd.cassandra.mixins - package org.springframework.xd.cassandra.mixins
-
- org.springframework.xd.dirt - package org.springframework.xd.dirt
-
Base package for DIRT (Distributed Integration RunTime).
- org.springframework.xd.dirt.analytics - package org.springframework.xd.dirt.analytics
-
Package for DIRT analytics support.
- org.springframework.xd.dirt.batch - package org.springframework.xd.dirt.batch
-
- org.springframework.xd.dirt.batch.tasklet - package org.springframework.xd.dirt.batch.tasklet
-
- org.springframework.xd.dirt.cluster - package org.springframework.xd.dirt.cluster
-
Package for DIRT cluster.
- org.springframework.xd.dirt.container.initializer - package org.springframework.xd.dirt.container.initializer
-
Package for container context initializer classes.
- org.springframework.xd.dirt.container.store - package org.springframework.xd.dirt.container.store
-
Package for container metadata store.
- org.springframework.xd.dirt.core - package org.springframework.xd.dirt.core
-
Package for DIRT core classes.
- org.springframework.xd.dirt.event - package org.springframework.xd.dirt.event
-
Package for DIRT events.
- org.springframework.xd.dirt.integration.bus - package org.springframework.xd.dirt.integration.bus
-
Package for DIRT classes that integrate with
MessageBus
.
- org.springframework.xd.dirt.integration.bus.converter - package org.springframework.xd.dirt.integration.bus.converter
-
Package for DIRT classes that provide message converters used to/from
MessageBus
.
- org.springframework.xd.dirt.integration.bus.local - package org.springframework.xd.dirt.integration.bus.local
-
- org.springframework.xd.dirt.integration.bus.rabbit - package org.springframework.xd.dirt.integration.bus.rabbit
-
Package for classes related to the RabbitMessageBus.
- org.springframework.xd.dirt.integration.json - package org.springframework.xd.dirt.integration.json
-
- org.springframework.xd.dirt.integration.kafka - package org.springframework.xd.dirt.integration.kafka
-
- org.springframework.xd.dirt.integration.rabbit - package org.springframework.xd.dirt.integration.rabbit
-
This package contains an implementation of the
MessageBus
for RabbitMQ.
- org.springframework.xd.dirt.integration.redis - package org.springframework.xd.dirt.integration.redis
-
This package contains an implementation of the
MessageBus
for Redis.
- org.springframework.xd.dirt.jdbc.util - package org.springframework.xd.dirt.jdbc.util
-
Package for DIRT JDBC util classes.
- org.springframework.xd.dirt.job - package org.springframework.xd.dirt.job
-
Provides classes that support spring batch admin for DIRT jobs.
- org.springframework.xd.dirt.job.dao - package org.springframework.xd.dirt.job.dao
-
- org.springframework.xd.dirt.job.dsl - package org.springframework.xd.dirt.job.dsl
-
- org.springframework.xd.dirt.module - package org.springframework.xd.dirt.module
-
Base package for DIRT module.
- org.springframework.xd.dirt.module.jmx - package org.springframework.xd.dirt.module.jmx
-
Package for DIRT module that provides JMX support.
- org.springframework.xd.dirt.module.store - package org.springframework.xd.dirt.module.store
-
Package for module meta data.
- org.springframework.xd.dirt.module.support - package org.springframework.xd.dirt.module.support
-
Package for DIRT module support.
- org.springframework.xd.dirt.modules.metadata - package org.springframework.xd.dirt.modules.metadata
-
Package for DIRT modules options' metadata.
- org.springframework.xd.dirt.plugins - package org.springframework.xd.dirt.plugins
-
Base Package for Spring XD plugins.
- org.springframework.xd.dirt.plugins.job - package org.springframework.xd.dirt.plugins.job
-
Contains classes that support Spring Batch for Job plugins.
- org.springframework.xd.dirt.plugins.job.support - package org.springframework.xd.dirt.plugins.job.support
-
Contains classes for improved Spring Batch support.
- org.springframework.xd.dirt.plugins.job.support.listener - package org.springframework.xd.dirt.plugins.job.support.listener
-
Contains classes that support listeners for DIRT job lifecycle events.
- org.springframework.xd.dirt.plugins.spark.streaming - package org.springframework.xd.dirt.plugins.spark.streaming
-
Package for spark streaming plugin support.
- org.springframework.xd.dirt.plugins.stream - package org.springframework.xd.dirt.plugins.stream
-
Package for Stream plugins.
- org.springframework.xd.dirt.rest - package org.springframework.xd.dirt.rest
-
Provides a REST API for interacting with the XD runtime.
- org.springframework.xd.dirt.rest.meta - package org.springframework.xd.dirt.rest.meta
-
- org.springframework.xd.dirt.rest.metrics - package org.springframework.xd.dirt.rest.metrics
-
Provides a REST API for XD metrics.
- org.springframework.xd.dirt.rest.security - package org.springframework.xd.dirt.rest.security
-
- org.springframework.xd.dirt.rest.validation - package org.springframework.xd.dirt.rest.validation
-
Provides server-side validation REST end-points.
- org.springframework.xd.dirt.server - package org.springframework.xd.dirt.server
-
Base package for DIRT server.
- org.springframework.xd.dirt.server.admin - package org.springframework.xd.dirt.server.admin
-
Base package for XD admin server.
- org.springframework.xd.dirt.server.admin.deployment - package org.springframework.xd.dirt.server.admin.deployment
-
Base package for deployment classes used by admin server.
- org.springframework.xd.dirt.server.admin.deployment.zk - package org.springframework.xd.dirt.server.admin.deployment.zk
-
Base package for classes that are used for ZK based deployment.
- org.springframework.xd.dirt.server.container - package org.springframework.xd.dirt.server.container
-
Base package for XD container server.
- org.springframework.xd.dirt.server.options - package org.springframework.xd.dirt.server.options
-
Package for DIRT server options.
- org.springframework.xd.dirt.server.security - package org.springframework.xd.dirt.server.security
-
- org.springframework.xd.dirt.server.singlenode - package org.springframework.xd.dirt.server.singlenode
-
Base package for XD single-node server.
- org.springframework.xd.dirt.spark - package org.springframework.xd.dirt.spark
-
- org.springframework.xd.dirt.stream - package org.springframework.xd.dirt.stream
-
Base package for processing DeploymentUnit (Stream/Job).
- org.springframework.xd.dirt.stream.completion - package org.springframework.xd.dirt.stream.completion
-
Package for code completion provider for Stream/Job and their module names/options when used in Shell.
- org.springframework.xd.dirt.stream.dsl - package org.springframework.xd.dirt.stream.dsl
-
Base package for processing DeploymentUnit(Stream/Job) DSL.
- org.springframework.xd.dirt.stream.zookeeper - package org.springframework.xd.dirt.stream.zookeeper
-
Package for DeploymentUnit(Stream/Job)'s Zookeeper based repositories.
- org.springframework.xd.dirt.test - package org.springframework.xd.dirt.test
-
Package for DIRT test classes.
- org.springframework.xd.dirt.test.process - package org.springframework.xd.dirt.test.process
-
Package for processing chain test support.
- org.springframework.xd.dirt.test.sink - package org.springframework.xd.dirt.test.sink
-
Package for test support sink that binds to named channel.
- org.springframework.xd.dirt.test.source - package org.springframework.xd.dirt.test.source
-
Package for test support source that binds to named channel.
- org.springframework.xd.dirt.util - package org.springframework.xd.dirt.util
-
Package for DIRT utils.
- org.springframework.xd.dirt.util.logging - package org.springframework.xd.dirt.util.logging
-
- org.springframework.xd.dirt.web - package org.springframework.xd.dirt.web
-
Contains Spring MVC related classes, e.g.
- org.springframework.xd.dirt.web.config - package org.springframework.xd.dirt.web.config
-
Contains Java Configuration classes.
- org.springframework.xd.dirt.web.controller - package org.springframework.xd.dirt.web.controller
-
Contains Spring MVC web controllers.
- org.springframework.xd.dirt.web.controller.support - package org.springframework.xd.dirt.web.controller.support
-
Contains various support classes for the web-ui controllers.
- org.springframework.xd.dirt.zookeeper - package org.springframework.xd.dirt.zookeeper
-
Package for DIRT Zookeeper support.
- org.springframework.xd.distributed.util - package org.springframework.xd.distributed.util
-
Package for distributed test utility classes.
- org.springframework.xd.documentation - package org.springframework.xd.documentation
-
- org.springframework.xd.extension.process - package org.springframework.xd.extension.process
-
- org.springframework.xd.extension.script - package org.springframework.xd.extension.script
-
- org.springframework.xd.gemfire - package org.springframework.xd.gemfire
-
Package for gemfire extensions.
- org.springframework.xd.gemfire.server - package org.springframework.xd.gemfire.server
-
Contains a simple driver application to run a Gemfire server.
- org.springframework.xd.gpload - package org.springframework.xd.gpload
-
- org.springframework.xd.greenplum.config - package org.springframework.xd.greenplum.config
-
- org.springframework.xd.greenplum.gpfdist - package org.springframework.xd.greenplum.gpfdist
-
- org.springframework.xd.greenplum.support - package org.springframework.xd.greenplum.support
-
- org.springframework.xd.hadoop.fs - package org.springframework.xd.hadoop.fs
-
Package for hadoop FS related classes.
- org.springframework.xd.http - package org.springframework.xd.http
-
Package for http extensions.
- org.springframework.xd.integration.fixtures - package org.springframework.xd.integration.fixtures
-
Base package for integration fixtures.
- org.springframework.xd.integration.hadoop - package org.springframework.xd.integration.hadoop
-
Base package for Hadoop/HDFS support.
- org.springframework.xd.integration.hadoop.config - package org.springframework.xd.integration.hadoop.config
-
Provides classes for configuration - parsers, namespace handlers, factory beans.
- org.springframework.xd.integration.hadoop.expression - package org.springframework.xd.integration.hadoop.expression
-
Package for HDFS Partitioning expression support.
- org.springframework.xd.integration.hadoop.outbound - package org.springframework.xd.integration.hadoop.outbound
-
Provides classes supporting outbound endpoints.
- org.springframework.xd.integration.hadoop.partition - package org.springframework.xd.integration.hadoop.partition
-
Package for HDFS Partitioning support.
- org.springframework.xd.integration.reactor.config - package org.springframework.xd.integration.reactor.config
-
Package for Reactor integration configurations.
- org.springframework.xd.integration.reactor.net - package org.springframework.xd.integration.reactor.net
-
Package for Reactor integration for network-aware server.
- org.springframework.xd.integration.reactor.syslog - package org.springframework.xd.integration.reactor.syslog
-
Package for Reactor integration for syslog.
- org.springframework.xd.integration.throughput - package org.springframework.xd.integration.throughput
-
Package for throughput sampler extensions.
- org.springframework.xd.integration.util - package org.springframework.xd.integration.util
-
Package for integration test utility.
- org.springframework.xd.integration.util.jmxresult - package org.springframework.xd.integration.util.jmxresult
-
Package for processing integration tests' JMX result.
- org.springframework.xd.jdbc - package org.springframework.xd.jdbc
-
Package for JDBC extensions.
- org.springframework.xd.mail - package org.springframework.xd.mail
-
Package for Mail module extensions.
- org.springframework.xd.module - package org.springframework.xd.module
-
Root package of the Module support.
- org.springframework.xd.module.core - package org.springframework.xd.module.core
-
Contains the Module core classes.
- org.springframework.xd.module.info - package org.springframework.xd.module.info
-
- org.springframework.xd.module.options - package org.springframework.xd.module.options
-
- org.springframework.xd.module.options.mixins - package org.springframework.xd.module.options.mixins
-
A set of reusable mixins for defining module options metadata.
- org.springframework.xd.module.options.spi - package org.springframework.xd.module.options.spi
-
SPI for Module Options.
- org.springframework.xd.module.options.support - package org.springframework.xd.module.options.support
-
- org.springframework.xd.module.options.types - package org.springframework.xd.module.options.types
-
Contains custom module option types.
- org.springframework.xd.module.options.validation - package org.springframework.xd.module.options.validation
-
- org.springframework.xd.module.support - package org.springframework.xd.module.support
-
Contains support classes for the Module support
- org.springframework.xd.mongodb - package org.springframework.xd.mongodb
-
Package for mongodb extensions.
- org.springframework.xd.reactor - package org.springframework.xd.reactor
-
- org.springframework.xd.redis - package org.springframework.xd.redis
-
- org.springframework.xd.rest.client - package org.springframework.xd.rest.client
-
Defines the various REST client operation interfaces.
- org.springframework.xd.rest.client.impl - package org.springframework.xd.rest.client.impl
-
Contains REST client operation implementations.
- org.springframework.xd.rest.client.impl.support - package org.springframework.xd.rest.client.impl.support
-
Contains support classes for the Rest client, e.g.
- org.springframework.xd.rest.domain - package org.springframework.xd.rest.domain
-
Contains the resources managed by the REST API.
- org.springframework.xd.rest.domain.meta - package org.springframework.xd.rest.domain.meta
-
- org.springframework.xd.rest.domain.metrics - package org.springframework.xd.rest.domain.metrics
-
Package for Rest domain metrics classes.
- org.springframework.xd.rest.domain.security - package org.springframework.xd.rest.domain.security
-
Contains the security-related resources managed by the REST API.
- org.springframework.xd.rest.domain.support - package org.springframework.xd.rest.domain.support
-
Package for rest domain support classes.
- org.springframework.xd.rest.domain.util - package org.springframework.xd.rest.domain.util
-
Package for common rest domain util classes.
- org.springframework.xd.rest.domain.validation - package org.springframework.xd.rest.domain.validation
-
Package for rest domain classes used for server-side validation purposes.
- org.springframework.xd.rxjava - package org.springframework.xd.rxjava
-
- org.springframework.xd.shell - package org.springframework.xd.shell
-
Package for core Spring XD Shell classes.
- org.springframework.xd.shell.command - package org.springframework.xd.shell.command
-
Package for various Spring XD Shell commands.
- org.springframework.xd.shell.command.support - package org.springframework.xd.shell.command.support
-
Provides support classes for the various shell commands.
- org.springframework.xd.shell.converter - package org.springframework.xd.shell.converter
-
Contains Shell converter classes.
- org.springframework.xd.shell.hadoop - package org.springframework.xd.shell.hadoop
-
Package for Hadoop Shell command classes.
- org.springframework.xd.shell.util - package org.springframework.xd.shell.util
-
Contains utilities for rendering textual contents (example: text tables), to the console.
- org.springframework.xd.spark - package org.springframework.xd.spark
-
Package for XD spark extensions.
- org.springframework.xd.spark.streaming - package org.springframework.xd.spark.streaming
-
Package for spark streaming integration.
- org.springframework.xd.spark.streaming.examples.java - package org.springframework.xd.spark.streaming.examples.java
-
Package for spark streaming java based examples.
- org.springframework.xd.spark.streaming.java - package org.springframework.xd.spark.streaming.java
-
Package for java based spark streaming integration support.
- org.springframework.xd.spark.tasklet - package org.springframework.xd.spark.tasklet
-
Package for spark tasklets.
- org.springframework.xd.splunk - package org.springframework.xd.splunk
-
Package for Splunk extensions.
- org.springframework.xd.sqoop - package org.springframework.xd.sqoop
-
Package for XD sqoop extensions.
- org.springframework.xd.store - package org.springframework.xd.store
-
Package for analytics repository.
- org.springframework.xd.syslog - package org.springframework.xd.syslog
-
Package for SYSLOG extensions.
- org.springframework.xd.tcp - package org.springframework.xd.tcp
-
Package for TCP extensions.
- org.springframework.xd.tcp.encdec - package org.springframework.xd.tcp.encdec
-
Package for encoders/decoders config for TCP extensions.
- org.springframework.xd.test - package org.springframework.xd.test
-
Contains test support classes.
- org.springframework.xd.test.fixtures - package org.springframework.xd.test.fixtures
-
Contains integration test fixtures classes.
- org.springframework.xd.test.fixtures.util - package org.springframework.xd.test.fixtures.util
-
Contains test fixture utility classes.
- org.springframework.xd.test.generator - package org.springframework.xd.test.generator
-
utilities to generate load on a server
- org.springframework.xd.test.kafka - package org.springframework.xd.test.kafka
-
Contains Kafka test support classes.
- org.springframework.xd.test.mqtt - package org.springframework.xd.test.mqtt
-
Contains MQTT test support classes.
- org.springframework.xd.test.rabbit - package org.springframework.xd.test.rabbit
-
Contains Rabbit test support classes.
- org.springframework.xd.test.redis - package org.springframework.xd.test.redis
-
Contains Redis support classes.
- org.springframework.xd.tuple - package org.springframework.xd.tuple
-
Base package for tuple classes.
- org.springframework.xd.tuple.batch - package org.springframework.xd.tuple.batch
-
Contains tuple batch classes.
- org.springframework.xd.tuple.integration - package org.springframework.xd.tuple.integration
-
Contains classes that supports tuple integration such as tuple transformers etc.,
- org.springframework.xd.tuple.processor - package org.springframework.xd.tuple.processor
-
Contains tuple processor classes.
- org.springframework.xd.tuple.serializer.kryo - package org.springframework.xd.tuple.serializer.kryo
-
Contains tuple processor classes.
- org.springframework.xd.tuple.spel - package org.springframework.xd.tuple.spel
-
Contains tuple SpEL accessor classes.
- org.springframework.xd.yarn - package org.springframework.xd.yarn
-
- outputChannel - Variable in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- OutputMapper<I,O,A,MO> - Interface in org.springframework.xd.analytics.ml
-
An OutputMapper
maps a given model input MO
to an appropriate domain input O
for the given
analytic A
by potentially using data from the original input I
.
- outputType(String) - Method in class org.springframework.xd.test.fixtures.KafkaSource
-
set the outputType for the kafka source
- outputType(String) - Method in class org.springframework.xd.test.fixtures.TcpClientSource
-
Sets the output type for the fixture
- P2P_NAMED_CHANNEL_TYPE_PREFIX - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- PackageSuiteRunner - Class in org.springframework.xd.test
-
A Suite
to run all concrete classes ending in Tests in the same package.
- PackageSuiteRunner(Class<?>, RunnerBuilder) - Constructor for class org.springframework.xd.test.PackageSuiteRunner
-
- padRight(String, int, char) - Static method in class org.springframework.xd.shell.util.CommonUtils
-
Right-pad a String with a configurable padding character.
- padRight(String, int) - Static method in class org.springframework.xd.shell.util.CommonUtils
-
Right-pad the provided String with empty spaces.
- PageNotFoundException - Exception in org.springframework.xd.dirt.util
-
Exception thrown when a Pageable
requests a page that does not exist.
- PageNotFoundException(String) - Constructor for exception org.springframework.xd.dirt.util.PageNotFoundException
-
- PageNotFoundException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.util.PageNotFoundException
-
- PagingUtility<T extends java.lang.Comparable<? super T>> - Class in org.springframework.xd.dirt.util
-
Utility class for paging support in repository accessor methods.
- PagingUtility() - Constructor for class org.springframework.xd.dirt.util.PagingUtility
-
- ParentConfiguration - Class in org.springframework.xd.dirt.server
-
Beans defined and imported here are in the global parent context, hence available to the entire hierarchy, including
Admins, Containers, and Modules.
- ParentConfiguration() - Constructor for class org.springframework.xd.dirt.server.ParentConfiguration
-
- ParentLastURLClassLoader - Class in org.springframework.xd.module.support
-
Extension for URLClassLoader
that uses a parent-last (or child first) delegation.
- ParentLastURLClassLoader(URL[], ClassLoader) - Constructor for class org.springframework.xd.module.support.ParentLastURLClassLoader
-
- ParentLastURLClassLoader(URL[], ClassLoader, boolean) - Constructor for class org.springframework.xd.module.support.ParentLastURLClassLoader
-
- parse(String) - Method in class org.springframework.xd.dirt.job.dsl.JobParser
-
Parse a job flow definition into an abstract syntax tree (AST).
- parse(String) - Method in class org.springframework.xd.dirt.stream.dsl.StreamConfigParser
-
Parse a stream definition without supplying the stream name up front.
- parse(String, String) - Method in class org.springframework.xd.dirt.stream.dsl.StreamConfigParser
-
Parse a stream definition.
- parse(String, String, ParsingContext) - Method in interface org.springframework.xd.dirt.stream.XDParser
-
Parse a DSL string.
- parse(String[]) - Method in class org.springframework.xd.dirt.stream.XDStreamParser.MultiLineDocumentParser
-
- parse(String, String, ParsingContext) - Method in class org.springframework.xd.dirt.stream.XDStreamParser
-
- parseArguments(Parameters) - Method in class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandler
-
- parseConfigOptions(String[], Map<String, String>) - Static method in class org.springframework.xd.sqoop.SqoopRunner
-
- parseConsumer(Element, ParserContext) - Method in class org.springframework.xd.integration.hadoop.config.DatasetOutboundChannelAdapterParser
-
- parseConsumer(Element, ParserContext) - Method in class org.springframework.xd.integration.hadoop.config.HdfsOutboundChannelAdapterParser
-
- parseDeploymentProperties(String) - Static method in class org.springframework.xd.rest.domain.support.DeploymentPropertiesFormat
-
Parses a String comprised of 0 or more comma-delimited key=value pairs where
each key has the format:
module.[modulename].[key]
.
- parseInternal(Element, ParserContext) - Method in class org.springframework.xd.integration.hadoop.config.NamingStrategyParser
-
- parseInternal(Element, ParserContext) - Method in class org.springframework.xd.integration.hadoop.config.RolloverStrategyParser
-
- parseJobToGraph(String) - Method in class org.springframework.xd.dirt.rest.ToolsController
-
Parse a single job specification into a graph structure.
- parseNumberList(String) - Static method in class org.springframework.integration.x.kafka.KafkaPartitionAllocator
-
Expects a String containing a list of numbers or ranges, e.g.
- parser() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- parser - Variable in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- parser - Variable in class org.springframework.xd.dirt.stream.completion.StacktraceFingerprintingCompletionRecoveryStrategy
-
- parseSqoopCommandArguments(String, String[], List<String>) - Static method in class org.springframework.xd.sqoop.SqoopRunner
-
- ParsingContext - Enum in org.springframework.xd.dirt.stream
-
Captures the context in which a parse operation is made.
- ParsingContext.Position - Enum in org.springframework.xd.dirt.stream
-
Represents the position of a module in an XD DSL declaration.
- partition(int) - Method in class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
Partition a database table assuming that the data in the column specified
are uniformly distributed.
- partition(int) - Method in class org.springframework.batch.integration.x.RemoteFilePartitioner
-
- PARTITION_HEADER - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- PARTITION_INDEX - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
The consumer's partition index.
- PARTITION_KEY_EXPRESSION - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
The partition key expression.
- PARTITION_KEY_EXTRACTOR_CLASS - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
The partition key class.
- PARTITION_SELECTOR_CLASS - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
The partition selector class.
- PARTITION_SELECTOR_EXPRESSION - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
The partition selector expression.
- partitionedJdbcHdfsJob() - Method in class org.springframework.xd.integration.fixtures.Jobs
-
Create an instance of the PartitionedJdbcHdfsJob job with the default hdfs target dir, fileName, table,
columnNames, partitionColumn and partitions.
- PartitionedJdbcHdfsJob - Class in org.springframework.xd.test.fixtures
-
A test fixture that represents a partitioned JdbcHdfs Job
- PartitionedJdbcHdfsJob(String, String, String, String, String, int) - Constructor for class org.springframework.xd.test.fixtures.PartitionedJdbcHdfsJob
-
Construct a new jdbchdfs partitioned fixture using the provided parameters.
- PartitionKeyExtractorStrategy - Interface in org.springframework.xd.dirt.integration.bus
-
Strategy for extracting a partition key from a Message.
- PartitionSelectorStrategy - Interface in org.springframework.xd.dirt.integration.bus
-
Strategy for determining the partition to which a message should be sent.
- PassthruModuleOptionsMetadata - Class in org.springframework.xd.module.options
-
Implementation of
ModuleOptionsMetadata
used when no explicit information about a module has been authored.
- PassthruModuleOptionsMetadata() - Constructor for class org.springframework.xd.module.options.PassthruModuleOptionsMetadata
-
- password - Variable in class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- Password - Class in org.springframework.xd.module.options.types
-
This module option type represents a password.
- Password(String) - Constructor for class org.springframework.xd.module.options.types.Password
-
- PASSWORD_PARAMETER_NAMES - Static variable in class org.springframework.xd.dirt.rest.PasswordUtils
-
- passwordParameterPattern - Static variable in class org.springframework.xd.dirt.rest.PasswordUtils
-
- PasswordUtils - Class in org.springframework.xd.dirt.rest
-
- Paths - Class in org.springframework.xd.dirt.zookeeper
-
Common paths and path utilities for XD components.
- Paths() - Constructor for class org.springframework.xd.dirt.zookeeper.Paths
-
- peek() - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Return the token at the current position.
- peek(int) - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Return the token at the specified offset from the current position.
- peek(int, TokenKind) - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Peek at the token at an offset (relative to the current position) - if the token
matches the indicated kind, return true, otherwise return false.
- peek(TokenKind) - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Return true
if the indicated token matches the current token
position.
- PeriodicTriggerMixin - Class in org.springframework.xd.module.options.mixins
-
Mixin for options that include a periodic fixed-delay trigger.
- PeriodicTriggerMixin() - Constructor for class org.springframework.xd.module.options.mixins.PeriodicTriggerMixin
-
- PipeIntoOtherModulesExpansionStrategy - Class in org.springframework.xd.dirt.stream.completion
-
Continues a well-formed stream definition by adding a pipe symbol and another module, provided that the stream
definition hasn't reached its end yet.
- PipeIntoOtherModulesExpansionStrategy(ModuleRegistry) - Constructor for class org.springframework.xd.dirt.stream.completion.PipeIntoOtherModulesExpansionStrategy
-
Construct a new PipeIntoOtherModulesExpansionStrategy given a ModuleDefinition repository.
- Plugin - Interface in org.springframework.xd.module.core
-
To be implemented by classes that want to alter how a
Module
works.
- PLUGIN_CONTEXT_CONFIG_ROOT - Static variable in class org.springframework.xd.dirt.plugins.AbstractPlugin
-
- pluginContext() - Method in class org.springframework.xd.dirt.server.singlenode.SingleNodeApplication
-
- PluginContextComponentScanningExtensionsInitializer - Class in org.springframework.xd.dirt.container.initializer
-
- PluginContextComponentScanningExtensionsInitializer() - Constructor for class org.springframework.xd.dirt.container.initializer.PluginContextComponentScanningExtensionsInitializer
-
- pluginContextInitializers() - Method in class org.springframework.xd.dirt.server.container.ContainerBootstrapContext
-
- PluginContextResourceExtensionsInitializer - Class in org.springframework.xd.dirt.container.initializer
-
- PluginContextResourceExtensionsInitializer() - Constructor for class org.springframework.xd.dirt.container.initializer.PluginContextResourceExtensionsInitializer
-
- PluginsInitializer - Class in org.springframework.xd.dirt.container.initializer
-
- PluginsInitializer() - Constructor for class org.springframework.xd.dirt.container.initializer.PluginsInitializer
-
- PojoModuleOptionsMetadata - Class in org.springframework.xd.module.options
-
An implementation of
ModuleOptionsMetadata
that derives its information from a plain old java object:
public setters are reported as valid options
the type of the option is derived from the accepted type by the setter
ModuleOptions
for such a POJO will work as follows:
an instance of the class will be created reflectively and injected with user provided values,
reported properties are computed from all the getters,
the POJO may bear JSR303 validation annotations, which will be used to validate the interpolated options,
if the POJO implements
ProfileNamesProvider
, profile names will be gathered from a reflective call to
ProfileNamesProvider.profilesToActivate()
- PojoModuleOptionsMetadata(Class<?>) - Constructor for class org.springframework.xd.module.options.PojoModuleOptionsMetadata
-
- PojoModuleOptionsMetadata(Class<?>, ConversionService) - Constructor for class org.springframework.xd.module.options.PojoModuleOptionsMetadata
-
- PojoToJsonMessageConverter - Class in org.springframework.xd.dirt.integration.bus.converter
-
A MessageConverter
to convert a Java object to a JSON String
- PojoToJsonMessageConverter() - Constructor for class org.springframework.xd.dirt.integration.bus.converter.PojoToJsonMessageConverter
-
- PojoToStringMessageConverter - Class in org.springframework.xd.dirt.integration.bus.converter
-
A MessageConverter
to convert a Java object to a String using toString()
- PojoToStringMessageConverter() - Constructor for class org.springframework.xd.dirt.integration.bus.converter.PojoToStringMessageConverter
-
- poll(DeploymentMessage) - Method in interface org.springframework.xd.dirt.server.admin.deployment.DeploymentMessagePublisher
-
Publish the
DeploymentMessage
and block the
executing thread until the message has been processed
by the recipient.
- poll(DeploymentMessage) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ZKDeploymentMessagePublisher
-
- PollingMailSource - Class in org.springframework.xd.test.fixtures
-
Fixture that represents the mail source module, which uses polling (here forced to 1s).
- PollingMailSource() - Constructor for class org.springframework.xd.test.fixtures.PollingMailSource
-
- port - Variable in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- port - Variable in class org.springframework.xd.test.fixtures.AbstractMailSource
-
- port(int) - Method in class org.springframework.xd.test.fixtures.AbstractMailSource
-
- port(int) - Method in class org.springframework.xd.test.fixtures.GemFireCQSource
-
Set the gemfire server port.
- port(int) - Method in class org.springframework.xd.test.fixtures.GemFireServerSink
-
Set the gemfire server port.
- port(int) - Method in class org.springframework.xd.test.fixtures.GemFireSource
-
Set the gemfire server port.
- port(int) - Method in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
Sets the port that the HdfsMongoDb Job will transmit mongo commands
- port - Variable in class org.springframework.xd.test.fixtures.JmsSource
-
- port - Variable in class org.springframework.xd.test.fixtures.MqttSink
-
- port(int) - Method in class org.springframework.xd.test.fixtures.TcpClientSource
-
Sets the port for the fixture
- port - Variable in class org.springframework.xd.test.fixtures.TcpSource
-
- PORT_KEY - Static variable in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- portAvailable(int) - Static method in class org.springframework.xd.gemfire.server.CacheServer
-
- position - Variable in exception org.springframework.xd.dirt.job.dsl.JobSpecificationException
-
- position() - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
Return the current token position.
- position - Variable in exception org.springframework.xd.dirt.stream.dsl.StreamDefinitionException
-
- possibleValues - Variable in class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandler
-
- postData(String) - Method in class org.springframework.xd.test.fixtures.SimpleHttpSource
-
Make a HTTP POST request using the provided string in the http body.
- postData(String) - Method in interface org.springframework.xd.test.generator.HttpGenerator
-
Generate a http POST request using the String as the body of the request.
- postData(String) - Method in class org.springframework.xd.test.generator.SimpleHttpGenerator
-
- postFromFile(File) - Method in class org.springframework.xd.test.fixtures.SimpleHttpSource
-
Generate a http request from the contents of a file
- postFromFile(File) - Method in interface org.springframework.xd.test.generator.HttpGenerator
-
Generate a http request from the contents of a file
- postFromFile(File) - Method in class org.springframework.xd.test.generator.SimpleHttpGenerator
-
- postHttp(String, String, File, MediaType) - Method in class org.springframework.xd.shell.command.HttpCommands
-
- postJobSpecWalk(T, JobSpecification) - Method in class org.springframework.xd.dirt.job.dsl.JobSpecificationVisitor
-
Override to provide code that will run just after the visit completes.
- postProcessAfterInitialization(Object, String) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusAwareRouterBeanPostProcessor
-
- postProcessAfterInitialization(Object, String) - Method in class org.springframework.xd.dirt.plugins.job.BatchJobRegistryBeanPostProcessor
-
- postProcessBeforeInitialization(Object, String) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusAwareRouterBeanPostProcessor
-
- postProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractPlugin
-
- postProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.job.JobEventsListenerPlugin
-
- postProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.job.JobPartitionerPlugin
-
- postProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.job.JobPlugin
-
- postProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.spark.streaming.SparkStreamingPlugin
-
- postProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionPlugin
-
- postProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.stream.StreamPlugin
-
- postProcessModule(Module) - Method in interface org.springframework.xd.module.core.Plugin
-
Apply changes to the module after it is initialized i.e. after its context is refreshed, but before it is
started.
- PrefixNarrowingModuleOptions - Class in org.springframework.xd.module.options
-
A decorator on another instance of
ModuleOptions
(in practice, one representing options to a composed module)
that will filter and remap property values exposed through its property source.
- PrefixNarrowingModuleOptions(ModuleOptions, String) - Constructor for class org.springframework.xd.module.options.PrefixNarrowingModuleOptions
-
- preJobSpecWalk() - Method in class org.springframework.xd.dirt.job.dsl.JobSpecificationVisitor
-
Override to provide code that will run just before the visit starts.
- prepareStepExecutionTable(StepExecutionInfoResource, TimeZone) - Static method in class org.springframework.xd.shell.command.support.JobCommandsUtils
-
- preProcessConnection(RedisConnection, boolean) - Method in class org.springframework.xd.analytics.metrics.redis.StringRedisRetryTemplate
-
- preProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractPlugin
-
- preProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.ContainerInfoPlugin
-
- preProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.job.JobPlugin
-
- preProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.MBeanExportingPlugin
-
- preProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.ModuleInfoPlugin
-
- preProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.stream.StreamPlugin
-
- preProcessModule(Module) - Method in class org.springframework.xd.dirt.plugins.ZookeeperConnectionPlugin
-
- preProcessModule(Module) - Method in interface org.springframework.xd.module.core.Plugin
-
Apply changes to the module before it is initialized i.e. before its context is refreshed.
- printLog(String, List<String>, List<String>) - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- process(Message<?>, String) - Method in class org.springframework.xd.analytics.metrics.integration.AggregateCounterHandler
-
- process(Message<?>) - Method in class org.springframework.xd.analytics.metrics.integration.FieldValueCounterHandler
-
- process(Message<?>) - Method in class org.springframework.xd.analytics.metrics.integration.GaugeHandler
-
- process(Message<?>) - Method in class org.springframework.xd.analytics.metrics.integration.MessageCounterHandler
-
- process(Message<?>) - Method in class org.springframework.xd.analytics.metrics.integration.RichGaugeHandler
-
- process(Stream<I>) - Method in interface org.springframework.xd.reactor.Processor
-
Process a stream of messages and return an output stream.
- process(Observable<I>) - Method in interface org.springframework.xd.rxjava.Processor
-
Process a stream of messages and return an output stream.
- process(JavaDStream<String>) - Method in class org.springframework.xd.spark.streaming.examples.java.FileLogger
-
- process(JavaDStream<String>) - Method in class org.springframework.xd.spark.streaming.examples.java.WordCount
-
- process(I) - Method in interface org.springframework.xd.spark.streaming.java.Processor
-
Processes the input DStream and optionally returns an output DStream.
- process(Tuple) - Method in interface org.springframework.xd.tuple.processor.TupleProcessor
-
- PROCESS_ID_KEY - Static variable in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- PROCESS_ID_KEY - Static variable in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- processor - Variable in class org.springframework.xd.reactor.AbstractReactorMessageHandler
-
- Processor<I,O> - Interface in org.springframework.xd.reactor
-
Contract for performing stream processing using Reactor within an XD processor module
- Processor<I,O> - Interface in org.springframework.xd.rxjava
-
Contract for performing stream processing using RxJava within an XD processor module
- Processor<I extends org.apache.spark.streaming.api.java.JavaDStreamLike,O extends org.apache.spark.streaming.api.java.JavaDStreamLike> - Interface in org.springframework.xd.spark.streaming.java
-
Interface for the Java based modules using the Spark Streaming API to process messages from the Message Bus.
- Processors - Class in org.springframework.xd.integration.fixtures
-
A factory that provides fully instantiated processor fixtures.
- Processors() - Constructor for class org.springframework.xd.integration.fixtures.Processors
-
- processProperties(ConfigurableListableBeanFactory, Properties) - Method in class org.springframework.xd.module.options.DefaultModuleOptionsMetadataCollector
-
- processResults(ModuleDeploymentWriter.ResultCollector) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleDeploymentWriter
-
Block the calling thread until all expected results are returned
or until a timeout occurs.
- processValue(String, Object) - Method in class org.springframework.xd.analytics.metrics.integration.FieldValueCounterHandler
-
- PRODUCER - Static variable in class org.springframework.xd.dirt.integration.bus.Binding
-
- PRODUCER_BATCHING_ADVANCED_PROPERTIES - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- PRODUCER_BATCHING_BASIC_PROPERTIES - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- PRODUCER_COMPRESSION_PROPERTIES - Static variable in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- PRODUCER_PARTITIONING_PROPERTIES - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- PRODUCER_STANDARD_PROPERTIES - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- ProfileNamesProvider - Interface in org.springframework.xd.module.options.spi
-
To be implemented by classes that instruct the framework to activate some named profiles.
- profilesToActivate() - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.dirt.modules.metadata.FileAsRefMixin
-
- profilesToActivate() - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- profilesToActivate() - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.gemfire.GemfireHostPortMixin
-
- profilesToActivate() - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.module.options.mixins.ExpressionOrScriptMixin
-
- profilesToActivate() - Method in class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin
-
- profilesToActivate() - Method in class org.springframework.xd.module.options.ModuleOptions
-
- profilesToActivate() - Method in class org.springframework.xd.module.options.PrefixNarrowingModuleOptions
-
- profilesToActivate() - Method in interface org.springframework.xd.module.options.spi.ProfileNamesProvider
-
- profilesToActivate() - Method in class org.springframework.xd.syslog.SyslogSourceOptionsMetadata
-
- profilesToActivate() - Method in class org.springframework.xd.tcp.encdec.EncoderDecoderMixins.DecoderMixin
-
- profilesToActivate() - Method in class org.springframework.xd.tcp.encdec.EncoderDecoderMixins.EncoderMixin
-
- progress(long, long) - Method in class org.springframework.xd.dirt.rest.BatchStepExecutionsController
-
Get the step execution progress for the given jobExecutions step.
- progressInfoResourceAssembler - Variable in class org.springframework.xd.dirt.rest.AbstractBatchJobsController
-
- prompt(String, String, boolean) - Method in class org.springframework.xd.shell.command.ConsoleUserInput
-
- prompt(String, String, boolean) - Method in interface org.springframework.xd.shell.command.UserInput
-
Display a prompt text to the user and expect them to enter a free-form value.
- promptWithOptions(String, String, String...) - Method in class org.springframework.xd.shell.command.ConsoleUserInput
-
Loops until one of the options
is provided.
- promptWithOptions(String, String, String...) - Method in interface org.springframework.xd.shell.command.UserInput
-
Display a prompt text to the user and expect one of options
in return.
- properties - Variable in class org.springframework.xd.dirt.job.dsl.Graph
-
- properties - Variable in class org.springframework.xd.dirt.job.dsl.Link
-
Properties on a link can capture the name of a potential transition that
would lead to this link being taken when the 'from' job completes.
- properties - Variable in class org.springframework.xd.dirt.job.dsl.Node
-
- properties(String) - Method in class org.springframework.xd.test.fixtures.Transform
-
Sets the propertiesLocation to be used by the transform.
- propertiesForDescriptor(ModuleDescriptor) - Method in interface org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentPropertiesProvider
-
- propertiesForDescriptor(ModuleDescriptor) - Method in class org.springframework.xd.dirt.server.admin.deployment.RuntimeModuleDeploymentPropertiesProvider
-
Return the runtime deployment properties for the given module descriptor.
- propertiesForDescriptor(ModuleDescriptor) - Method in class org.springframework.xd.dirt.server.admin.deployment.StreamRuntimePropertiesProvider
-
Return the runtime deployment properties for the given module descriptor.
- propertiesForDescriptor(ModuleDescriptor) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DefaultModuleDeploymentPropertiesProvider
-
- protocol - Variable in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- protocol - Variable in class org.springframework.xd.test.fixtures.AbstractMailSource
-
- protocol(String) - Method in class org.springframework.xd.test.fixtures.AbstractMailSource
-
- publish(P) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.BatchJobListener
-
- publish(DeploymentMessage) - Method in interface org.springframework.xd.dirt.server.admin.deployment.DeploymentMessagePublisher
-
- publish(DeploymentMessage) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ZKDeploymentMessagePublisher
-
- publishWithThrowableHeader(P, String) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.BatchJobListener
-
- PUBSUB_NAMED_CHANNEL_PATTERN - Static variable in class org.springframework.xd.dirt.integration.bus.BusUtils
-
- PUBSUB_NAMED_CHANNEL_TYPE_PREFIX - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- put(String, String) - Method in class org.springframework.integration.x.kafka.NamespaceDelegatingMetadataStore
-
- put(String, String) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- put(String, String) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- put(String, Object) - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- put(String, String) - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- put(String, String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- put(String, Object) - Method in class org.springframework.xd.tuple.TupleBuilder
-
- putAll(Map<? extends String, ? extends String>) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- putAll(Map<? extends String, ? extends String>) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- putAll(Map<? extends String, ?>) - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- putAll(Map<? extends String, ? extends String>) - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- putAll(Tuple) - Method in class org.springframework.xd.tuple.TupleBuilder
-
Add all names and values of the tuple to the built tuple.
- rabbit(String) - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Construct a new rabbitSink that will push messages to rabbit broker.
- RabbitAdminException - Exception in org.springframework.xd.dirt.integration.bus
-
Exceptions thrown while interfacing with the RabbitMQ admin plugin.
- RabbitAdminException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.integration.bus.RabbitAdminException
-
- RabbitAdminException(String) - Constructor for exception org.springframework.xd.dirt.integration.bus.RabbitAdminException
-
- RabbitAdminTestSupport - Class in org.springframework.xd.test.rabbit
-
JUnit Rule
that detects the fact that RabbitMQ is available on localhost with
the management plugin enabled.
- RabbitAdminTestSupport() - Constructor for class org.springframework.xd.test.rabbit.RabbitAdminTestSupport
-
- RabbitBusCleaner - Class in org.springframework.xd.dirt.integration.bus.rabbit
-
Implementation of
BusCleaner
for the
RabbitMessageBus
.
- RabbitBusCleaner() - Constructor for class org.springframework.xd.dirt.integration.bus.rabbit.RabbitBusCleaner
-
- rabbitConnectionFactory(RabbitProperties, ConnectionFactory) - Method in class org.springframework.xd.dirt.integration.rabbit.ConnectionFactorySettings
-
- RabbitConnectionMixin - Class in org.springframework.xd.dirt.modules.metadata
-
Factors out options for the typical connection setup to RabbitMQ.
- RabbitConnectionMixin() - Constructor for class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- rabbitFactory() - Method in class org.springframework.xd.dirt.integration.rabbit.ConnectionFactorySettings
-
- RabbitManagementUtils - Class in org.springframework.xd.dirt.integration.bus
-
- RabbitManagementUtils() - Constructor for class org.springframework.xd.dirt.integration.bus.RabbitManagementUtils
-
- RabbitMessageBus - Class in org.springframework.xd.dirt.integration.rabbit
-
- RabbitMessageBus(ConnectionFactory, Codec) - Constructor for class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- RabbitSink - Class in org.springframework.xd.test.fixtures
-
A test fixture that allows testing of the rabbit sink module.
- RabbitSink(String, String, String) - Constructor for class org.springframework.xd.test.fixtures.RabbitSink
-
Initialize and instance of the RabbitSink
- RabbitSinkOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Captures options to the rabbit
sink module.
- RabbitSinkOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.RabbitSinkOptionsMetadata
-
- rabbitSource() - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new RabbitSource using the environment and defaults.
- RabbitSource - Class in org.springframework.xd.test.fixtures
-
A test fixture that allows testing of the rabbit source module.
- RabbitSource(CachingConnectionFactory, String) - Constructor for class org.springframework.xd.test.fixtures.RabbitSource
-
Initialize and instance of the RabbitSource
- RabbitSourceOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Describes options to the rabbit
source module.
- RabbitSourceOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- RabbitTestSupport - Class in org.springframework.xd.test.rabbit
-
JUnit Rule
that detects the fact that RabbitMQ is available on localhost.
- RabbitTestSupport() - Constructor for class org.springframework.xd.test.rabbit.RabbitTestSupport
-
- RabbitTestSupport(boolean) - Constructor for class org.springframework.xd.test.rabbit.RabbitTestSupport
-
- raiseException(int, JobDSLMessage, Object...) - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
- RandomConfigurationSupport - Class in org.springframework.xd.test
-
Support class to have random configuration for tests.
- RandomConfigurationSupport() - Constructor for class org.springframework.xd.test.RandomConfigurationSupport
-
- RangeCapableRepository<T,ID extends java.io.Serializable & java.lang.Comparable<ID>> - Interface in org.springframework.xd.store
-
To be implemented by repositories that know how to return a slice of their data.
- ReactorNamespaceHandler - Class in org.springframework.xd.integration.reactor.config
-
- ReactorNamespaceHandler() - Constructor for class org.springframework.xd.integration.reactor.config.ReactorNamespaceHandler
-
- ReactorNetSourceOptionsMetadata - Class in org.springframework.xd.integration.reactor.net
-
Provides metadata about the configuration options of a ReactorPeer
in Spring XD.
- ReactorNetSourceOptionsMetadata() - Constructor for class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- ReactorPeerFactoryBean<IN,OUT> - Class in org.springframework.xd.integration.reactor.net
-
- ReactorPeerFactoryBean(Environment, String, Map<String, Codec>) - Constructor for class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
- ReactorPeerInboundChannelAdapter<IN,OUT> - Class in org.springframework.xd.integration.reactor.net
-
Inbound ChannelAdapter that uses ReactorPeer
abstraction to provide high-speed TCP or UDP ingest.
- ReactorPeerInboundChannelAdapter(ReactorPeer<IN, OUT, ChannelStream<IN, OUT>>) - Constructor for class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapter
-
- ReactorPeerInboundChannelAdapterConfiguration<IN,OUT> - Class in org.springframework.xd.integration.reactor.net
-
- ReactorPeerInboundChannelAdapterConfiguration() - Constructor for class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- ReactorReflectionUtils - Class in org.springframework.xd.reactor
-
Utility class for working with the reflection API for Reactor based processors.
- ReactorReflectionUtils() - Constructor for class org.springframework.xd.reactor.ReactorReflectionUtils
-
- read(EvaluationContext, Object, String) - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor.MessageOptimalPropertyAccessor
-
- read(EvaluationContext, Object, String) - Method in class org.springframework.xd.integration.hadoop.expression.MessagePartitionKeyPropertyAccessor
-
- read(Kryo, Input, Class<Tuple>) - Method in class org.springframework.xd.tuple.serializer.kryo.DefaultTupleSerializer
-
- read(EvaluationContext, Object, String) - Method in class org.springframework.xd.tuple.spel.TuplePropertyAccessor
-
- ReadableTable - Class in org.springframework.xd.greenplum.support
-
Settings for readable external table.
- ReadableTable() - Constructor for class org.springframework.xd.greenplum.support.ReadableTable
-
- ReadableTableFactoryBean - Class in org.springframework.xd.greenplum.support
-
- ReadableTableFactoryBean() - Constructor for class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- recalculateJobStates(PathChildrenCache) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DefaultDeploymentStateRecalculator
-
Iterate all deployed jobs, recalculate the deployment status of each, and
create an ephemeral node indicating the job state.
- recalculateStreamStates(PathChildrenCache) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DefaultDeploymentStateRecalculator
-
Iterate all deployed streams, recalculate the state of each, and create
an ephemeral node indicating the stream state.
- receive(int) - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChain
-
- receive(int) - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainConsumer
-
- receive(int) - Method in class org.springframework.xd.dirt.test.sink.AbstractSingleNodeNamedChannelSink
-
- receive(int) - Method in interface org.springframework.xd.dirt.test.sink.NamedChannelSink
-
- receive() - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
Receive data from the process.
- receivePayload(int) - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChain
-
- receivePayload(int) - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainConsumer
-
- receivePayload(int) - Method in class org.springframework.xd.dirt.test.sink.AbstractSingleNodeNamedChannelSink
-
- receivePayload(int) - Method in interface org.springframework.xd.dirt.test.sink.NamedChannelSink
-
- recordValue(String, long) - Method in interface org.springframework.xd.analytics.metrics.core.GaugeRepository
-
Set the value of the gauge.
- recordValue(String, double, double) - Method in interface org.springframework.xd.analytics.metrics.core.RichGaugeRepository
-
Set the current value of the gauge, smoothing accumulated values with the provided alpha value.
- recordValue(String, long) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryGaugeRepository
-
- recordValue(String, double, double) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryRichGaugeRepository
-
- recordValue(String, long) - Method in class org.springframework.xd.analytics.metrics.redis.RedisGaugeRepository
-
- recordValue(String, double, double) - Method in class org.springframework.xd.analytics.metrics.redis.RedisRichGaugeRepository
-
- recover(RetryContext) - Method in class org.springframework.xd.analytics.metrics.redis.LoggingRecoveryCallback
-
- redeployModule(ModuleRedeployer.ModuleDeployment, boolean) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer
-
Redeploy a module to a container.
- RedisAggregateCounterRepository - Class in org.springframework.xd.analytics.metrics.redis
-
- RedisAggregateCounterRepository(RedisConnectionFactory, RetryOperations) - Constructor for class org.springframework.xd.analytics.metrics.redis.RedisAggregateCounterRepository
-
- redisConnectionFactory() - Method in class org.springframework.xd.redis.RedisSinkConfiguration
-
- RedisConnectionMixin - Class in org.springframework.xd.dirt.modules.metadata
-
Mixin for Redis connection options.
- RedisConnectionMixin() - Constructor for class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- RedisCounterRepository - Class in org.springframework.xd.analytics.metrics.redis
-
- RedisCounterRepository(RedisConnectionFactory, RetryOperations) - Constructor for class org.springframework.xd.analytics.metrics.redis.RedisCounterRepository
-
- RedisCounterRepository(String, RedisConnectionFactory, RetryOperations) - Constructor for class org.springframework.xd.analytics.metrics.redis.RedisCounterRepository
-
- RedisFieldValueCounterRepository - Class in org.springframework.xd.analytics.metrics.redis
-
- RedisFieldValueCounterRepository(RedisConnectionFactory, RetryOperations) - Constructor for class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- RedisFieldValueCounterRepository(RedisConnectionFactory, String, RetryOperations) - Constructor for class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- RedisGaugeRepository - Class in org.springframework.xd.analytics.metrics.redis
-
Redis backed implementation that uses Redis keys to store and update the value.
- RedisGaugeRepository(RedisConnectionFactory, RetryOperations) - Constructor for class org.springframework.xd.analytics.metrics.redis.RedisGaugeRepository
-
- RedisGaugeRepository(RedisConnectionFactory, String, RetryOperations) - Constructor for class org.springframework.xd.analytics.metrics.redis.RedisGaugeRepository
-
- redisKeyFromId(ID) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- RedisMessageBus - Class in org.springframework.xd.dirt.integration.redis
-
- RedisMessageBus(RedisConnectionFactory, Codec) - Constructor for class org.springframework.xd.dirt.integration.redis.RedisMessageBus
-
- RedisMessageBus(RedisConnectionFactory, Codec, String...) - Constructor for class org.springframework.xd.dirt.integration.redis.RedisMessageBus
-
- redisOperations - Variable in class org.springframework.xd.store.AbstractRedisRepository
-
- RedisRetryTemplate<K,V> - Class in org.springframework.xd.analytics.metrics.redis
-
Adds Retry functionality to RedisTemplate
- RedisRetryTemplate() - Constructor for class org.springframework.xd.analytics.metrics.redis.RedisRetryTemplate
-
- RedisRichGaugeRepository - Class in org.springframework.xd.analytics.metrics.redis
-
Repository for rich-gauges backed by Redis.
- RedisRichGaugeRepository(RedisConnectionFactory, RetryOperations) - Constructor for class org.springframework.xd.analytics.metrics.redis.RedisRichGaugeRepository
-
- RedisSinkConfiguration - Class in org.springframework.xd.redis
-
Configuration for Redis Sink
- RedisSinkConfiguration() - Constructor for class org.springframework.xd.redis.RedisSinkConfiguration
-
- RedisSinkOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Options metadata for Redis sink module.
- RedisSinkOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- RedisTestSupport - Class in org.springframework.xd.test.redis
-
JUnit Rule
that detects the fact that a Redis server is running on localhost.
- RedisTestSupport() - Constructor for class org.springframework.xd.test.redis.RedisTestSupport
-
- registerNew(ModuleDefinition) - Method in class org.springframework.xd.dirt.module.DelegatingModuleRegistry
-
- registerNew(ModuleDefinition) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperComposedModuleDefinitionRegistry
-
- registerNew(ModuleDefinition) - Method in class org.springframework.xd.dirt.module.SynchronizingModuleRegistry
-
- registerNew(ModuleDefinition) - Method in interface org.springframework.xd.dirt.module.WritableModuleRegistry
-
Attempt to register the given definition, if that registry can handle it.
- registerNew(ModuleDefinition) - Method in class org.springframework.xd.dirt.module.WritableResourceModuleRegistry
-
- RemoteFilePartitioner - Class in org.springframework.batch.integration.x
-
Takes the result of an (S)FTP Gateway LS (list of FileInfo) and creates a StepExecution
for each file.
- RemoteFilePartitioner(RemoteFilePartitioner.Gateway, String) - Constructor for class org.springframework.batch.integration.x.RemoteFilePartitioner
-
- RemoteFilePartitioner.Gateway - Interface in org.springframework.batch.integration.x
-
- RemoteFileToHadoopTasklet - Class in org.springframework.batch.integration.x
-
Retrieves a fileName from the step execution context; uses the RemoteFileTemplate
to retrieve the file as a
String and writes to hdfs.
- RemoteFileToHadoopTasklet(RemoteFileTemplate, Configuration, String) - Constructor for class org.springframework.batch.integration.x.RemoteFileToHadoopTasklet
-
- remove(String) - Method in class org.springframework.integration.x.kafka.NamespaceDelegatingMetadataStore
-
- remove(Object) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- remove(Object) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- remove(Object) - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- remove() - Method in class org.springframework.xd.dirt.zookeeper.ChildPathIterator
-
Implementation throws
UnsupportedOperationException
because removals are not supported.
- remove(Object) - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- removeAbandoned - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- removeAbandonedTimeout - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- removeConnectionListener(ConnectionListener) - Method in class org.springframework.xd.dirt.integration.rabbit.LocalizedQueueConnectionFactory
-
- removeGroupFromPubSub(String) - Static method in class org.springframework.xd.dirt.integration.bus.BusUtils
-
- removeListener(ZooKeeperConnectionListener) - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
- removeModule(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractMessageBusBinderPlugin
-
- removeModule(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractPlugin
-
- removeModule(Module) - Method in class org.springframework.xd.dirt.plugins.job.JobEventsListenerPlugin
-
- removeModule(Module) - Method in class org.springframework.xd.dirt.plugins.job.JobPartitionerPlugin
-
- removeModule(Module) - Method in interface org.springframework.xd.module.core.Plugin
-
Take any actions necessary to remove a module from the system.
- removePathListener(String, PathChildrenCacheListener) - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
Remove a PathChildrenCacheListener
for the given path.
- removeRestartParameterIfExists(JobParameters) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
If
JobParameters
contains a parameters named
"XD_isRestart" removed it.
- renderMapDataAsTable(List<Map<String, Object>>, List<String>) - Static method in class org.springframework.xd.shell.util.UiUtils
-
Renders a textual representation of the list of provided Map data
- renderParameterInfoDataAsTable(Map<String, String>, boolean, int) - Static method in class org.springframework.xd.shell.util.UiUtils
-
- renderParameterInfoDataAsTable(Map<String, String>) - Static method in class org.springframework.xd.shell.util.UiUtils
-
Renders a textual representation of provided parameter map.
- renderTextTable(Table) - Static method in class org.springframework.xd.shell.util.UiUtils
-
- renderTextTable(Table, boolean) - Static method in class org.springframework.xd.shell.util.UiUtils
-
Renders a textual representation of the provided
Table
- replaceInputSourceFile(Object, String) - Static method in class org.springframework.xd.gpload.GploadTasklet
-
- replacePort(URL, int) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Substitutes the port associated with the URL with another port.
- REPLY_TO - Static variable in class org.springframework.xd.dirt.integration.bus.XdHeaders
-
- repoPrefix - Variable in class org.springframework.xd.store.AbstractRedisRepository
-
- RepositoryConnectionListener - Class in org.springframework.xd.dirt.stream.zookeeper
-
ZooKeeper connection listener that ensures path creation for
nodes required by the various repository implementations that
use ZooKeeper.
- RepositoryConnectionListener() - Constructor for class org.springframework.xd.dirt.stream.zookeeper.RepositoryConnectionListener
-
- REQUESTED - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of the module deployment requests node.
- REQUIRED_ACKS - Static variable in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- reset(String) - Method in interface org.springframework.xd.analytics.metrics.core.CounterRepository
-
Reset the given counter to zero.
- reset(String, String) - Method in interface org.springframework.xd.analytics.metrics.core.FieldValueCounterRepository
-
Reset the FieldValueCounter to zero for the given field name, creating missing counters.
- reset(String) - Method in interface org.springframework.xd.analytics.metrics.core.GaugeRepository
-
Reset the gauge to zero
- reset(String) - Method in interface org.springframework.xd.analytics.metrics.core.RichGaugeRepository
-
Reset the gauge to zero and reset any accumulated average, max and min values
- reset(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- reset(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryCounterRepository
-
- reset(String, String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryFieldValueCounterRepository
-
- reset(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryGaugeRepository
-
- reset(String) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryRichGaugeRepository
-
- reset(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisCounterRepository
-
- reset(String, String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- reset(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisGaugeRepository
-
- reset(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisRichGaugeRepository
-
- reset() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- resetBytesWritten() - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- resetBytesWritten() - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- resetBytesWritten() - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- resetOffsets(Collection<Partition>) - Method in class org.springframework.integration.x.kafka.WindowingOffsetManager
-
- resetRichGauge(RichGauge) - Static method in class org.springframework.xd.analytics.metrics.core.MetricUtils
-
- resolve(MessageHeaders) - Method in class org.springframework.xd.dirt.integration.bus.StringConvertingContentTypeResolver
-
- resolve(Map<String, Object>) - Method in class org.springframework.xd.dirt.integration.bus.StringConvertingContentTypeResolver
-
- resolve(ModuleDefinition) - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver
-
- resolve(ModuleDefinition) - Method in class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionPluginMetadataResolver
-
- resolve(StreamLookupEnvironment, String) - Method in class org.springframework.xd.dirt.stream.dsl.ChannelNode
-
- resolve(StreamLookupEnvironment, String) - Method in class org.springframework.xd.dirt.stream.dsl.SourceChannelNode
-
- resolve(StreamLookupEnvironment, String) - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- resolve(ModuleDefinition) - Method in class org.springframework.xd.module.info.DefaultSimpleModuleInformationResolver
-
- resolve(ModuleDefinition) - Method in class org.springframework.xd.module.info.DelegatingModuleInformationResolver
-
- resolve(ModuleDefinition) - Method in interface org.springframework.xd.module.info.ModuleInformationResolver
-
Return information about the given module, or null
if the provided definition is not supported by this
resolver.
- resolve(ModuleDefinition) - Method in class org.springframework.xd.module.options.DefaultModuleOptionsMetadataResolver
-
- resolve(ModuleDefinition) - Method in class org.springframework.xd.module.options.DelegatingModuleOptionsMetadataResolver
-
- resolve(ModuleDefinition) - Method in class org.springframework.xd.module.options.EnvironmentAwareModuleOptionsMetadataResolver
-
- resolve(ModuleDefinition) - Method in interface org.springframework.xd.module.options.ModuleOptionsMetadataResolver
-
Return metadata about a module, as identified by the given moduleDefinition.
- resolveContentType(String, Module) - Static method in class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionSupport
-
Resolve the MimeType
to use for the given content type
specified for the module input/output.
- resolveDestination(String) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusAwareChannelResolver
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.xd.integration.hadoop.config.NamingStrategyParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.xd.integration.hadoop.config.RolloverStrategyParser
-
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterParser
-
- resolver - Variable in class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
- resource - Variable in class org.springframework.xd.test.AbstractExternalResourceTestSupport
-
- resourceBasedConfigurationFile(SimpleModuleDefinition) - Static method in class org.springframework.xd.module.options.ModuleUtils
-
Return the resource that can be used to configure a module, or null if no such resource exists.
- ResourceConfiguredModule - Class in org.springframework.xd.module.core
-
A
SimpleModule
configured using a bean definition resource (XML or
Groovy)
- ResourceConfiguredModule(ModuleDescriptor, ModuleDeploymentProperties) - Constructor for class org.springframework.xd.module.core.ResourceConfiguredModule
-
- ResourceConfiguredModule(ModuleDescriptor, ModuleDeploymentProperties, ClassLoader, ModuleOptions) - Constructor for class org.springframework.xd.module.core.ResourceConfiguredModule
-
- ResourceDefinitionException - Exception in org.springframework.xd.dirt.module
-
Thrown when a problem is detected with the (DSL) definition of an XD resource.
- ResourceDefinitionException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.module.ResourceDefinitionException
-
- ResourceDefinitionException(String) - Constructor for exception org.springframework.xd.dirt.module.ResourceDefinitionException
-
- ResourceDeployer<R extends BaseDefinition> - Interface in org.springframework.xd.dirt.core
-
Interface for XD Resource Services.
- ResourceModuleRegistry - Class in org.springframework.xd.dirt.module
-
- ResourceModuleRegistry(String) - Constructor for class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
- ResourceOperations - Interface in org.springframework.xd.rest.client
-
Operations common to resources like Stream and Job.
- ResourcePatternScanningOptionHandler - Class in org.springframework.xd.dirt.server.options
-
An OptionHandler
that scans a resource pattern for existing resources (using a single '*' wildcard) and
allows all String values s that would fit if that single wildcard was replaced by s.
- ResourcePatternScanningOptionHandler(CmdLineParser, OptionDef, Setter<String>, String) - Constructor for class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandler
-
- ResourcePatternScanningOptionHandlers - Class in org.springframework.xd.dirt.server.options
-
- ResourcePatternScanningOptionHandlers.DistributedAnalyticsOptionHandler - Class in org.springframework.xd.dirt.server.options
-
Computes values for --analytics in the distributed case (memory is NOT supported).
- ResourcePatternScanningOptionHandlers.DistributedAnalyticsOptionHandler(CmdLineParser, OptionDef, Setter<String>) - Constructor for class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandlers.DistributedAnalyticsOptionHandler
-
- ResourcePatternScanningOptionHandlers.HadoopDistroOptionHandler - Class in org.springframework.xd.dirt.server.options
-
Computes values for --hadoopDistro out of names of subdirectories of the lib/
dir.
- ResourcePatternScanningOptionHandlers.HadoopDistroOptionHandler(CmdLineParser, OptionDef, Setter<String>) - Constructor for class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandlers.HadoopDistroOptionHandler
-
- ResourcePatternScanningOptionHandlers.SingleNodeAnalyticsOptionHandler - Class in org.springframework.xd.dirt.server.options
-
Computes values for --analytics in the single node case (accepts memory).
- ResourcePatternScanningOptionHandlers.SingleNodeAnalyticsOptionHandler(CmdLineParser, OptionDef, Setter<String>) - Constructor for class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandlers.SingleNodeAnalyticsOptionHandler
-
- ResourcePatternScanningOptionHandlers.SingleNodeDataTransportOptionHandler - Class in org.springframework.xd.dirt.server.options
-
Computes values for (data) --transport for the singlenode case.
- ResourcePatternScanningOptionHandlers.SingleNodeDataTransportOptionHandler(CmdLineParser, OptionDef, Setter<String>) - Constructor for class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandlers.SingleNodeDataTransportOptionHandler
-
- ResourcesIntoJdbcJobModuleOptionsMetadata - Class in org.springframework.xd.jdbc
-
Typical class for metadata about jobs that slurp delimited resources into jdbc.
- ResourcesIntoJdbcJobModuleOptionsMetadata() - Constructor for class org.springframework.xd.jdbc.ResourcesIntoJdbcJobModuleOptionsMetadata
-
- ResourcesIntoJdbcJobModuleOptionsMetadata.JobImportToJdbcMixin - Class in org.springframework.xd.jdbc
-
- ResourcesIntoJdbcJobModuleOptionsMetadata.JobImportToJdbcMixin() - Constructor for class org.springframework.xd.jdbc.ResourcesIntoJdbcJobModuleOptionsMetadata.JobImportToJdbcMixin
-
Sets default which are appropriate for batch jobs.
- ResourceStateVerifier - Class in org.springframework.xd.dirt.test
-
Verifies the state of resources (job or stream) by polling repository state until the
resource is in the expected state or the operation times out.
- ResourceStateVerifier(DeploymentStatusRepository<?, String>, DomainRepository<? extends BaseDefinition, String>) - Constructor for class org.springframework.xd.dirt.test.ResourceStateVerifier
-
- RESPONSES - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of the parent node for deployment request responses.
- restart(Long) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobService
-
- restartJobExecution(long) - Method in class org.springframework.xd.dirt.rest.BatchJobExecutionsController
-
Restart the Job Execution with the given executionId.
- restartJobExecution(long) - Method in class org.springframework.xd.rest.client.impl.JobTemplate
-
- restartJobExecution(long) - Method in interface org.springframework.xd.rest.client.JobOperations
-
Restart a given job execution.
- restartJobExecution(long) - Method in class org.springframework.xd.shell.command.JobCommands
-
- RestConfiguration - Class in org.springframework.xd.dirt.rest
-
Takes care of infrastructure setup for the web/rest layer.
- RestConfiguration() - Constructor for class org.springframework.xd.dirt.rest.RestConfiguration
-
- RestControllerAdvice - Class in org.springframework.xd.dirt.rest
-
Central class for behavior common to all REST controllers.
- RestControllerAdvice() - Constructor for class org.springframework.xd.dirt.rest.RestControllerAdvice
-
- RESTDeploymentState - Enum in org.springframework.xd.rest.domain
-
REST domain representation of org.springframework.xd.dirt.core.DeploymentUnitStatus.State.
- RestLogoutSuccessHandler - Class in org.springframework.xd.dirt.web.controller.support
-
Implementation of the LogoutSuccessHandler
that only returns an HTTP
status code of 200
.
- RestLogoutSuccessHandler() - Constructor for class org.springframework.xd.dirt.web.controller.support.RestLogoutSuccessHandler
-
- RESTModuleType - Enum in org.springframework.xd.rest.domain
-
Sibling of org.springframework.xd.module.ModuleType, but we don't want to drag that into client dependencies.
- RestTemplateMessageConverterUtil - Class in org.springframework.xd.rest.domain.support
-
Utility class that does two things:
Resets a RestTemplate
's message converters list to have json support come before xml.
Force injects JAXBContexts that know about our particular classes
- RestTemplateMessageConverterUtil() - Constructor for class org.springframework.xd.rest.domain.support.RestTemplateMessageConverterUtil
-
- RESULT_LOCATION - Static variable in class org.springframework.xd.integration.util.XdEnvironment
-
- retrieve(String, Date, Date, AggregateCounterOperations.Resolution) - Method in interface org.springframework.xd.rest.client.AggregateCounterOperations
-
Retrieve the information for the given named AggregateCounter
- retrieve(String) - Method in interface org.springframework.xd.rest.client.CounterOperations
-
Retrieve information about the given named counter.
- retrieve(String) - Method in interface org.springframework.xd.rest.client.FieldValueCounterOperations
-
Retrieve information about the given named field value counter.
- retrieve(String) - Method in interface org.springframework.xd.rest.client.GaugeOperations
-
Retrieve information about the given named gauge.
- retrieve(String, Date, Date, AggregateCounterOperations.Resolution) - Method in class org.springframework.xd.rest.client.impl.AggregateCounterTemplate
-
- retrieve(String) - Method in interface org.springframework.xd.rest.client.RichGaugeOperations
-
Display the value of the named Rich Gauge
- RetryOperations() - Method in class org.springframework.xd.analytics.metrics.redis.RedisRetryTemplate
-
- RichGauge - Class in org.springframework.xd.analytics.metrics.core
-
A gauge which stores the maximum, minimum and average in addition to the current value.
- RichGauge(String) - Constructor for class org.springframework.xd.analytics.metrics.core.RichGauge
-
Creates an "empty" gauge.
- RichGauge(String, double) - Constructor for class org.springframework.xd.analytics.metrics.core.RichGauge
-
- RichGauge(String, double, double, double, double, double, long) - Constructor for class org.springframework.xd.analytics.metrics.core.RichGauge
-
- RichGaugeCommands - Class in org.springframework.xd.shell.command
-
Commands for interacting with RichGauge analytics.
- RichGaugeCommands() - Constructor for class org.springframework.xd.shell.command.RichGaugeCommands
-
- RichGaugeHandler - Class in org.springframework.xd.analytics.metrics.integration
-
- RichGaugeHandler(RichGaugeRepository, String, double) - Constructor for class org.springframework.xd.analytics.metrics.integration.RichGaugeHandler
-
- richGaugeOperations() - Method in class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- RichGaugeOperations - Interface in org.springframework.xd.rest.client
-
Interface defining operations available when dealing with Rich Gauge.
- richGaugeOperations() - Method in interface org.springframework.xd.rest.client.SpringXDOperations
-
Returns the portion of the API for interaction with RichGauge.
- RichGaugeRepository - Interface in org.springframework.xd.analytics.metrics.core
-
A service for managing RichGauge instances.
- RichGaugeResource - Class in org.springframework.xd.rest.domain.metrics
-
The REST representation of a RichGauge.
- RichGaugeResource() - Constructor for class org.springframework.xd.rest.domain.metrics.RichGaugeResource
-
No-arg constructor for serialization frameworks.
- RichGaugeResource(String, double, double, double, double, double, long) - Constructor for class org.springframework.xd.rest.domain.metrics.RichGaugeResource
-
- RichGaugesController - Class in org.springframework.xd.dirt.rest.metrics
-
Exposes representations of
Gauge
s.
- RichGaugesController(RichGaugeRepository) - Constructor for class org.springframework.xd.dirt.rest.metrics.RichGaugesController
-
- RichGaugeSinkOptionsMetadata - Class in org.springframework.xd.analytics.metrics.metadata
-
Captures options for the rich-gauge
sink module.
- RichGaugeSinkOptionsMetadata() - Constructor for class org.springframework.xd.analytics.metrics.metadata.RichGaugeSinkOptionsMetadata
-
- RichGaugeTemplate - Class in org.springframework.xd.rest.client.impl
-
Implementation of the RichGauge part of the metrics API.
- RichGaugeTemplate(AbstractTemplate) - Constructor for class org.springframework.xd.rest.client.impl.RichGaugeTemplate
-
- rm(String, boolean, boolean) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- RolloverStrategyParser - Class in org.springframework.xd.integration.hadoop.config
-
Parser for the 'rollover-policy' element.
- RolloverStrategyParser() - Constructor for class org.springframework.xd.integration.hadoop.config.RolloverStrategyParser
-
- root - Variable in class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
- routingKey(String) - Method in class org.springframework.xd.test.fixtures.RabbitSink
-
Sets the routing key that will be used to route messages to the appropriate key.
- run() - Method in class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter.StreamReadingTask
-
- run(String...) - Method in class org.springframework.xd.batch.hsqldb.server.HsqlServerApplication
-
- run(String...) - Method in class org.springframework.xd.dirt.server.admin.AdminServerApplication
-
- run(String...) - Method in class org.springframework.xd.dirt.server.container.ContainerServerApplication
-
- run(String...) - Method in class org.springframework.xd.dirt.server.singlenode.SingleNodeApplication
-
- run(String...) - Method in class org.springframework.xd.yarn.XdYarnAdminInfoCommand
-
- RuntimeBatchConfigurer - Class in org.springframework.xd.dirt.batch
-
Spring XD runtime specific BatchConfigurer
.
- RuntimeBatchConfigurer() - Constructor for class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- RuntimeBatchConfigurer(DataSource) - Constructor for class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- RuntimeCommands - Class in org.springframework.xd.shell.command
-
Commands to interact with cluster for containers/modules.
- RuntimeCommands() - Constructor for class org.springframework.xd.shell.command.RuntimeCommands
-
- RuntimeContainerResourceAssembler - Class in org.springframework.xd.dirt.rest
-
- RuntimeContainerResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.RuntimeContainerResourceAssembler
-
- RuntimeContext - Class in org.springframework.xd.greenplum.support
-
Runtime context for load operations.
- RuntimeContext() - Constructor for class org.springframework.xd.greenplum.support.RuntimeContext
-
- runtimeDeploymentProperties - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer.ModuleDeployment
-
- RuntimeIOException - Exception in org.springframework.xd.dirt.core
-
Thrown when something goes wrong during some IO operation.
- RuntimeIOException(String, IOException) - Constructor for exception org.springframework.xd.dirt.core.RuntimeIOException
-
- RuntimeModuleDeploymentProperties - Class in org.springframework.xd.module
-
- RuntimeModuleDeploymentProperties() - Constructor for class org.springframework.xd.module.RuntimeModuleDeploymentProperties
-
- RuntimeModuleDeploymentPropertiesProvider - Class in org.springframework.xd.dirt.server.admin.deployment
-
- RuntimeModuleDeploymentPropertiesProvider(ModuleDeploymentPropertiesProvider<ModuleDeploymentProperties>) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.RuntimeModuleDeploymentPropertiesProvider
-
Construct a DefaultRuntimeModuleDeploymentPropertiesProvider
.
- runtimeOperations() - Method in class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- RuntimeOperations - Interface in org.springframework.xd.rest.client
-
Interface defining operations available against runtime container/modules.
- runtimeOperations() - Method in interface org.springframework.xd.rest.client.SpringXDOperations
-
Returns the portion of the API for interaction with runtime containers/modules.
- RuntimeTemplate - Class in org.springframework.xd.rest.client.impl
-
Implementation of the runtime containers/modules related part of the API.
- RuntimeTimeoutException - Exception in org.springframework.xd.dirt.core
-
Exception thrown when a blocking operation times out.
- RuntimeTimeoutException(String) - Constructor for exception org.springframework.xd.dirt.core.RuntimeTimeoutException
-
Construct a RuntimeTimeoutException
.
- RuntimeTimeoutException(String, TimeoutException) - Constructor for exception org.springframework.xd.dirt.core.RuntimeTimeoutException
-
Construct a RuntimeTimeoutException
.
- RuntimeUtils - Class in org.springframework.xd.dirt.util
-
Utilities for obtaining runtime information for the running process.
- RuntimeUtils() - Constructor for class org.springframework.xd.dirt.util.RuntimeUtils
-
- save(S) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryAggregateCounterRepository
-
- save(S) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- save(Iterable<S>) - Method in class org.springframework.xd.analytics.metrics.memory.InMemoryMetricRepository
-
- save(S) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- save(Iterable<S>) - Method in class org.springframework.xd.analytics.metrics.redis.RedisFieldValueCounterRepository
-
- save(Admin) - Method in interface org.springframework.xd.dirt.container.store.AdminRepository
-
Save the admin runtime attributes.
- save(Admin) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperAdminRepository
-
Save the admin runtime attributes.
- save(S) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- save(Iterable<S>) - Method in class org.springframework.xd.dirt.container.store.ZooKeeperContainerRepository
- save(R) - Method in interface org.springframework.xd.dirt.core.ResourceDeployer
-
- save(S) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- save(Iterable<S>) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleMetadataRepository
-
- save(String, String, boolean) - Method in class org.springframework.xd.dirt.rest.JobsController
-
- save(String, String, boolean) - Method in class org.springframework.xd.dirt.rest.XDController
-
Create a new resource definition.
- save(D) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- save(Iterable<S>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- save(S) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobDefinitionRepository
-
- save(S) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- save(Iterable<S>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperJobRepository
-
- save(Iterable<S>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- save(S) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamDefinitionRepository
-
- save(S) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- save(Iterable<S>) - Method in class org.springframework.xd.dirt.stream.zookeeper.ZooKeeperStreamRepository
-
- save(S) - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
- save(S) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- save(Iterable<S>) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
- save(Iterable<S>) - Method in class org.springframework.xd.store.AbstractRepository
-
- saveDependencies(ModuleDependencyRepository, ModuleDefinition, String) - Static method in class org.springframework.xd.dirt.module.support.ModuleDefinitionRepositoryUtils
-
- saveDependencies(ModuleDependencyRepository, StreamDefinition) - Static method in class org.springframework.xd.dirt.stream.StreamDefinitionRepositoryUtils
-
Save the dependencies of each module to its containing stream.
- scheduleDepartedContainerDeployer() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.ContainerListener
-
Schedules execution of DepartedContainerDeployer
on a regular basis.
- ScriptMixin - Class in org.springframework.xd.module.options.mixins
-
A standard mixin for modules that do some transformation based on a script.
- ScriptMixin() - Constructor for class org.springframework.xd.module.options.mixins.ScriptMixin
-
- ScriptModulePropertiesFactoryBean - Class in org.springframework.xd.extension.script
-
- ScriptModulePropertiesFactoryBean() - Constructor for class org.springframework.xd.extension.script.ScriptModulePropertiesFactoryBean
-
- SECURITY_AUTH_METHOD - Static variable in class org.springframework.xd.sqoop.SqoopRunner
-
- SECURITY_MAPREDUCE_JOBHISTORY_PRINCIPAL - Static variable in class org.springframework.xd.sqoop.SqoopRunner
-
- SECURITY_NAMENODE_PRINCIPAL - Static variable in class org.springframework.xd.sqoop.SqoopRunner
-
- SECURITY_RM_MANAGER_PRINCIPAL - Static variable in class org.springframework.xd.sqoop.SqoopRunner
-
- SECURITY_USER_KEYTAB - Static variable in class org.springframework.xd.sqoop.SqoopRunner
-
- SECURITY_USER_PRINCIPAL - Static variable in class org.springframework.xd.sqoop.SqoopRunner
-
- SecurityConfiguration - Class in org.springframework.xd.dirt.web.config
-
Setup Spring Security for the http endpoints of the application.
- SecurityConfiguration() - Constructor for class org.springframework.xd.dirt.web.config.SecurityConfiguration
-
- SecurityConfiguration.AuthorizationConfig - Class in org.springframework.xd.dirt.web.config
-
Holds configuration for the authorization aspects of security.
- SecurityConfiguration.AuthorizationConfig() - Constructor for class org.springframework.xd.dirt.web.config.SecurityConfiguration.AuthorizationConfig
-
- SecurityController - Class in org.springframework.xd.dirt.rest.security
-
Provides security-related meta information.
- SecurityController() - Constructor for class org.springframework.xd.dirt.rest.security.SecurityController
-
- SecurityInfoResource - Class in org.springframework.xd.rest.domain.security
-
Provides security related meta-information.
- SecurityInfoResource() - Constructor for class org.springframework.xd.rest.domain.security.SecurityInfoResource
-
Default constructor for serialization frameworks.
- SegmentRejectType - Enum in org.springframework.xd.greenplum.support
-
- select(String) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- select(String) - Method in interface org.springframework.xd.tuple.Tuple
-
Use SpEL expression to return a subset of the tuple that matches the expression
- selectPartition(Object, int) - Method in interface org.springframework.xd.dirt.integration.bus.PartitionSelectorStrategy
-
Determine the partition based on a key.
- send(Message<?>) - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChain
-
- send(Message<?>) - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainProducer
-
- send(Message<?>) - Method in class org.springframework.xd.dirt.test.source.AbstractSingleNodeNamedChannelSource
-
- send(Message<?>) - Method in interface org.springframework.xd.dirt.test.source.NamedChannelSource
-
- send(String) - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
Send data as a String to stdin.
- send(Message) - Method in class org.springframework.xd.spark.streaming.SparkMessageSender
-
Send a message out of Spark cluster.
- sendAndReceive(String) - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
Send and receive data in request/response fashion.
- sendBytes(byte[]) - Method in class org.springframework.xd.test.fixtures.SyslogTcpSource
-
Sends TCP traffic to a syslog source host and port.
- sendBytes(byte[]) - Method in class org.springframework.xd.test.fixtures.SyslogUdpSource
-
Sends UDP traffic to a syslog source host and port.
- sendBytes(byte[]) - Method in class org.springframework.xd.test.fixtures.TcpSource
-
Send the specified types to the host and and port of the TCP source.
- sendData(String) - Method in class org.springframework.xd.test.fixtures.JmsSource
-
Sends data to the JMS broker via TCP.
- sendData(String) - Method in class org.springframework.xd.test.fixtures.MqttSource
-
Sends a string via Mqtt to a Rabbit Mqtt Broker.
- sendData(String) - Method in class org.springframework.xd.test.fixtures.RabbitSource
-
Sends data to the RabbitMQ Broker.
- sendEmail(String, String, String) - Method in class org.springframework.xd.test.fixtures.AbstractMailSource
-
- sendPayload(Object) - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChain
-
- sendPayload(Object) - Method in class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainProducer
-
- sendPayload(Object) - Method in class org.springframework.xd.dirt.test.source.AbstractSingleNodeNamedChannelSource
-
- sendPayload(Object) - Method in interface org.springframework.xd.dirt.test.source.NamedChannelSource
-
- SEQUENCE - Static variable in interface org.springframework.xd.dirt.integration.bus.BusProperties
-
The sequence index of the module.
- SEQUENCE_KEY - Static variable in class org.springframework.xd.module.RuntimeModuleDeploymentProperties
-
Key for the sequence
property.
- SerializationException - Exception in org.springframework.xd.dirt.integration.bus
-
Thrown when something goes wrong with inter-module communication.
- SerializationException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.integration.bus.SerializationException
-
- serialize(Counter) - Method in class org.springframework.xd.analytics.metrics.redis.RedisCounterRepository
-
- serialize(T) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
Provide a String representation of the domain entity.
- SerializedToJavaMessageConverter - Class in org.springframework.xd.dirt.integration.bus.converter
-
A MessageConverter
to deserialize Serializable
Java objects.
- SerializedToJavaMessageConverter() - Constructor for class org.springframework.xd.dirt.integration.bus.converter.SerializedToJavaMessageConverter
-
- serializeId(String) - Method in class org.springframework.xd.analytics.metrics.redis.RedisCounterRepository
-
- serializeId(ID) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
Return a String representation of the domain ID.
- serializePayloadIfNecessary(Message<?>) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- ServerProcessUtils - Class in org.springframework.xd.distributed.util
-
Collection of utilities for starting external processes required
for a distributed XD system.
- ServerProcessUtils() - Constructor for class org.springframework.xd.distributed.util.ServerProcessUtils
-
- ServerTcpConnectionFactoryOptionsMetadataMixin - Class in org.springframework.xd.tcp
-
Mixin for options metadata that configure a server tcp connection factory.
- ServerTcpConnectionFactoryOptionsMetadataMixin() - Constructor for class org.springframework.xd.tcp.ServerTcpConnectionFactoryOptionsMetadataMixin
-
- sessionRepository() - Method in class org.springframework.xd.dirt.web.config.SecurityConfiguration
-
- setAbandonWhenPercentageFull(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setAccessToken(String) - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- setAccessTokenSecret(String) - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- setAckMode(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setAcknowledge(String) - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- setAckTimeoutOnServer(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setAddresses(String[]) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setAddresses(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- setAdminAddresses(String[]) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setAfterSqls(List<String>) - Method in class org.springframework.xd.greenplum.support.JdbcCommands
-
- setAggregation(String) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setAllowNullValues(Boolean) - Method in class org.springframework.xd.hadoop.fs.DatasetDefinitionFactoryBean
-
- setAllowUnknownKeys(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setAlpha(double) - Method in class org.springframework.xd.analytics.metrics.metadata.RichGaugeSinkOptionsMetadata
-
- setAlternateUsernameAllowed(boolean) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setAppJar(String) - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- setAppJar(String) - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.xd.dirt.module.ModuleDeployer
- setApplicationContext(ApplicationContext) - Method in class org.springframework.xd.dirt.plugins.AbstractPlugin
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.xd.dirt.server.container.ContainerRegistrar
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.xd.shell.hadoop.ConfigurationCommands
-
- setArgs(String) - Method in class org.springframework.xd.sqoop.SqoopOptionsMetadata
-
- setArguments(String[]) - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- setAsText(String) - Method in class org.springframework.xd.extension.process.DelimitedStringToMapPropertyEditor
-
- setAsync(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- setAttribute(String, String) - Method in class org.springframework.xd.dirt.event.AbstractEvent
-
- setAuthenticated(boolean) - Method in class org.springframework.xd.rest.domain.security.SecurityInfoResource
-
- setAuthenticationDatabaseName(String) - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- setAuthenticationEnabled(boolean) - Method in class org.springframework.xd.rest.domain.security.SecurityInfoResource
-
- setAutoCreateDir(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- setAutoCreateLocalDir(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- setAutoCreateLocalDir(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setAutoOffsetReset(AutoOffsetResetStrategy) - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- setAutoStartup(boolean) - Method in class org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper
-
Specify whether to start automatically.
- setAutoStartup(boolean) - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
Set the flag that indicates whether this connection
should be started automatically.
- setAutoStartup(boolean) - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
Sets the auto startup.
- setAutoStartup(boolean) - Method in class org.springframework.xd.integration.hadoop.config.DatasetWritingMessageHandlerFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.xd.integration.hadoop.config.HdfsStoreMessageHandlerFactoryBean
-
Sets the auto startup.
- setAutoStartup(boolean) - Method in class org.springframework.xd.integration.hadoop.config.HdfsWritingMessageHandlerFactoryBean
-
- setAutoStartup(boolean) - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
Sets the auto startup.
- setAutoStartup(boolean) - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsWritingMessageHandler
-
- setBaseFilename(String) - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- setBaseFilename(String) - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- setBaseFilename(String) - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- setBaseFilename(String) - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- setBaseFilename(String) - Method in class org.springframework.xd.integration.hadoop.config.HdfsWritingMessageHandlerFactoryBean
-
- setBasePath(String) - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- setBasePath(String) - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- setBasePath(String) - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- setBasePath(String) - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- setBasePath(String) - Method in class org.springframework.xd.integration.hadoop.config.HdfsWritingMessageHandlerFactoryBean
-
- setBasePath(Path) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the base path for the writer.
- setBatchBytes(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setBatchCount(int) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setBatchInterval(String) - Method in class org.springframework.xd.spark.streaming.DefaultSparkStreamingModuleOptionsMetadata
-
- setBatchPeriod(int) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setBatchTimeout(int) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setBcc(String) - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.xd.dirt.module.support.ThreadContextClassLoaderSetterAdvice
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.xd.integration.util.XdEnvironment
-
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.xd.module.core.ModuleFactory
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusAwareRouterBeanPostProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.xd.dirt.plugins.job.BatchJobRegistryBeanPostProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- setBeforeSqls(List<String>) - Method in class org.springframework.xd.greenplum.support.JdbcCommands
-
- setBinary(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- setBinary(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- setBlockOnBufferFull(boolean) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setBrokerList(String) - Method in class org.springframework.integration.x.kafka.KafkaSinkModuleOptionsMetadata
-
- setBufferMemory(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setBufferSize(int) - Method in class org.springframework.xd.tcp.encdec.EncoderDecoderMixins.BufferSizeMixin
-
- setByPassSystemClassLoaderForResources(boolean) - Method in class org.springframework.xd.module.support.ParentLastURLClassLoader
-
- setCacheEventExpression(String) - Method in class org.springframework.xd.gemfire.GemfireSourceOptionsMetadata
-
- setCc(String) - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- setCharset(String) - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- setCharset(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- setCharset(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- setCharset(String) - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
Set the charset name for String encoding.
- setCharset(String) - Method in class org.springframework.xd.http.HttpClientProcessorOptionsMetadata
-
- setCharset(String) - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- setCharset(String) - Method in class org.springframework.xd.module.options.mixins.FromStringCharsetMixin
-
- setCharset(String) - Method in class org.springframework.xd.module.options.mixins.ToStringCharsetMixin
-
- setCheckColumn(String) - Method in class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
- setCheckColumn(String) - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- setCleanSession(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- setCleanSql(String) - Method in class org.springframework.xd.greenplum.support.JdbcCommands
-
- setClientId(String) - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- setClientId(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- setClientId(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- setClientMode(int) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- setClientMode(int) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- setClientTimeZone(TimeZone) - Method in class org.springframework.xd.shell.Configuration
-
- setClobType(Integer) - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- setClose(boolean) - Method in class org.springframework.xd.tcp.ClientTcpConnectionFactoryOptionsMetadataMixin
-
- setCloseTimeout(long) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the close timeout for the writer.
- setCodec(Codec) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- setCodec(CodecInfo) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the codec for the writer.
- setCodec(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- setCodec(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
Set the type of Codec
to use to managing encoding and decoding of the data.
- setCodec(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setCodecInfoReference(Element, ParserContext, BeanDefinitionBuilder, String) - Static method in class org.springframework.xd.integration.hadoop.config.IntegrationHadoopNamespaceUtils
-
Sets the codec info reference.
- setCodecs(Map<String, Codec>) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setCollectionName(String) - Method in class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin
-
- setCollectionName(String) - Method in class org.springframework.xd.module.options.mixins.IntoMongoDbOptionMixin
-
- setCollectionType(RedisCollectionFactoryBean.CollectionType) - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- setColumn(String) - Method in class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
The name of the column to partition.
- setColumnDelimiter(Character) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setColumnNames(String) - Method in class org.springframework.xd.jdbc.JdbcMessagePayloadTransformer
-
- setColumnNames(String[]) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcBatchItemWriter
-
- setColumnNames(String) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- setColumnNames(String[]) - Method in class org.springframework.xd.jdbc.SingleTableDatabaseInitializer
-
Sets the column names which will be used to create a DDL definition
of the columns for the table.
- setColumns(String) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setColumns(String) - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- setColumns(String) - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- setColumns(String) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setColumns(String) - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- setColumns(String) - Method in class org.springframework.xd.jdbc.JdbcSinkModuleOptionsMetadata
-
- setCommand(String) - Method in class org.springframework.xd.extension.process.ShellModuleOptionsMetadata
-
- setCommand(String) - Method in class org.springframework.xd.sqoop.SqoopOptionsMetadata
-
- setCommitInterval(int) - Method in class org.springframework.xd.module.options.mixins.BatchJobCommitIntervalOptionMixin
-
- setComplete(boolean) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.ChunkContextInfo
-
- setComposedJob(boolean) - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
Set if this is a composed Job.
- setCompositeResolver(ModuleOptionsMetadataResolver) - Method in class org.springframework.xd.module.options.DefaultModuleOptionsMetadataResolver
-
- setCompressingPostProcessor(MessagePostProcessor) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
Set a MessagePostProcessor
to compress messages.
- setCompressionCodec(String) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setCompressionType(CompressionType) - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- setCompressionType(String) - Method in class org.springframework.xd.hadoop.fs.DatasetDefinitionFactoryBean
-
- setConcurrency(int) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setConf(String) - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- setConf(String) - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- setConfigName(String) - Method in class org.springframework.xd.module.options.EnvironmentAwareModuleOptionsMetadataResolver
-
- setConfigurableConversionService(ConfigurableConversionService) - Method in class org.springframework.xd.tuple.TupleBuilder.ConversionServiceBuilder
-
- setConfigurableConversionService(ConfigurableConversionService) - Method in class org.springframework.xd.tuple.TupleBuilder
-
- setConfiguration(Configuration) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the hadoop configuration for the writer.
- setConnectionProperties(String) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setConnectionTimeout(int) - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- setConnectTimeout(int) - Method in class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter
-
The connection timeout for making a connection to Twitter.
- setConnectTimeout(int) - Method in class org.springframework.integration.x.twitter.TwitterMixin
-
- setConsistencyLevel(ConsistencyLevel) - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- setConsumerKey(String) - Method in class org.springframework.integration.x.twitter.TwitterMixin
-
- setConsumerSecret(String) - Method in class org.springframework.integration.x.twitter.TwitterMixin
-
- setContactPoints(String) - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- setContainer(String) - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Set the container name.
- setContainer(String) - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Set the container name.
- setContainer(String) - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Set the container name.
- setContainerAttributes(ContainerAttributes) - Method in class org.springframework.xd.dirt.util.XdConfigLoggingInitializer
-
If not set, this property will default to null
.
- setContainerResolver(ContainerResolver) - Method in class org.springframework.xd.integration.fixtures.ModuleFixture
-
Set the container resolver to back sources that depend on runtime container information, e.g.
- setContentType(String) - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- setContentTypeResolver(ContentTypeResolver) - Method in class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
- setControlFile(String) - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- setControlFile(String) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- setControlFile(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setControlFile(ControlFile) - Method in class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- setControlFile(ControlFile) - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- setControlFile(ControlFile) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setControlFileResource(Resource) - Method in class org.springframework.xd.greenplum.support.ControlFileFactoryBean
-
- setConverterClass(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSinkOptionsMetadata
-
- setConverterClass(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setCorrelation(String) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setCount(int) - Method in class org.springframework.integration.x.kafka.WindowingOffsetManager
-
How many writes should be aggregated, before invoking the underlying OffsetManager
.
- setCount(int) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setCount(int) - Method in class org.springframework.xd.module.ModuleDeploymentProperties
-
Specify the number of container instances this module should be deployed to.
- setCounter(long) - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- setCounter(long) - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- setCounter(long) - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- setCreateDirectoryStructure(boolean) - Method in class org.springframework.xd.dirt.module.WritableResourceModuleRegistry
-
- setCriteria(String) - Method in class org.springframework.xd.module.ModuleDeploymentProperties
-
Specify the criteria expression to evaluate against container attributes to determine deployment candidates for this module.
- setCron(String) - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- setCronExpression(String) - Method in class org.springframework.xd.rest.domain.validation.CronValidation
-
- setCsvFormat() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setCsvFormat(Character, Character, String, String[], Character) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setData(Map<Integer, String>) - Method in class org.springframework.xd.shell.util.TableRow
-
- setDatabase(int) - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- setDatabase(String) - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- setDatabase(String) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- setDatabase(String) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setDatabaseName(String) - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- setDataSource(DataSource) - Method in class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
The data source for connecting to the database.
- setDataSource(DataSource) - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- setDataSource(DataSource) - Method in class org.springframework.xd.dirt.jdbc.util.DatabaseVendorFriendlyNameFactoryBean
-
- setDataSource(DataSource) - Method in class org.springframework.xd.dirt.job.dao.XdJdbcSearchableJobExecutionDao
-
- setDataSource(DataSource) - Method in class org.springframework.xd.greenplum.support.LoadFactoryBean
-
- setDataSource(DataSource) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- setDate(String) - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- setDateFormat(String) - Method in class org.springframework.xd.analytics.metrics.integration.AggregateCounterHandler
-
- setDateFormat(String) - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- setDateFormat(DateFormat) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
Will set the DateFormat
on the underlying DefaultJobParametersConverter
.
- setDateFormat(DateFormat) - Method in class org.springframework.xd.dirt.plugins.job.JobLaunchRequestTransformer
-
Will set the DateFormat
on the underlying DefaultJobParametersConverter
.
- setDateFormat(DateFormat) - Method in class org.springframework.xd.dirt.plugins.job.JobParametersBean
-
Will set the DateFormat
on the underlying DefaultJobParametersConverter
.
- setDateFormat(String) - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- setDateFormat(String) - Method in class org.springframework.xd.module.options.mixins.DateFormatMixin
-
- setDateFormat(DateFormat) - Method in class org.springframework.xd.tuple.batch.TupleFieldSetMapper
-
The
DateFormat
used by the resulting
Tuple
instance returned when converting strings to Dates.
- setDateFormatAsString(String) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
Allows for setting the DateFormat
using a String
.
- setDateFormatAsString(String) - Method in class org.springframework.xd.dirt.plugins.job.JobLaunchRequestTransformer
-
- setDateFormatAsString(String) - Method in class org.springframework.xd.dirt.plugins.job.JobParametersBean
-
- setDbHost(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setDbHost(String) - Method in class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- setDbkind(String) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setDbName(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setDbName(String) - Method in class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- setDbPassword(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setDbPassword(String) - Method in class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- setDbPort(int) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setDbPort(int) - Method in class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- setDbType(String) - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- setDbUser(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setDbUser(String) - Method in class org.springframework.xd.greenplum.support.GreenplumDataSourceFactoryBean
-
- setDecoder(EncoderDecoderMixins.Encoding) - Method in class org.springframework.xd.tcp.encdec.EncoderDecoderMixins.DecoderMixin
-
- setDecompressingPostProcessor(MessagePostProcessor) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
Set a MessagePostProcessor
to decompress messages.
- setDefaultAcknowledgeMode(AcknowledgeMode) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefaultAutoBindDLQ(boolean) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefaultAutoCommitOffsetEnabled(boolean) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
Set the default auto commit enabled property; This is used to commit the offset either automatically or
manually.
- setDefaultBackOffInitialInterval(long) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set the default retry back off initial interval for this bus; can be overridden with consumer
'backOffInitialInterval' property.
- setDefaultBackOffMaxInterval(long) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set the default retry back off max interval for this bus; can be overridden with consumer 'backOffMaxInterval'
property.
- setDefaultBackOffMultiplier(double) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set the default retry back off multiplier for this bus; can be overridden with consumer 'backOffMultiplier'
property.
- setDefaultBatchBufferLimit(int) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set the default batch buffer limit - used to send a batch early if its size exceeds this.
- setDefaultBatchingEnabled(boolean) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set whether this bus batches message sends by default.
- setDefaultBatchSize(int) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set the default batch size; only applies when batching is enabled and the bus supports batching.
- setDefaultBatchTimeout(long) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set the default batch timeout - used to send a batch if no messages arrive during this time.
- setDefaultChannelTransacted(boolean) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefaultCompress(boolean) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set whether compression will be used by producers, by default.
- setDefaultCompressionCodec(String) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setDefaultConcurrency(int) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set the default concurrency for this bus; can be overridden with consumer 'concurrency' property.
- setDefaultDefaultDeliveryMode(MessageDeliveryMode) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefaultDefaultRequeueRejected(boolean) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefaultDurableSubscription(boolean) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set whether subscriptions to taps/topics are durable.
- setDefaultFetchSize(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setDefaultMaxAttempts(int) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
The default maximum delivery attempts for this bus.
- setDefaultMaxConcurrency(int) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
Set the bus's default max consumers; can be overridden by consumer.maxConcurrency.
- setDefaultMaxWait(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setDefaultMinPartitionCount(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setDefaultPrefetchCount(int) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefaultPrefix(String) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefaultPropertiesString(String) - Method in class org.springframework.xd.mail.JavaMailPropertiesFactoryBean
-
- setDefaultQueueSize(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setDefaultReplicationFactor(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setDefaultReplyHeaderPatterns(String[]) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefaultRepublishToDLQ(boolean) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefaultRequestHeaderPatterns(String[]) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefaultRequiredAcks(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setDefaultTxSize(int) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setDefinition(String) - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- setDelay(long) - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- setDelegate(ModuleOptionsMetadataResolver) - Method in class org.springframework.xd.module.options.EnvironmentAwareModuleOptionsMetadataResolver
-
- setDelegates(ModuleRegistry...) - Method in class org.springframework.xd.dirt.module.DelegatingModuleRegistry
-
- setDelegates(List<ModuleInformationResolver>) - Method in class org.springframework.xd.module.info.DelegatingModuleInformationResolver
-
- setDelegates(List<ModuleOptionsMetadataResolver>) - Method in class org.springframework.xd.module.options.DelegatingModuleOptionsMetadataResolver
-
- setDelete(boolean) - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- setDeleted(boolean) - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
Set deleted flag explicitly if the job doesn't exist in job definition
- setDeleteFiles(boolean) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.FileDeletionStepExecutionListener
-
- setDeleteFiles(boolean) - Method in class org.springframework.xd.module.options.mixins.BatchJobDeleteFilesOptionMixin
-
- setDeleteRemoteFiles(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- setDeleteRemoteFiles(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setDelimited(boolean) - Method in class org.springframework.integration.x.twitter.TwitterStreamChannelAdapter
-
Whether "delimited=length" shoud be added to the query.
- setDelimited(boolean) - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- setDelimiter(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setDelimiter(Character) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setDelimiter(Character) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setDelimiter(String) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReader
-
- setDelimiter(String) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- setDelimiter(String) - Method in class org.springframework.xd.module.options.mixins.BatchJobFieldDelimiterOptionMixin
-
- setDeliveryMode(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSinkOptionsMetadata
-
- setDeployed(boolean) - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
Set deployed flag
- setDeployedModules(List<ModuleMetadata>) - Method in class org.springframework.xd.dirt.container.store.DetailedContainer
-
Set the deployed modules for this runtime container.
- setDeploymentAction(DeploymentAction) - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- setDeploymentProperties(Map<String, String>) - Method in class org.springframework.xd.dirt.core.Job.Builder
-
Set the deployment properties for the job.
- setDeploymentProperties(Map<String, String>) - Method in class org.springframework.xd.dirt.core.Stream.Builder
-
Set the deployment properties for the stream.
- setDeploymentProperties(Map<String, String>) - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- setDeployments(boolean) - Method in class org.springframework.xd.dirt.rest.XDController.QueryOptions
-
- setDeploymentSize(int) - Method in class org.springframework.xd.dirt.container.store.DetailedContainer
-
Set the number of deployed modules.
- setDeploymentUnitName(String) - Method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Set the deployment unit name.
- setDeploymentUnitName(String) - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Set the deployment unit name.
- setDestination(String) - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- setDir(String) - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- setDir(String) - Method in class org.springframework.xd.dirt.modules.metadata.FileSourceOptionsMetadata
-
- setDirectory(String) - Method in class org.springframework.xd.dirt.modules.metadata.FilePollHdfsJobOptionsMetadata
-
- setDirectory(String) - Method in class org.springframework.xd.dirt.modules.metadata.TimestampFileJobOptionsMetadata
-
- setDirectory(String) - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- setDirExpression(String) - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- setDiscardDeletes(boolean) - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- setDispatcher(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- setDispatcher(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
Set the name of the Dispatcher
to use, which will be pulled from the current Environment
.
- setDispatcher(Dispatcher) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
- setDispatcher(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setDriverClassName(String) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setDriverClassName(String) - Method in class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- setDurableSubscription(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- setEnableRetry(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setEnableSync(boolean) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Enables the syncable flag for the writer.
- setEnableTap(boolean) - Method in class org.springframework.xd.spark.streaming.DefaultSparkStreamingModuleOptionsMetadata
-
- setEncoder(EncoderDecoderMixins.Encoding) - Method in class org.springframework.xd.tcp.encdec.EncoderDecoderMixins.EncoderMixin
-
- setEncoding(String) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setEncoding(String) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setEndMessage(Object) - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerMessageHandler
-
- setEndMessage(String) - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerOptionsMetadata
-
- setEntityBasePackages(String[]) - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- setEnv(Environment) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setEnvironment(Environment) - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- setEnvironment(Map<String, String>) - Method in class org.springframework.batch.step.tasklet.x.ClasspathEnvironmentProvider
-
- setEnvironment(Map<String, String>) - Method in interface org.springframework.batch.step.tasklet.x.EnvironmentProvider
-
- setEnvironment(Environment) - Method in class org.springframework.xd.dirt.module.CustomModuleRegistryFactoryBean
-
- setEnvironment(Environment) - Method in class org.springframework.xd.dirt.module.WritableResourceModuleRegistry
-
- setEnvironment(Environment) - Method in class org.springframework.xd.dirt.server.container.ContainerServerApplication
-
- setEnvironment(Environment) - Method in class org.springframework.xd.dirt.server.SharedServerContextConfiguration.ZookeeperConnectionConfig
-
- setEnvironment(Environment) - Method in class org.springframework.xd.dirt.util.XdConfigLoggingInitializer
-
- setEnvironment(Map<String, String>) - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
A map containing environment variables to add to the process environment.
- setEnvironment(String) - Method in class org.springframework.xd.extension.process.ShellModuleOptionsMetadata
-
- setEnvironment(Map<String, String>) - Method in class org.springframework.xd.gpload.GploadEnvironmentProvider
-
- setEnvironment(Environment) - Method in class org.springframework.xd.module.options.EnvironmentAwareModuleOptionsMetadataResolver
-
- setEnvironment(Environment) - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- setEnvironment(Map<String, String>) - Method in class org.springframework.xd.sqoop.SqoopEnvironmentProvider
-
- setErrorChannel(MessageChannel) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setErrorHandler(ErrorHandler) - Method in class org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper
-
Provide an ErrorHandler
to be invoked if an Exception is thrown from the ZooKeeper server thread.
- setErrorMessage(String) - Method in class org.springframework.xd.rest.domain.validation.CronValidation
-
- setEscape(Character) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setEscape(Character) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setExchange(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSinkOptionsMetadata
-
- setExecutor(Executor) - Method in class org.springframework.integration.x.http.NettyHttpInboundChannelAdapter
-
- setExecutorCorePoolSize(int) - Method in class org.springframework.xd.dirt.integration.bus.local.LocalMessageBus
-
Set the ThreadPoolTaskExecutor
} core pool size to limit the number of concurrent
threads.
- setExecutorKeepAliveSeconds(int) - Method in class org.springframework.xd.dirt.integration.bus.local.LocalMessageBus
-
Set the ThreadPoolTaskExecutor
} keep alive seconds.
- setExecutorMaxPoolSize(int) - Method in class org.springframework.xd.dirt.integration.bus.local.LocalMessageBus
-
Set the ThreadPoolTaskExecutor
} max pool size to limit the number of concurrent
threads.
- setExecutorQueueSize(int) - Method in class org.springframework.xd.dirt.integration.bus.local.LocalMessageBus
-
Set the ThreadPoolTaskExecutor
} queue size to limit the number of concurrent
threads.
- setExpression(String) - Method in class org.springframework.xd.dirt.modules.metadata.LogSinkOptionsMetadata
-
- setExpression(String) - Method in class org.springframework.xd.dirt.modules.metadata.SplitterProcessorOptionsMetadata
-
- setExpression(String) - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- setExpression(String) - Method in class org.springframework.xd.module.options.mixins.ExpressionOrScriptMixin
-
- setExternalTable(ReadableTable) - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- setExternalTable(ReadableTable) - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- setFairQueue(boolean) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setFetchMaxBytes(int) - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- setFetchMaxWait(int) - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- setFetchMinBytes(int) - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- setFetchSize(int) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- setFieldName(String) - Method in class org.springframework.xd.analytics.metrics.metadata.FieldValueCounterSinkOptionsMetadata
-
- setFileDelay(long) - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- setFileExtension(String) - Method in class org.springframework.xd.dirt.modules.metadata.FilePollHdfsJobOptionsMetadata
-
- setFileExtension(String) - Method in class org.springframework.xd.dirt.modules.metadata.TimestampFileJobOptionsMetadata
-
- setFileExtension(String) - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- setFileName(String) - Method in class org.springframework.xd.dirt.modules.metadata.FilePollHdfsJobOptionsMetadata
-
- setFileName(String) - Method in class org.springframework.xd.dirt.modules.metadata.TimestampFileJobOptionsMetadata
-
- setFileName(String) - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- setFilenamePattern(String) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- setFileOpenAttempts(int) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the file open attempts for the writer.
- setFiles(String) - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- setFiles(String) - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- setFileSuffix(String) - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- setFileSuffix(String) - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- setFileSuffix(String) - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- setFileSuffix(String) - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- setFileSuffix(String) - Method in class org.springframework.xd.integration.hadoop.config.HdfsWritingMessageHandlerFactoryBean
-
- setFilterLevel(TwitterStreamChannelAdapter.FilterLevel) - Method in class org.springframework.integration.x.twitter.TwitterStreamChannelAdapter
-
One of "none", "low" or "medium"
- setFilterLevel(TwitterStreamChannelAdapter.FilterLevel) - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- setFixedDelay(int) - Method in class org.springframework.xd.dirt.modules.metadata.FileSourceOptionsMetadata
-
- setFixedDelay(int) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- setFixedDelay(int) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setFixedDelay(int) - Method in class org.springframework.xd.dirt.modules.metadata.TimeSourceOptionsMetadata
-
- setFixedDelay(Integer) - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- setFixedDelay(int) - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- setFixedDelay(int) - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- setFixedDelay(int) - Method in class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin
-
- setFixedDelay(int) - Method in class org.springframework.xd.tcp.TcpClientSourceOptionsMetadata
-
- setFlushCount(int) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setFlushTime(int) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setFlushTimeout(long) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the flush timeout for the writer.
- setFolder(String) - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- setFollow(String) - Method in class org.springframework.integration.x.twitter.TwitterStreamChannelAdapter
-
Restrict the stream to a user or users.
- setFollow(String) - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- setForceQuote(String[]) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setForceQuote(String[]) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setFormat(String) - Method in class org.springframework.xd.dirt.modules.metadata.TimeSourceOptionsMetadata
-
- setFormat(String) - Method in class org.springframework.xd.dirt.modules.metadata.TimestampFileJobOptionsMetadata
-
- setFormat(Format) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setFormat(String) - Method in class org.springframework.xd.hadoop.fs.DatasetDefinitionFactoryBean
-
- setFormatHeader(boolean) - Method in class org.springframework.xd.greenplum.support.ReadableTable
-
- setFormats(Locale, DateFormat) - Method in class org.springframework.xd.tuple.TupleBuilder
-
- setFraming(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- setFraming(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
Set the type of framing to use.
- setFraming(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setFrom(String) - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- setFromEnd(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- setFs(String) - Method in class org.springframework.xd.shell.hadoop.ConfigurationCommands
-
- setFsUri(String) - Method in class org.springframework.xd.module.options.mixins.HadoopConfigurationMixin
-
- setGaugeValue(Gauge, long) - Static method in class org.springframework.xd.analytics.metrics.core.MetricUtils
-
- setGeocode(String) - Method in class org.springframework.integration.x.twitter.TwitterSearchChannelAdapter
-
- setGeocode(String) - Method in class org.springframework.integration.x.twitter.TwitterSearchOptionsMetadata
-
- setGploadHome(String) - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- setGploadHome(String) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- setGploadInputDelimiter(Character) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setGploadOutputMatchColumns(List<String>) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setGploadOutputMode(ControlFile.OutputMode) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setGploadOutputTable(String) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setGploadOutputUpdateColumns(List<String>) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setGploadOutputUpdateCondition(String) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setGreenplumLoad(GreenplumLoad) - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistMessageHandler
-
- setGroup(String) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Set the module group.
- setGroupId(String) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setGroupName(String) - Method in class org.springframework.xd.dirt.plugins.job.BatchJobRegistryBeanPostProcessor
-
- setGroupName(String) - Method in class org.springframework.xd.dirt.plugins.job.ModuleJobLauncher
-
- setGroupRoleAttribute(String) - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- setGroupSearchBase(String) - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- setGroupSearchFilter(String) - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- setHADOOP_DISTRO(String) - Method in class org.springframework.xd.dirt.server.options.CommonOptions
-
- setHadoopProperties(Properties) - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- setHost(String) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- setHost(String) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- setHost(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setHost(String) - Method in class org.springframework.xd.gemfire.GemfireHostPortMixin
-
- setHost(String) - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- setHost(String) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- setHost(String) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setHost(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- setHost(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
Set the host to which this server will bind.
- setHost(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setHost(String) - Method in class org.springframework.xd.mail.MailServerMixin
-
- setHost(String) - Method in class org.springframework.xd.module.options.mixins.FtpConnectionMixin
-
- setHost(String) - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- setHost(String) - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- setHost(String) - Method in class org.springframework.xd.tcp.ClientTcpConnectionFactoryOptionsMetadataMixin
-
- setHostname(String) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setHostname(String) - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- setHttpMethod(HttpClientProcessorOptionsMetadata.HttpMethod) - Method in class org.springframework.xd.http.HttpClientProcessorOptionsMetadata
-
- setHttps(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.HttpSourceOptionsMetadata
-
- setIdField(String) - Method in class org.springframework.xd.dirt.modules.metadata.HdfsMongodbJobOptionsMetadata
-
- setIdField(String) - Method in class org.springframework.xd.mongodb.TupleWriteConverter
-
Set the tuple field name which will be used as the Mongo _id.
- setIdleTimeout(long) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the idle timeout for the writer.
- setIncludeEntities(boolean) - Method in class org.springframework.integration.x.twitter.TwitterSearchChannelAdapter
-
- setIncludeEntities(boolean) - Method in class org.springframework.integration.x.twitter.TwitterSearchOptionsMetadata
-
- setIncrementExpression(String) - Method in class org.springframework.xd.analytics.metrics.metadata.AggregateCounterSinkOptionsMetadata
-
- setIndex(int) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Set the module index.
- setIngestQuery(String) - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- setInitialDelay(int) - Method in class org.springframework.xd.module.options.mixins.PeriodicTriggerMixin
-
- setInitializeDatabase(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setInitializeDatabase(boolean) - Method in class org.springframework.xd.jdbc.AbstractImportToJdbcOptionsMetadata
-
- setInitializerScript(String) - Method in class org.springframework.xd.jdbc.AbstractImportToJdbcOptionsMetadata
-
- setInitialOffsets(String) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setInitialRetryInterval(int) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setInitialSize(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setInitScript(String) - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- setInitSQL(String) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setInputSourceFile(String) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.xd.reactor.MultipleBroadcasterMessageHandler
-
- setIntegrationEvaluationContext(EvaluationContext) - Method in class org.springframework.xd.rxjava.MultipleSubjectMessageHandler
-
- setInUsePrefix(String) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the in use prefix for the writer.
- setInUseSuffix(String) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the in use suffix for the writer.
- setIp(String) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- setIp(String) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- setIsolationLevel(String) - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- setIsolationLevelForCreate(String) - Method in class org.springframework.xd.dirt.plugins.job.support.JobLaunchingJobRepositoryFactoryBean
-
public setter for the isolation level to be used for the transaction when
job execution entities are initially created.
- setJdbcInterceptors(String) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setJdbcTemplate(JdbcOperations) - Method in class org.springframework.xd.dirt.plugins.job.DistributedJobLocator
-
- setJdbcTemplate(JdbcTemplate) - Method in class org.springframework.xd.greenplum.support.JdbcCommands
-
- setJmxEnabled(boolean) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setJobExplorer(JobExplorer) - Method in class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
- setJobExplorer(JobExplorer) - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- setJobLocator(DistributedJobLocator) - Method in class org.springframework.xd.dirt.plugins.job.BatchJobRegistryBeanPostProcessor
-
- setJobName(String) - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Set the job name.
- setJobRegistry(JobRegistry) - Method in class org.springframework.xd.dirt.plugins.job.BatchJobRegistryBeanPostProcessor
-
- setKafkaOffsetTopicBatchBytes(int) - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- setKafkaOffsetTopicBatchTime(int) - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- setKafkaOffsetTopicMaxSize(int) - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- setKafkaOffsetTopicName(String) - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- setKafkaOffsetTopicRequiredAcks(int) - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- setKafkaOffsetTopicRetentionTime(int) - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- setKafkaOffsetTopicSegmentSize(int) - Method in class org.springframework.integration.x.kafka.KafkaOffsetTopicOptionsMixin
-
- setKeepAliveInterval(int) - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- setKeeptable(boolean) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setKey(String) - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- setKeyExpression(String) - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- setKeyExpression(String) - Method in class org.springframework.xd.gemfire.GemfireServerSinkModuleOptionsMetadata
-
- setKeyspace(String) - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- setKnownHostsExpression(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setLanguage(String) - Method in class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter
-
Filter tweets by language or languages.
- setLanguage(String) - Method in class org.springframework.integration.x.twitter.TwitterMixin
-
- setLengthFieldLength(int) - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- setLengthFieldLength(int) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
Set the length of the length field if using length-field framing.
- setLengthFieldLength(int) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setLevel(String) - Method in class org.springframework.xd.dirt.modules.metadata.LogSinkOptionsMetadata
-
- setLibjars(String) - Method in class org.springframework.xd.sqoop.SqoopOptionsMetadata
-
- setLibjars(String) - Method in class org.springframework.xd.sqoop.SqoopTasklet
-
- setLike(String) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setLike(String) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setLineAggregator(LineAggregator<T>) - Method in class org.springframework.xd.batch.item.hadoop.HdfsTextItemWriter
-
Public setter for the LineAggregator
.
- setLineAggregator(LineAggregator<T>) - Method in class org.springframework.xd.batch.item.hadoop.SimpleHdfsTextItemWriter
-
Public setter for the LineAggregator
.
- setLines(int) - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- setListeners(String) - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- setLoadConfiguration(LoadConfiguration) - Method in class org.springframework.xd.greenplum.support.LoadFactoryBean
-
- setLocalDir(String) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- setLocalDir(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setLocations(String) - Method in class org.springframework.integration.x.twitter.TwitterStreamChannelAdapter
-
Bound the returned tweets by location(s).
- setLocations(String) - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- setLocations(List<String>) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setLocations(List<String>) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setLocations(List<String>) - Method in class org.springframework.xd.greenplum.support.RuntimeContext
-
- setLogAbandoned(boolean) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setLogErrorsInto(String) - Method in class org.springframework.xd.greenplum.support.ReadableTable
-
- setLogErrorsInto(String) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setMainClass(String) - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- setMainClass(String) - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- setMakeParametersUnique(boolean) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
If not set, this property defaults to true
.
- setMakeParametersUnique(boolean) - Method in class org.springframework.xd.dirt.plugins.job.JobLaunchRequestTransformer
-
If not set, this property defaults to true
.
- setMakeParametersUnique(boolean) - Method in class org.springframework.xd.dirt.plugins.job.JobParametersBean
-
If not set, this property defaults to true
.
- setMakeUnique(boolean) - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- setManagementPort(Integer) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- setManagementPort(String) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- setManagerDn(String) - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- setManagerPassword(String) - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- setMappedRequestHeaders(String) - Method in class org.springframework.xd.module.options.mixins.MappedRequestHeadersMixin
-
- setMappedResponseHeaders(String) - Method in class org.springframework.xd.module.options.mixins.MappedResponseHeadersMixin
-
- setMappings(Map<String, String>) - Method in class org.springframework.xd.dirt.jdbc.util.DatabaseVendorFriendlyNameFactoryBean
-
- setMarkAsRead(boolean) - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- setMaster(String) - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- setMaster(String) - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- setMatchColumns(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setMatchColumns(List<String>) - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- setMatchColumns(String[]) - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- setMaxActive(int) - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- setMaxActive(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setMaxAge(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setMaxAttempts(int) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setMaxBufferTime(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setMaxConcurrency(int) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setMaxContentLength(int) - Method in class org.springframework.integration.x.http.NettyHttpInboundChannelAdapter
-
Set the max content length; default 1Mb.
- setMaxContentLength(int) - Method in class org.springframework.xd.dirt.modules.metadata.HttpSourceOptionsMetadata
-
- setMaxIdle(int) - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- setMaxIdle(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setMaxMessages(long) - Method in class org.springframework.xd.module.options.mixins.MaxMessagesDefaultOneMixin
-
- setMaxMessages(long) - Method in class org.springframework.xd.module.options.mixins.MaxMessagesDefaultUnlimitedMixin
-
- setMaxRequestSize(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setMaxRetryInterval(int) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setMaxRowsPerPoll(int) - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- setMaxSendDuration(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setMaxSendRetries(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setMaxVarCharLength(int) - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- setMaxWait(int) - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- setMaxWait(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setMaxWidth(int) - Method in class org.springframework.xd.shell.util.TableHeader
-
Defaults to -1 indicating to ignore the property.
- setMbean(String) - Method in class org.springframework.xd.integration.util.jmxresult.JMXRequest
-
- setMeanErrorRate(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setMeanErrorRatio(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setMeanSendDuration(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setMeanSendRate(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.x.http.NettyHttpInboundChannelAdapter
-
- setMessageConverterClass(String) - Method in class org.springframework.xd.dirt.modules.metadata.HttpSourceOptionsMetadata
-
- setMessageRates(Map<String, HashMap<String, Double>>) - Method in class org.springframework.xd.dirt.container.store.DetailedContainer
-
Set the messageRates for the individual deployed modules.
- setMetricsEnabled(boolean) - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- setMinEvictableIdleTimeMillis(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setMinIdle(int) - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- setMinIdle(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setMinSendDuration(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setMode(KafkaMessageBus.Mode) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setMode(FileReadingMode) - Method in class org.springframework.xd.dirt.modules.metadata.FileAsRefMixin
-
- setMode(FileSinkOptionsMetadata.Mode) - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- setMode(FileSinkOptionsMetadata.Mode) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- setMode(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setMode(Mode) - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- setMode(Mode) - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- setModuleChannel(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setModuleDefinition(ModuleDefinition) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
- setModuleDefinitions(List<ModuleDefinition>) - Method in class org.springframework.xd.dirt.core.BaseDefinition
-
- setModuleDescriptor(ModuleDescriptor) - Method in class org.springframework.xd.dirt.core.Job.Builder
-
Set the module descriptor for this job.
- setModuleDescriptors(Deque<ModuleDescriptor>) - Method in class org.springframework.xd.dirt.core.Stream.Builder
-
Set the module descriptors for this stream.
- setModuleLabel(String) - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Set the module label.
- setModuleLabel(String) - Method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Set the module label.
- setModuleLabel(String) - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Set the module label.
- setModuleLabel(String) - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Set the module label.
- setModuleLabel(String) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Set the module label.
- setModuleName(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setModuleName(String) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Set the module name.
- setModules(ArrayList<Module>) - Method in class org.springframework.xd.integration.util.jmxresult.JMXValue
-
- setModuleSequence(String) - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
-
Set the module sequence.
- setModuleSequence(String) - Method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Set the module sequence.
- setModuleSequence(String) - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Set the module sequence.
- setModuleSequence(String) - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Set the module sequence.
- setModuleType(String) - Method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
-
Set the module type.
- setModuleType(String) - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
-
Set the module type.
- setModuleType(String) - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Set the module type.
- setName(String) - Method in class org.springframework.xd.analytics.metrics.metadata.MetricNameMixin
-
- setName(String) - Method in class org.springframework.xd.dirt.core.Job.Builder
-
Set the job name.
- setName(String) - Method in class org.springframework.xd.dirt.core.Stream.Builder
-
Set the stream name.
- setName(String) - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- setName(String) - Method in class org.springframework.xd.dirt.modules.metadata.LogSinkOptionsMetadata
-
- setName(String) - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- setName(String) - Method in class org.springframework.xd.shell.util.TableHeader
-
- setName(String) - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- setName(String) - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- setNameExpression(String) - Method in class org.springframework.xd.analytics.metrics.metadata.MetricNameMixin
-
- setNameExpression(String) - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- setNames(String) - Method in class org.springframework.xd.module.options.mixins.BatchJobFieldNamesOptionMixin
-
- setNames(List<String>) - Method in class org.springframework.xd.tuple.batch.TupleFieldExtractor
-
An ordered list of field names to be extracted from each item.
- setNamingStrategy(FileNamingStrategy) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the naming strategy.
- setNativeOptions(String) - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- setNextExecutionTime(Date) - Method in class org.springframework.xd.rest.domain.validation.CronValidation
-
- setNio(boolean) - Method in class org.springframework.xd.syslog.SyslogTcpSourceOptionsMetadata
-
- setNio(boolean) - Method in class org.springframework.xd.tcp.AbstractTcpConnectionFactoryOptionsMetadata
-
- setNodes(String[]) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setNullString(String) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setNullString(String) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setNumberFormat(NumberFormat) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
Setter for the NumberFormat
which is set on the underlying DefaultJobParametersConverter
.
- setNumberFormat(NumberFormat) - Method in class org.springframework.xd.dirt.plugins.job.JobLaunchRequestTransformer
-
Setter for the NumberFormat
which is set on the underlying DefaultJobParametersConverter
.
- setNumberFormat(NumberFormat) - Method in class org.springframework.xd.dirt.plugins.job.JobParametersBean
-
Setter for the NumberFormat
which is set on the underlying DefaultJobParametersConverter
.
- setNumberFormat(String) - Method in class org.springframework.xd.dirt.plugins.job.JobPluginMetadataResolver.JobOptionsMetadata
-
- setNumberFormatAsString(String) - Method in class org.springframework.xd.dirt.plugins.job.ExpandedJobParametersConverter
-
Allows for setting the NumberFormat
using a String
.
- setNumberFormatAsString(String) - Method in class org.springframework.xd.dirt.plugins.job.JobLaunchRequestTransformer
-
- setNumberFormatAsString(String) - Method in class org.springframework.xd.dirt.plugins.job.JobParametersBean
-
- setOffsetManagement(KafkaMessageBus.OffsetManagement) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOffsetStorage(KafkaSourceModuleOptionsMetadata.OffsetStorageStrategy) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setOffsetStoreBatchBytes(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOffsetStoreBatchTime(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOffsetStoreMaxFetchSize(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOffsetStoreRequiredAcks(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOffsetStoreRetentionTime(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOffsetStoreSegmentSize(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOffsetStoreTopic(String) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOffsetUpdateCount(int) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setOffsetUpdateCount(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOffsetUpdateShutdownTimeout(int) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setOffsetUpdateShutdownTimeout(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOffsetUpdateTimeWindow(int) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setOffsetUpdateTimeWindow(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setOperations - Variable in class org.springframework.xd.analytics.metrics.redis.RedisAggregateCounterRepository
-
- setOptions(String) - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- setOptions(String) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- setOutputChannel(MessageChannel) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setOverride(String) - Method in class org.springframework.xd.dirt.jdbc.util.DatabaseVendorFriendlyNameFactoryBean
-
- setOverrideValue(Long) - Method in class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
- setOverwrite(boolean) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the file overwrite flag for the writer.
- setOwner(String) - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- setParameter(String, String) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Set a module parameter.
- setParentContext(ApplicationContext) - Method in class org.springframework.xd.module.core.CompositeModule
-
- setParentContext(ApplicationContext) - Method in interface org.springframework.xd.module.core.Module
-
set a parent application context
- setParentContext(ApplicationContext) - Method in class org.springframework.xd.module.core.SimpleModule
-
- setPartitionClause(String) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- setPartitionColumn(String) - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- setPartitionExpression(String) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the partition expression.
- setPartitionPath(String) - Method in class org.springframework.xd.hadoop.fs.DatasetDefinitionFactoryBean
-
- setPartitionResultsTimeout(long) - Method in class org.springframework.xd.module.options.mixins.BatchJobSinglestepPartitionSupportOptionMixin
-
- setPartitions(int) - Method in class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
The number of partitions to create.
- setPartitions(String) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setPartitions(int) - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- setPartitionSelector(PartitionSelectorStrategy) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Set the partition strategy to be used by this bus if no partitionExpression is provided for a module.
- setPassPhrase(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setPassword(String) - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- setPassword(String) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setPassword(String) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setPassword(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- setPassword(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- setPassword(String) - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- setPassword(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setPassword(String) - Method in class org.springframework.xd.dirt.web.controller.support.AuthenticationRequest
-
- setPassword(String) - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- setPassword(String) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- setPassword(String) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setPassword(Password) - Method in class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- setPassword(String) - Method in class org.springframework.xd.mail.MailServerMixin
-
- setPassword(Password) - Method in class org.springframework.xd.module.options.mixins.FtpConnectionMixin
-
- setPassword(String) - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- setPassword(String) - Method in class org.springframework.xd.shell.Target.Credentials
-
- setPassword(String) - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- setPasswordFile(String) - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- setPasswordFile(String) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- setPath(String) - Method in class org.springframework.xd.spark.streaming.examples.java.FileLogger
-
- setPath(String) - Method in class org.springframework.xd.spark.streaming.examples.java.FileLoggerModuleOptionsMetadata
-
- setPathReference(Element, ParserContext, BeanDefinitionBuilder, String, String) - Static method in class org.springframework.xd.integration.hadoop.config.IntegrationHadoopNamespaceUtils
-
Sets the path reference.
- setPattern(String) - Method in class org.springframework.xd.dirt.modules.metadata.FileSourceOptionsMetadata
-
- setPattern(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setPayload(Object) - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
Set the payload
- setPayload(String) - Method in class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- setPersistence(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- setPersistenceDirectory(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- setPhase(int) - Method in class org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper
-
Specify the lifecycle phase for the embedded server.
- setPhase(int) - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
Sets the phase.
- setPhase(int) - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
Sets the phase.
- setPhase(int) - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsWritingMessageHandler
-
- setPid(Integer) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- setPid(Integer) - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
-
- setPoller(PollerMetadata) - Method in class org.springframework.xd.dirt.integration.bus.local.LocalMessageBus
-
Set the poller to use when QueueChannels are used.
- setPort(int) - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- setPort(Integer) - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
-
- setPort(int) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setPort(int) - Method in class org.springframework.xd.dirt.modules.metadata.HttpSourceOptionsMetadata
-
- setPort(int) - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- setPort(int) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setPORT(int) - Method in class org.springframework.xd.dirt.server.options.AdminOptions
-
- setPORT(int) - Method in class org.springframework.xd.dirt.server.options.SingleNodeOptions
-
- setPort(String) - Method in class org.springframework.xd.gemfire.GemfireHostPortMixin
-
- setPort(Integer) - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- setPort(Integer) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- setPort(int) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setPort(Integer) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setPort(int) - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- setPort(int) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerFactoryBean
-
Set the port to which this server will bind.
- setPort(int) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setPort(int) - Method in class org.springframework.xd.mail.MailServerMixin
-
- setPort(int) - Method in class org.springframework.xd.module.options.mixins.FtpConnectionMixin
-
- setPort(int) - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- setPort(int) - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- setPort(int) - Method in class org.springframework.xd.syslog.SyslogSourceOptionsMetadata
-
- setPort(int) - Method in class org.springframework.xd.tcp.ClientTcpConnectionFactoryOptionsMetadataMixin
-
- setPort(int) - Method in class org.springframework.xd.tcp.ServerTcpConnectionFactoryOptionsMetadataMixin
-
- setPrefetch(int) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setPrefix(String) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
Change the prefix after creation.
- setPrepareSql(String) - Method in class org.springframework.xd.greenplum.support.JdbcCommands
-
- setPreserveTimestamp(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- setPrettyPrint(boolean) - Method in class org.springframework.xd.dirt.integration.bus.converter.PojoToJsonMessageConverter
-
- setPrettyPrint(boolean) - Method in class org.springframework.xd.dirt.integration.bus.converter.TupleToJsonMessageConverter
-
- setPreventDuplicates(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.FileSourceOptionsMetadata
-
- setPrivateKey(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setProgramArgs(String) - Method in class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- setProgramArgs(String) - Method in class org.springframework.xd.spark.tasklet.SparkTasklet
-
- setProperties(String) - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- setPropertiesFile(String) - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- setPropertiesFileString(String) - Method in class org.springframework.xd.mail.JavaMailPropertiesFactoryBean
-
- setPropertiesLocation(String) - Method in class org.springframework.xd.module.options.mixins.ScriptMixin
-
- setPropertiesString(String) - Method in class org.springframework.xd.mail.JavaMailPropertiesFactoryBean
-
- setProperty(String) - Method in class org.springframework.xd.shell.hadoop.ConfigurationCommands
-
- setProtocol(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorPeerInboundChannelAdapterConfiguration
-
- setProtocol(MailProtocol) - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- setProvider(String) - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- setPubSub(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- setQos(int) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- setQos(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- setQuery(String) - Method in class org.springframework.integration.x.twitter.TwitterSearchChannelAdapter
-
- setQuery(String) - Method in class org.springframework.integration.x.twitter.TwitterSearchOptionsMetadata
-
- setQuery(String) - Method in class org.springframework.xd.gemfire.GemfireCQSourceOptionsMetadata
-
- setQuery(String) - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- setQuery(String) - Method in class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin
-
- setQueryType(CassandraMessageHandler.Type) - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- setQueue(String) - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- setQueueExpression(String) - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- setQueues(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setQueueSize(int) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setQueueSize(int) - Method in class org.springframework.xd.dirt.integration.bus.local.LocalMessageBus
-
Set the size of the queue when using QueueChannel
s.
- setQuote(Character) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setQuote(Character) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setRateInterval(int) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setRateInterval(int) - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistMessageHandler
-
- setReadTimeout(int) - Method in class org.springframework.integration.x.twitter.AbstractTwitterInboundChannelAdapter
-
The read timeout for the underlying URLConnection to the twitter stream.
- setReadTimeout(int) - Method in class org.springframework.integration.x.twitter.TwitterMixin
-
- setReceiveBufferBytes(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setReceiveCount(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setReceiveErrorCount(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setReconnectBackoff(long) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.xd.analytics.metrics.redis.RedisRetryTemplate
-
- setRedirectErrorStream(boolean) - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
Set to true to redirect stderr to stdout.
- setRedirectErrorStream(boolean) - Method in class org.springframework.xd.extension.process.ShellModuleOptionsMetadata
-
- setRegexPattern(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setRegionName(String) - Method in class org.springframework.xd.gemfire.GemfireServerSinkModuleOptionsMetadata
-
- setRegionName(String) - Method in class org.springframework.xd.gemfire.GemfireSourceOptionsMetadata
-
- setRelease(String) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setRemoteDir(String) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- setRemoteDir(String) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- setRemoteDir(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setRemoteFileSeparator(String) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- setRemoteFileSeparator(String) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- setRemoveAbandoned(boolean) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setRemoveAbandonedTimeout(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setReOpen(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- setrep(String, int, boolean, boolean) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- setReplyTimeout(int) - Method in class org.springframework.xd.http.HttpClientProcessorOptionsMetadata
-
- setReplyTo(String) - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- setRequest(JMXRequest) - Method in class org.springframework.xd.integration.util.jmxresult.JMXChannelResult
-
- setRequest(JMXRequest) - Method in class org.springframework.xd.integration.util.jmxresult.JMXResult
-
- setRequest(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setRequestId(String) - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- setRequestRequiredAck(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setRequeue(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setRequireHashFiles(boolean) - Method in class org.springframework.xd.dirt.module.ResourceModuleRegistry
-
- setRequiresHashFiles(boolean) - Method in class org.springframework.xd.dirt.module.CustomModuleRegistryFactoryBean
-
- setResourceLoader(ResourceLoader) - Method in class org.springframework.xd.mail.JavaMailPropertiesFactoryBean
-
- setResourceLoader(ResourceLoader) - Method in class org.springframework.xd.module.options.DefaultModuleOptionsMetadataResolver
-
- setResourceLoader(ResourceLoader) - Method in class org.springframework.xd.module.options.EnvironmentAwareModuleOptionsMetadataResolver
-
- setResourceManagerHost(String) - Method in class org.springframework.xd.module.options.mixins.MapreduceConfigurationMixin
-
- setResourceManagerPort(String) - Method in class org.springframework.xd.module.options.mixins.MapreduceConfigurationMixin
-
- setResources(Resource[]) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.FileDeletionStepExecutionListener
-
- setResources(String) - Method in class org.springframework.xd.module.options.mixins.BatchJobResourcesOptionMixin
-
- setRestartable(boolean) - Method in class org.springframework.xd.module.options.mixins.BatchJobRestartableOptionMixin
-
- setRestartable(boolean) - Method in class org.springframework.xd.rest.domain.JobExecutionInfoResource
-
Set restartable flag explicitly based on the job executions status of the same job instance.
- setResultType(TwitterSearchChannelAdapter.ResultType) - Method in class org.springframework.integration.x.twitter.TwitterSearchChannelAdapter
-
- setResultType(TwitterSearchChannelAdapter.ResultType) - Method in class org.springframework.integration.x.twitter.TwitterSearchOptionsMetadata
-
- setRetained(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- setRetryBackoff(long) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setRetryMultiplier(double) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setRetryOperations(RetryOperations) - Method in class org.springframework.xd.analytics.metrics.redis.RedisRetryTemplate
-
- setRetryOperations(RetryOperations) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
Retry configuration for operations such as validating topic creation
- setRetryPolicy(RetryPolicy) - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- setRetryPolicy(RetryPolicy) - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
Set the Curator retry policy.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.xd.analytics.metrics.redis.RedisRichGaugeRepository
-
- setReverseLookup(boolean) - Method in class org.springframework.xd.tcp.AbstractTcpConnectionFactoryOptionsMetadata
-
- setRfc(String) - Method in class org.springframework.xd.syslog.SyslogSourceOptionsMetadata
-
- setRichGaugeValue(RichGauge, double, double) - Static method in class org.springframework.xd.analytics.metrics.core.MetricUtils
-
- setRingBufferSize(int) - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler
-
The size of the RingBuffer, must be a power of 2.
- setRollover(int) - Method in class org.springframework.xd.dirt.modules.metadata.FilePollHdfsJobOptionsMetadata
-
- setRollover(int) - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- setRolloverStrategy(RolloverStrategy) - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
Sets the rollover strategy.
- setRolloverThresholdInBytes(long) - Method in class org.springframework.xd.batch.item.hadoop.AbstractHdfsItemWriter
-
- setRolloverThresholdInBytes(long) - Method in class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- setRolloverThresholdInBytes(long) - Method in class org.springframework.xd.hadoop.fs.AbstractHdfsWriter
-
- setRolloverThresholdInBytes(long) - Method in class org.springframework.xd.hadoop.fs.HdfsTextFileWriterFactory
-
- setRolloverThresholdInBytes(long) - Method in class org.springframework.xd.integration.hadoop.config.HdfsWritingMessageHandlerFactoryBean
-
- setRoutingKey(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSinkOptionsMetadata
-
- setRules(List<String>) - Method in class org.springframework.xd.dirt.web.config.SecurityConfiguration.AuthorizationConfig
-
- setRunSql(String) - Method in class org.springframework.xd.greenplum.support.JdbcCommands
-
- setSampleUnit(String) - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerMessageHandler
-
- setSampleUnit(TimeUnit) - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerMessageHandler
-
- setSampleUnit(String) - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerOptionsMetadata
-
- setScript(String) - Method in class org.springframework.xd.module.options.mixins.ScriptMixin
-
- setScripts(Resource...) - Method in class org.springframework.xd.jdbc.SingleTableDatabaseInitializer
-
- setSegmentRejectLimit(Integer) - Method in class org.springframework.xd.greenplum.support.ReadableTable
-
- setSegmentRejectLimit(Integer) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setSegmentRejectType(SegmentRejectType) - Method in class org.springframework.xd.greenplum.support.ReadableTable
-
- setSegmentRejectType(SegmentRejectType) - Method in class org.springframework.xd.greenplum.support.ReadableTableFactoryBean
-
- setSendBufferBytes(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setSendCount(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setSendErrorCount(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setSentinelMaster(String) - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- setSentinelNodes(String) - Method in class org.springframework.xd.dirt.modules.metadata.RedisConnectionMixin
-
- setSequence(int) - Method in class org.springframework.xd.module.RuntimeModuleDeploymentProperties
-
Set the module sequence.
- setServerProperties(Properties) - Method in class org.springframework.xd.batch.hsqldb.server.HSQLServerBean
-
- setShortDescription(String) - Method in class org.springframework.xd.module.info.ModuleInformation
-
- setShortDescription(String) - Method in class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource
-
- setShouldCreateModuleClassLoader(boolean) - Method in class org.springframework.xd.module.options.DefaultModuleOptionsMetadataResolver
-
Set to true to create a new classloader (ParentLastURLClassLoader) when loading
the module options metadata classes.
- setShutdownTimeout(int) - Method in class org.springframework.integration.x.kafka.WindowingOffsetManager
-
- setSinkChannelName(String) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Set the module sink channel name.
- setSocketBufferBytes(int) - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- setSocketBufferSize(int) - Method in class org.springframework.xd.dirt.integration.kafka.KafkaMessageBus
-
- setSocketTimeout(int) - Method in class org.springframework.integration.x.kafka.KafkaConsumerOptionsMixin
-
- setSocketTimeout(int) - Method in class org.springframework.xd.tcp.AbstractTcpConnectionFactoryOptionsMetadata
-
- setSourceChannelName(String) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Set the module source channel name.
- setSplit(boolean) - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- setSplit(boolean) - Method in class org.springframework.xd.module.options.mixins.FromMongoDbOptionMixin
-
- setSpringXDOperations(SpringXDOperations) - Method in class org.springframework.xd.shell.XDShell
-
- setSql(String) - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- setSql(String) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- setSqlAfter(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setSqlAfter(List<String>) - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- setSqlAfter(List<String>) - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- setSqlBefore(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setSqlBefore(List<String>) - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- setSqlBefore(List<String>) - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- setSqlTaskScheduler(TaskScheduler) - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistMessageHandler
-
- setSslPropertiesLocation(Resource) - Method in class org.springframework.integration.x.http.NettyHttpInboundChannelAdapter
-
- setSslPropertiesLocation(Resource) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setSslPropertiesLocation(String) - Method in class org.springframework.xd.dirt.modules.metadata.HttpSourceOptionsMetadata
-
- setSslPropertiesLocation(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- setStallWarnings(boolean) - Method in class org.springframework.integration.x.twitter.TwitterStreamChannelAdapter
-
Whether "stall_warnings=true" should be added to the query.
- setStallWarnings(boolean) - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- setStandardDeviationSendDuration(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setStartedAt(Date) - Method in class org.springframework.xd.dirt.stream.BaseInstance
-
Set the date when this instance was started.
- setStartMessage(Object) - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerMessageHandler
-
- setStartMessage(String) - Method in class org.springframework.xd.integration.throughput.ThroughputSamplerOptionsMetadata
-
- setStatementExpression(String) - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- setStatus(DeploymentUnitStatus) - Method in class org.springframework.xd.dirt.stream.BaseInstance
-
- setStatus(String) - Method in class org.springframework.xd.integration.util.jmxresult.JMXChannelResult
-
- setStatus(String) - Method in class org.springframework.xd.integration.util.jmxresult.JMXResult
-
- setStatus(String) - Method in class org.springframework.xd.rest.domain.DeployableResource
-
- setStepExecution(StepExecution) - Method in class org.springframework.xd.dirt.plugins.job.support.listener.ChunkContextInfo
-
- setStopTimeout(int) - Method in class org.springframework.xd.reactor.AbstractReactorMessageHandler
-
Time in milliseconds to wait when shutting down the processor, waiting on a latch inside
the onComplete method of the subscriber.
- setStorageLevel(String) - Method in class org.springframework.xd.spark.streaming.DefaultSparkStreamingModuleOptionsMetadata
-
- setStore(AggregatorProcessorModuleOptionsMetadata.StoreKind) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setStoreWriter(DataStoreWriter<String>) - Method in class org.springframework.xd.integration.hadoop.config.HdfsStoreMessageHandlerFactoryBean
-
Sets the store writer.
- setStreamName(String) - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Set the stream name.
- setStreams(int) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setSubject(String) - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- setSubscriptionName(String) - Method in class org.springframework.xd.dirt.modules.metadata.JmsSourceModuleOptionsMetadata
-
- setSuffix(String) - Method in class org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata
-
- setSuspectTimeout(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setSystemProcessExitCodeMapper(SystemProcessExitCodeMapper) - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
- setTable(String) - Method in class org.springframework.batch.integration.x.IncrementalColumnRangePartitioner
-
The name of the SQL table the data are in.
- setTable(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setTable(String) - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- setTable(String) - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- setTableName(String) - Method in class org.springframework.xd.jdbc.AbstractImportToJdbcOptionsMetadata
-
- setTableName(String) - Method in class org.springframework.xd.jdbc.JdbcHdfsOptionsMetadata
-
- setTableName(String) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcBatchItemWriter
-
- setTableName(String) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- setTableName(String) - Method in class org.springframework.xd.jdbc.SingleTableDatabaseInitializer
-
- setTablePrefix(String) - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- setTarget(Target) - Method in class org.springframework.xd.shell.Configuration
-
Set the XD Admin Server
Target
.
- setTargetException(Exception) - Method in class org.springframework.xd.shell.Target
-
Sets the exception in case an error occurred during targeting.
- setTargetResultMessage(String) - Method in class org.springframework.xd.shell.Target
-
Set the result messages indicating the success or failure while targeting the Spring XD Admin Server.
- setTcpPort(int) - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- setTemporaryRemoteDir(String) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- setTerminationCheckInterval(long) - Method in class org.springframework.batch.step.tasklet.x.AbstractProcessBuilderTasklet
-
The time interval how often the tasklet will check for termination
status.
- setTestOnBorrow(boolean) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setTestOnReturn(boolean) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setTestWhileIdle(boolean) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setTextFormat() - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setTextFormat(Character, String, Character) - Method in class org.springframework.xd.greenplum.support.AbstractExternalTable
-
- setTimeBetweenEvictionRunsMillis(int) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setTimeField(String) - Method in class org.springframework.xd.analytics.metrics.metadata.AggregateCounterSinkOptionsMetadata
-
- setTimeout(int) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setTimeSinceLastSend(String) - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- setTimespan(long) - Method in class org.springframework.integration.x.kafka.WindowingOffsetManager
-
The timespan for aggregating write operations, before invoking the underlying OffsetManager
.
- setTimestamp(String) - Method in class org.springframework.xd.integration.util.jmxresult.JMXChannelResult
-
- setTimestamp(String) - Method in class org.springframework.xd.integration.util.jmxresult.JMXResult
-
- setTimeUnit(String) - Method in class org.springframework.xd.module.options.mixins.PeriodicTriggerMixin
-
- setTimeZone(TimeZone) - Method in class org.springframework.xd.dirt.rest.AbstractBatchJobsController
-
- setTimeZone(String) - Method in class org.springframework.xd.shell.command.ConfigCommands
-
Allows for setting the TimeZone
via a Spring XD Shell command.
- setTmpFileSuffix(String) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- setTmpFileSuffix(String) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSourceOptionsMetadata
-
- setTmpFileSuffix(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setTo(String) - Method in class org.springframework.xd.mail.MailSinkOptionsMetadata
-
- setTopic(String) - Method in class org.springframework.integration.x.kafka.KafkaSinkModuleOptionsMetadata
-
- setTopic(String) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setTopic(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSinkOptionsMetadata
-
- setTopic(String) - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- setTopicExpression(String) - Method in class org.springframework.xd.dirt.modules.metadata.RedisSinkOptionsMetadata
-
- setTopicMetadataFetchTimeout(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setTopicMetadataRefreshInterval(int) - Method in class org.springframework.integration.x.kafka.KafkaProducerOptionsMixin
-
- setTopics(String) - Method in class org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata
-
- setTopics(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttSourceOptionsMetadata
-
- setTrack(String) - Method in class org.springframework.integration.x.twitter.TwitterStreamChannelAdapter
-
Filter tweets by words or phrases.
- setTrack(String) - Method in class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- setTrackHistory(boolean) - Method in class org.springframework.xd.module.ModuleDeploymentProperties
-
Specify the trackHistory property for this module.
- setTransacted(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.xd.dirt.plugins.job.support.JobLaunchingJobRepositoryFactoryBean
-
Public setter for the PlatformTransactionManager
.
- setTransport(String) - Method in class org.springframework.xd.integration.reactor.net.ReactorNetSourceOptionsMetadata
-
- setTtl(int) - Method in class org.springframework.xd.cassandra.CassandraSinkOptionsMetadata
-
- setTupleToStringConverter(Converter<Tuple, String>) - Method in class org.springframework.xd.tuple.DefaultTuple
-
- setTxSize(int) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitSourceOptionsMetadata
-
- setType(String) - Method in class org.springframework.xd.integration.util.jmxresult.JMXRequest
-
- setType(ModuleType) - Method in class org.springframework.xd.module.ModuleDescriptor.Builder
-
Set the module type.
- setTypes(Map<String, FieldSetType>) - Method in class org.springframework.xd.tuple.batch.TupleFieldSetMapper
-
- setUnitName(String) - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- setUpdate(String) - Method in class org.springframework.xd.jdbc.JdbcSourceModuleOptionsMetadata
-
- setUpdateColumns(String) - Method in class org.springframework.xd.greenplum.config.GPFDistSinkOptionsMetadata
-
- setUpdateColumns(List<String>) - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- setUpdateColumns(String[]) - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- setUpdateCondition(String) - Method in class org.springframework.xd.greenplum.support.LoadConfiguration
-
- setUpdateCondition(String) - Method in class org.springframework.xd.greenplum.support.LoadConfigurationFactoryBean
-
- setupReceiveServer() - Method in class org.springframework.xd.test.fixtures.AbstractMailSource
-
- setupReceiveServer() - Method in class org.springframework.xd.test.fixtures.DisposableMailSupport
-
Provide configuration options for the "receive" part of the fixture.
- setupReceiveServer() - Method in class org.springframework.xd.test.fixtures.MailSink
-
- setupSendServer() - Method in class org.springframework.xd.test.fixtures.AbstractMailSource
-
- setupSendServer() - Method in class org.springframework.xd.test.fixtures.DisposableMailSupport
-
Provide configuration options for the "send" part of the fixture.
- setupSendServer() - Method in class org.springframework.xd.test.fixtures.MailSink
-
- setupZookeeperPropertySource(String, boolean) - Method in class org.springframework.xd.dirt.server.SharedServerContextConfiguration.ZookeeperConnectionConfig
-
- setUrl(String) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setUrl(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- setUrl(String) - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- setUrl(String) - Method in class org.springframework.xd.http.HttpClientProcessorOptionsMetadata
-
- setUrl(String) - Method in class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- setUseDirectBuffers(boolean) - Method in class org.springframework.xd.tcp.AbstractTcpConnectionFactoryOptionsMetadata
-
- setUseEquals(boolean) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setUseLocator(boolean) - Method in class org.springframework.xd.gemfire.GemfireHostPortMixin
-
- setUsePolling(boolean) - Method in class org.springframework.xd.mail.MailSourceOptionsMetadata
-
- setUser(String) - Method in class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- setUser(String) - Method in class org.springframework.xd.greenplum.support.ControlFile
-
- setUserDnPattern(String) - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- setUsername(String) - Method in class org.springframework.xd.cassandra.mixins.CassandraConnectionMixin
-
- setUsername(String) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setUsername(String) - Method in class org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata
-
- setUsername(String) - Method in class org.springframework.xd.dirt.modules.metadata.MqttConnectionMixin
-
- setUsername(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- setUsername(String) - Method in class org.springframework.xd.dirt.web.controller.support.AuthenticationRequest
-
- setUsername(String) - Method in class org.springframework.xd.gpload.GploadOptionsMetadata
-
- setUsername(String) - Method in class org.springframework.xd.gpload.GploadTasklet
-
- setUsername(String) - Method in class org.springframework.xd.jdbc.JdbcConnectionMixin
-
- setUsername(String) - Method in class org.springframework.xd.mail.MailServerMixin
-
- setUsername(String) - Method in class org.springframework.xd.module.options.mixins.FtpConnectionMixin
-
- setUsername(String) - Method in class org.springframework.xd.module.options.mixins.MongoDbConnectionMixin
-
- setUsername(String) - Method in class org.springframework.xd.rest.domain.security.SecurityInfoResource
-
- setUsername(String) - Method in class org.springframework.xd.shell.Target.Credentials
-
- setUsername(String) - Method in class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- setUsers(Properties) - Method in class org.springframework.xd.dirt.server.security.FileAuthenticationConfiguration
-
- setUserSearchBase(String) - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- setUserSearchFilter(String) - Method in class org.springframework.xd.dirt.server.security.LdapAuthenticationConfiguration
-
- setUseSSL(boolean) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setUseSSL(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- setUseTemporaryFilename(boolean) - Method in class org.springframework.xd.dirt.modules.metadata.FtpSinkOptionsMetadata
-
- setValid(boolean) - Method in class org.springframework.xd.rest.domain.validation.CronValidation
-
- setValidateTransactionState(boolean) - Method in class org.springframework.xd.dirt.batch.RuntimeBatchConfigurer
-
- setValidateTransactionState(boolean) - Method in class org.springframework.xd.dirt.plugins.job.support.JobLaunchingJobRepositoryFactoryBean
-
Flag to determine whether to check for an existing transaction when a
JobExecution is created.
- setValidationInterval(long) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setValidationQuery(String) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setValidatorClassName(String) - Method in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- setValue(Module) - Method in class org.springframework.xd.integration.util.jmxresult.JMXChannelResult
-
- setValue(JMXValue) - Method in class org.springframework.xd.integration.util.jmxresult.JMXResult
-
- setVariables(String) - Method in class org.springframework.xd.extension.script.ScriptModulePropertiesFactoryBean
-
- setVariables(String) - Method in class org.springframework.xd.module.options.mixins.ScriptMixin
-
- setVerifyCursorPosition(boolean) - Method in class org.springframework.xd.jdbc.NamedColumnJdbcItemReaderFactory
-
- setVhost(String) - Method in class org.springframework.xd.dirt.integration.rabbit.RabbitMessageBus
-
- setVhost(String) - Method in class org.springframework.xd.dirt.modules.metadata.RabbitConnectionMixin
-
- setWidth(int) - Method in class org.springframework.xd.shell.util.TableHeader
-
- setWithMarkers(Boolean) - Method in class org.springframework.xd.dirt.modules.metadata.FileAsRefMixin
-
- setWorkingDir(String) - Method in class org.springframework.xd.extension.process.ShellModuleOptionsMetadata
-
- setWorkingDirectory(String) - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
Set the process working directory
- setWriteConcern(IntoMongoDbOptionMixin.WriteConcern) - Method in class org.springframework.xd.module.options.mixins.IntoMongoDbOptionMixin
-
- setWriterCacheSize(int) - Method in class org.springframework.xd.hadoop.fs.DatasetDefinitionFactoryBean
-
- setXD_ANALYTICS(String) - Method in class org.springframework.xd.dirt.server.options.CommonDistributedOptions
-
- setXD_ANALYTICS(String) - Method in class org.springframework.xd.dirt.server.options.SingleNodeOptions
-
- setXD_CONTAINER_GROUPS(String) - Method in class org.springframework.xd.dirt.server.options.ContainerOptions
-
- setXD_CONTAINER_HOSTNAME(String) - Method in class org.springframework.xd.dirt.server.options.ContainerOptions
-
- setXD_CONTAINER_IP(String) - Method in class org.springframework.xd.dirt.server.options.ContainerOptions
-
- setXD_MGMT_PORT(int) - Method in class org.springframework.xd.dirt.server.options.CommonOptions
-
- setXD_TRANSPORT(String) - Method in class org.springframework.xd.dirt.server.options.SingleNodeOptions
-
- setXdModuleConfigLocation(String) - Method in class org.springframework.xd.module.options.EnvironmentAwareModuleOptionsMetadataResolver
-
- setZkconnect(String) - Method in class org.springframework.integration.x.kafka.KafkaZKOptionMixin
-
- setZkconnectionTimeout(int) - Method in class org.springframework.integration.x.kafka.KafkaZKOptionMixin
-
- setZksessionTimeout(int) - Method in class org.springframework.integration.x.kafka.KafkaZKOptionMixin
-
- setZksyncTime(int) - Method in class org.springframework.integration.x.kafka.KafkaZKOptionMixin
-
- SftpSourceOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Module options for SFTP source module.
- SftpSourceOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.SftpSourceOptionsMetadata
-
- ShallowMetricResourceAssembler<M extends Metric> - Class in org.springframework.xd.dirt.rest.metrics
-
Base class for a ResourceAssembler
that builds shallow resources for metrics (exposing only their names, and
hence their "self" rel).
- ShallowMetricResourceAssembler(Class<?>) - Constructor for class org.springframework.xd.dirt.rest.metrics.ShallowMetricResourceAssembler
-
- sharedChannelName - Variable in class org.springframework.xd.dirt.test.AbstractSingleNodeNamedChannelModule
-
- SharedServerContextConfiguration - Class in org.springframework.xd.dirt.server
-
Beans defined and imported here are shared by the XD Admin Server and Container Server.
- SharedServerContextConfiguration() - Constructor for class org.springframework.xd.dirt.server.SharedServerContextConfiguration
-
- SharedServerContextConfiguration.ZookeeperConnectionConfig - Class in org.springframework.xd.dirt.server
-
- SharedServerContextConfiguration.ZookeeperConnectionConfig() - Constructor for class org.springframework.xd.dirt.server.SharedServerContextConfiguration.ZookeeperConnectionConfig
-
- shell - Variable in class org.springframework.xd.test.fixtures.AbstractMetricSink
-
- ShellCommandProcessor - Class in org.springframework.xd.extension.process
-
Creates a process to run a shell command and communicate with it using String payloads over stdin and stdout.
- ShellCommandProcessor(AbstractByteArraySerializer, String) - Constructor for class org.springframework.xd.extension.process.ShellCommandProcessor
-
Creates a process to invoke a shell command to send and receive messages from the processes using the process's stdin and stdout.
- ShellModuleOptionsMetadata - Class in org.springframework.xd.extension.process
-
Options Metadata for shell processor and sink modules.
- ShellModuleOptionsMetadata() - Constructor for class org.springframework.xd.extension.process.ShellModuleOptionsMetadata
-
- shouldBind() - Method in class org.springframework.xd.module.core.AbstractModule
-
- shouldBind() - Method in interface org.springframework.xd.module.core.Module
-
Should the module require messagebus binding.
- shouldBind() - Method in class org.springframework.xd.module.core.NonBindingResourceConfiguredModule
-
- shouldBindAndValidate() - Method in enum org.springframework.xd.dirt.stream.ParsingContext
-
- shouldConsider(Resource) - Method in class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandler
-
Whether the matched Spring resource should even be considered for inclusion in the result set.
- shouldConsider(Resource) - Method in class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandlers.HadoopDistroOptionHandler
-
- shouldConsider(Resource) - Method in class org.springframework.xd.dirt.server.options.ResourcePatternScanningOptionHandlers.SingleNodeDataTransportOptionHandler
-
- shouldShowOption(ModuleOption, int) - Static method in class org.springframework.xd.dirt.stream.completion.CompletionProvider
-
- shouldTrigger(String, List<ModuleDescriptor>, CompletionKind) - Method in class org.springframework.xd.dirt.stream.completion.AddModuleOptionsExpansionStrategy
-
- shouldTrigger(String, List<ModuleDescriptor>, CompletionKind) - Method in interface org.springframework.xd.dirt.stream.completion.CompletionExpansionStrategy
-
Whether this completion should be triggered.
- shouldTrigger(String, Exception, CompletionKind) - Method in interface org.springframework.xd.dirt.stream.completion.CompletionRecoveryStrategy
-
Whether this completion should be triggered.
- shouldTrigger(String, List<ModuleDescriptor>, CompletionKind) - Method in class org.springframework.xd.dirt.stream.completion.PipeIntoOtherModulesExpansionStrategy
-
- shouldTrigger(String, Exception, CompletionKind) - Method in class org.springframework.xd.dirt.stream.completion.StacktraceFingerprintingCompletionRecoveryStrategy
-
- shutdown() - Method in class org.springframework.xd.test.kafka.EmbeddedZookeeper
-
- shutdownAll() - Method in class org.springframework.xd.distributed.util.DefaultDistributedTestSupport
-
- shutdownAll() - Method in interface org.springframework.xd.distributed.util.DistributedTestSupport
-
- shutdownContainer(String) - Method in class org.springframework.xd.dirt.rest.ContainersController
-
Shutdown container by the given containerId.
- shutdownContainer(long) - Method in class org.springframework.xd.distributed.util.DefaultDistributedTestSupport
-
Shut down the container JVM with the given process id.
- shutdownContainer(long) - Method in interface org.springframework.xd.distributed.util.DistributedTestSupport
-
Shut down the container JVM with the given process id.
- shutdownContainers() - Method in class org.springframework.xd.distributed.util.DefaultDistributedTestSupport
-
- shutdownContainers() - Method in interface org.springframework.xd.distributed.util.DistributedTestSupport
-
- simple(String, ModuleType, String) - Static method in class org.springframework.xd.module.ModuleDefinitions
-
Create a new definition for a simple module (one where its implementation code can be located).
- SimpleAbstractHdfsItemWriter<T> - Class in org.springframework.xd.batch.item.hadoop
-
- SimpleAbstractHdfsItemWriter() - Constructor for class org.springframework.xd.batch.item.hadoop.SimpleAbstractHdfsItemWriter
-
- SimpleCounterSink - Class in org.springframework.xd.test.fixtures
-
Used to generate the counter sink portion of a stream.
- SimpleCounterSink(String) - Constructor for class org.springframework.xd.test.fixtures.SimpleCounterSink
-
- SimpleFileSink - Class in org.springframework.xd.test.fixtures
-
Used to generate the file sink portion of a stream.
- SimpleFileSink() - Constructor for class org.springframework.xd.test.fixtures.SimpleFileSink
-
Use XD Defaults for the file name and directory to where the sink will write its results.
- SimpleFileSink(String, String, boolean, String) - Constructor for class org.springframework.xd.test.fixtures.SimpleFileSink
-
Construct a new SimpleFileSink given the directory and file to write to as well as the if the file is binary
and the mode that determines what to do if the file already exists.
- SimpleFileSource - Class in org.springframework.xd.test.fixtures
-
A FileSource for integration tests.
- SimpleFileSource(String, String, SimpleFileSource.Mode) - Constructor for class org.springframework.xd.test.fixtures.SimpleFileSource
-
Construct a new SimpleFileSource using the provided directory and file names.
- SimpleFileSource(String, String) - Constructor for class org.springframework.xd.test.fixtures.SimpleFileSource
-
Construct a new SimpleFileSource using the provided directory and file names.
- SimpleFileSource.Mode - Enum in org.springframework.xd.test.fixtures
-
- SimpleHdfsTextItemWriter<T> - Class in org.springframework.xd.batch.item.hadoop
-
- SimpleHdfsTextItemWriter(FileSystem) - Constructor for class org.springframework.xd.batch.item.hadoop.SimpleHdfsTextItemWriter
-
- SimpleHttpGenerator - Class in org.springframework.xd.test.generator
-
Used to generate basic http posts for string and file contents
- SimpleHttpGenerator(String, int) - Constructor for class org.springframework.xd.test.generator.SimpleHttpGenerator
-
- SimpleHttpSource - Class in org.springframework.xd.test.fixtures
-
An HTTP source that default to using localhost:9000
- SimpleHttpSource() - Constructor for class org.springframework.xd.test.fixtures.SimpleHttpSource
-
Construct a new SimpleHttpSource, given a host.
- SimpleHttpSource(String) - Constructor for class org.springframework.xd.test.fixtures.SimpleHttpSource
-
Construct a new SimpleHttpSource, given a host.
- SimpleHttpSource(String, int) - Constructor for class org.springframework.xd.test.fixtures.SimpleHttpSource
-
Construct a new SimpleHttpSource, given a host and a port connect to.
- SimpleModule - Class in org.springframework.xd.module.core
-
A
Module
implementation backed by a Spring
ApplicationContext
.
- SimpleModule(ModuleDescriptor, ModuleDeploymentProperties) - Constructor for class org.springframework.xd.module.core.SimpleModule
-
- SimpleModule(ModuleDescriptor, ModuleDeploymentProperties, ClassLoader, ModuleOptions) - Constructor for class org.springframework.xd.module.core.SimpleModule
-
- SimpleModuleDefinition - Class in org.springframework.xd.module
-
A module definition for a "simple", single module whose code and supporting resources
can be located somewhere.
- SimpleModuleOptionsMetadata - Class in org.springframework.xd.module.options
-
An implementation of
ModuleOptionsMetadata
that only knows how to list options and does not support advanced
facilities such as derived options, profile activation or validation.
- SimpleModuleOptionsMetadata() - Constructor for class org.springframework.xd.module.options.SimpleModuleOptionsMetadata
-
- SimpleTailSource - Class in org.springframework.xd.test.fixtures
-
A tail source for integration tests.
- SimpleTailSource() - Constructor for class org.springframework.xd.test.fixtures.SimpleTailSource
-
Construct a SimpleTailSource with a file delay of 5 seconds
- SimpleTailSource(int, String) - Constructor for class org.springframework.xd.test.fixtures.SimpleTailSource
-
Construct a SimpleTailSource using the provided delay and filename
- SimpleXdChunkListener - Class in org.springframework.xd.dirt.plugins.job.support.listener
-
- SimpleXdChunkListener(SubscribableChannel, SubscribableChannel) - Constructor for class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdChunkListener
-
- SimpleXdItemListener<I,O> - Class in org.springframework.xd.dirt.plugins.job.support.listener
-
- SimpleXdItemListener(SubscribableChannel, SubscribableChannel) - Constructor for class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdItemListener
-
- SimpleXdJobExecutionListener - Class in org.springframework.xd.dirt.plugins.job.support.listener
-
- SimpleXdJobExecutionListener(SubscribableChannel, SubscribableChannel) - Constructor for class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdJobExecutionListener
-
- SimpleXdSkipListener - Class in org.springframework.xd.dirt.plugins.job.support.listener
-
- SimpleXdSkipListener(SubscribableChannel, SubscribableChannel) - Constructor for class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdSkipListener
-
- SimpleXdStepExecutionListener - Class in org.springframework.xd.dirt.plugins.job.support.listener
-
- SimpleXdStepExecutionListener(SubscribableChannel, SubscribableChannel) - Constructor for class org.springframework.xd.dirt.plugins.job.support.listener.SimpleXdStepExecutionListener
-
- SINGLENODE_PROFILE - Static variable in class org.springframework.xd.dirt.util.XdProfiles
-
- SINGLENODE_TOKEN - Static variable in class org.springframework.xd.integration.util.ConfigUtil
-
- SingleNodeApplication - Class in org.springframework.xd.dirt.server.singlenode
-
Single Node XD Runtime.
- SingleNodeApplication() - Constructor for class org.springframework.xd.dirt.server.singlenode.SingleNodeApplication
-
- SingleNodeIntegrationTestSupport - Class in org.springframework.xd.dirt.test
-
- SingleNodeIntegrationTestSupport(SingleNodeApplication) - Constructor for class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
Constructor useful for testing custom modules
- SingleNodeNamedChannelSinkFactory - Class in org.springframework.xd.dirt.test.sink
-
- SingleNodeNamedChannelSinkFactory(MessageBus) - Constructor for class org.springframework.xd.dirt.test.sink.SingleNodeNamedChannelSinkFactory
-
- SingleNodeNamedChannelSourceFactory - Class in org.springframework.xd.dirt.test.source
-
- SingleNodeNamedChannelSourceFactory(MessageBus) - Constructor for class org.springframework.xd.dirt.test.source.SingleNodeNamedChannelSourceFactory
-
- SingleNodeNamedQueueSink - Class in org.springframework.xd.dirt.test.sink
-
- SingleNodeNamedQueueSink(MessageBus, String) - Constructor for class org.springframework.xd.dirt.test.sink.SingleNodeNamedQueueSink
-
- SingleNodeNamedQueueSource - Class in org.springframework.xd.dirt.test.source
-
- SingleNodeNamedQueueSource(MessageBus, String) - Constructor for class org.springframework.xd.dirt.test.source.SingleNodeNamedQueueSource
-
- SingleNodeNamedTopicSink - Class in org.springframework.xd.dirt.test.sink
-
- SingleNodeNamedTopicSink(MessageBus, String) - Constructor for class org.springframework.xd.dirt.test.sink.SingleNodeNamedTopicSink
-
- SingleNodeNamedTopicSource - Class in org.springframework.xd.dirt.test.source
-
- SingleNodeNamedTopicSource(MessageBus, String) - Constructor for class org.springframework.xd.dirt.test.source.SingleNodeNamedTopicSource
-
- SingleNodeOptions - Class in org.springframework.xd.dirt.server.options
-
Holds options that can be used in single-node mode.
- SingleNodeOptions() - Constructor for class org.springframework.xd.dirt.server.options.SingleNodeOptions
-
- SingleNodeProcessingChain - Class in org.springframework.xd.dirt.test.process
-
Creates a stream to test a processing chain "p1 | p2 ...
- SingleNodeProcessingChain(SingleNodeApplication, String, String) - Constructor for class org.springframework.xd.dirt.test.process.SingleNodeProcessingChain
-
- SingleNodeProcessingChain(SingleNodeApplication, String, String, String) - Constructor for class org.springframework.xd.dirt.test.process.SingleNodeProcessingChain
-
- SingleNodeProcessingChainConsumer - Class in org.springframework.xd.dirt.test.process
-
Creates a stream to test a processing chain including a source but no sink and adds a
NamedChannelSink
to
create a complete stream.
- SingleNodeProcessingChainConsumer(SingleNodeApplication, String, String) - Constructor for class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainConsumer
-
- SingleNodeProcessingChainConsumer(SingleNodeApplication, String, String, String) - Constructor for class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainConsumer
-
- SingleNodeProcessingChainProducer - Class in org.springframework.xd.dirt.test.process
-
Creates a stream to test a processing chain including a sink but no source and adds a
NamedChannelSource
to
create a complete stream.
- SingleNodeProcessingChainProducer(SingleNodeApplication, String, String) - Constructor for class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainProducer
-
- SingleNodeProcessingChainProducer(SingleNodeApplication, String, String, String) - Constructor for class org.springframework.xd.dirt.test.process.SingleNodeProcessingChainProducer
-
- SingleNodeProcessingChainSupport - Class in org.springframework.xd.dirt.test.process
-
- SingleTableDatabaseInitializer - Class in org.springframework.xd.jdbc
-
Class that's intended for initializing a single table and the script used can use a placeholder #table for the table
name.
- SingleTableDatabaseInitializer() - Constructor for class org.springframework.xd.jdbc.SingleTableDatabaseInitializer
-
- SingletonModuleRegistry - Class in org.springframework.xd.dirt.test
-
An implementation of
ModuleRegistry
suitable to lookup a module that is at
the root of the classpath.
- SingletonModuleRegistry(ModuleType, String) - Constructor for class org.springframework.xd.dirt.test.SingletonModuleRegistry
-
- SingletonModuleRegistry(ModuleType, String, String) - Constructor for class org.springframework.xd.dirt.test.SingletonModuleRegistry
-
- sink - Variable in class org.springframework.xd.dirt.test.process.AbstractSingleNodeProcessingChain
-
- SinkChannelNode - Class in org.springframework.xd.dirt.stream.dsl
-
- SinkChannelNode(ChannelNode, int) - Constructor for class org.springframework.xd.dirt.stream.dsl.SinkChannelNode
-
- Sinks - Class in org.springframework.xd.integration.fixtures
-
A factory that provides fully instantiated sink fixtures based on the environment selected at test startup.
- Sinks(XdEnvironment) - Constructor for class org.springframework.xd.integration.fixtures.Sinks
-
Initializes the instance with xdEnvironment
- size() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- size() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- size() - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- size() - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- size() - Method in class org.springframework.xd.tuple.DefaultTuple
-
- size() - Method in interface org.springframework.xd.tuple.Tuple
-
Return the number of elements in this tuple.
- SKIP_EVENTS_SUFFIX - Static variable in interface org.springframework.xd.dirt.plugins.job.support.listener.XDJobListenerConstants
-
- slice(List<T>, Pageable) - Method in class org.springframework.xd.store.AbstractInMemoryRepository
-
Post-process the list to only return elements matching the page request.
- source - Variable in class org.springframework.xd.dirt.test.process.AbstractSingleNodeProcessingChain
-
- SourceChannelNode - Class in org.springframework.xd.dirt.stream.dsl
-
- SourceChannelNode(ChannelNode, int) - Constructor for class org.springframework.xd.dirt.stream.dsl.SourceChannelNode
-
- Sources - Class in org.springframework.xd.integration.fixtures
-
A convenience class for creating instances of sources to be used for integration testing.
- Sources(XdEnvironment) - Constructor for class org.springframework.xd.integration.fixtures.Sources
-
Construct a new Sources instance using the provided environment.
- spark - package spark
-
- SPARK_DEFAULT_MASTER_URL - Static variable in interface org.springframework.xd.spark.streaming.SparkStreamingSupport
-
- SPARK_DEFAULT_STORAGE_LEVEL - Static variable in interface org.springframework.xd.spark.streaming.SparkStreamingSupport
-
- SPARK_MASTER_URL_PROP - Static variable in interface org.springframework.xd.spark.streaming.SparkStreamingSupport
-
- SPARK_STORAGE_LEVEL_MODULE_OPTION - Static variable in interface org.springframework.xd.spark.streaming.SparkStreamingSupport
-
- SPARK_STORAGE_LEVEL_PROP - Static variable in interface org.springframework.xd.spark.streaming.SparkStreamingSupport
-
- SPARK_STREAMING_BATCH_INTERVAL_MODULE_OPTION - Static variable in interface org.springframework.xd.spark.streaming.SparkStreamingSupport
-
- SPARK_STREAMING_BATCH_INTERVAL_PROP - Static variable in interface org.springframework.xd.spark.streaming.SparkStreamingSupport
-
- SPARK_STREAMING_DEFAULT_BATCH_INTERVAL - Static variable in interface org.springframework.xd.spark.streaming.SparkStreamingSupport
-
- sparkAppJar(String) - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
Sets the location of the spark app jar
- sparkAppJarSource(String) - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
Sets the location of a source jar that can be copied to the target location where
XD can access the jar
- sparkAppJob() - Method in class org.springframework.xd.integration.fixtures.Jobs
-
Create a new SparkAppJob fixture instance that is configured via property files
or environment variables.
- SparkAppJob - Class in org.springframework.xd.test.fixtures
-
A test fixture that represents the Spark App Job
- SparkAppJob(String, String, String, String) - Constructor for class org.springframework.xd.test.fixtures.SparkAppJob
-
Construct a new SparkAppJob fixture using the provided spark app's name, jar,
main class and master.
- sparkAppMainClass(String) - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
Sets the package and class of spark app
- sparkAppName(String) - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
Sets the spark App Name for the fixture
- SparkAppOptionsMetadata - Class in org.springframework.xd.spark
-
Module options for Spark application module.
- SparkAppOptionsMetadata() - Constructor for class org.springframework.xd.spark.SparkAppOptionsMetadata
-
- SparkConfig - Annotation Type in org.springframework.xd.spark.streaming
-
Marker Annotation for providing spark configuration as properties.
- sparkMaster(String) - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
Sets The url of the spark master(spark://url:7077 or localhost[x]
- SparkMessageSender - Class in org.springframework.xd.spark.streaming
-
Abstract class that defines abstract methods to support sending the computed messages out of Spark cluster
to XD MessageBus etc.
- SparkMessageSender() - Constructor for class org.springframework.xd.spark.streaming.SparkMessageSender
-
- SparkPi - Class in spark
-
SparkPi Sample Code that utilizes spark master calls to generate a rough estimate of pi.
- SparkPi() - Constructor for class spark.SparkPi
-
- SparkStreamingChannel - Class in org.springframework.xd.dirt.plugins.spark.streaming
-
The DirectChannel
that provides support for
spark streaming configurations.
- SparkStreamingChannel() - Constructor for class org.springframework.xd.dirt.plugins.spark.streaming.SparkStreamingChannel
-
- SparkStreamingContainerFilter - Class in org.springframework.xd.dirt.spark
-
A
ContainerFilter
which filters out the containers that have a spark
streaming module running.
- SparkStreamingContainerFilter() - Constructor for class org.springframework.xd.dirt.spark.SparkStreamingContainerFilter
-
- SparkStreamingModuleExecutor<I,P extends SparkStreamingSupport> - Interface in org.springframework.xd.spark.streaming
-
The interface that streaming module executor will implement that runs the computation logic on the input DStream
and send the output via $
SparkMessageSender
.
- SparkStreamingPlugin - Class in org.springframework.xd.dirt.plugins.spark.streaming
-
Plugin for Spark Streaming support.
- SparkStreamingPlugin(MessageBus) - Constructor for class org.springframework.xd.dirt.plugins.spark.streaming.SparkStreamingPlugin
-
- SparkStreamingSupport - Interface in org.springframework.xd.spark.streaming
-
Base interface for spring XD and spark streaming integration.
- SparkTasklet - Class in org.springframework.xd.spark.tasklet
-
Tasklet
for running Spark application.
- SparkTasklet() - Constructor for class org.springframework.xd.spark.tasklet.SparkTasklet
-
- Split - Class in org.springframework.xd.dirt.job.dsl
-
The AST node representing a split.
- Split(List<JobNode>) - Constructor for class org.springframework.xd.dirt.job.dsl.Split
-
- SplitterProcessorOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Captures options for the splitter
processor module.
- SplitterProcessorOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.SplitterProcessorOptionsMetadata
-
- SplunkSinkOptionsMetadata - Class in org.springframework.xd.splunk
-
Captures options to the splunk
sink module.
- SplunkSinkOptionsMetadata() - Constructor for class org.springframework.xd.splunk.SplunkSinkOptionsMetadata
-
- SplunkTransformer - Class in org.springframework.integration.x.splunk
-
Message consumer that will push the payload to a splunk instance via a TCP-Port.
- SplunkTransformer() - Constructor for class org.springframework.integration.x.splunk.SplunkTransformer
-
- SpringXDException - Exception in org.springframework.xd.rest.client.impl
-
A Java exception that wraps the serialized VndErrors
object.
- SpringXDException(VndErrors) - Constructor for exception org.springframework.xd.rest.client.impl.SpringXDException
-
- SpringXDOperations - Interface in org.springframework.xd.rest.client
-
Main entry point for interacting with a running XD system.
- SpringXDTemplate - Class in org.springframework.xd.rest.client.impl
-
Implementation of the entry point to the API.
- SpringXDTemplate(URI) - Constructor for class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- SpringXDTemplate(ClientHttpRequestFactory, URI) - Constructor for class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- SpringXDTemplate(URI, String, String, String, String, String) - Constructor for class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- SpringXDTemplate(ClientHttpRequestFactory, URI, String, String, String, String, String) - Constructor for class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- SqlUtils - Class in org.springframework.xd.greenplum.support
-
- SqlUtils() - Constructor for class org.springframework.xd.greenplum.support.SqlUtils
-
- SqoopEnvironmentProvider - Class in org.springframework.xd.sqoop
-
Class that sets environment variables for Sqoop
- SqoopEnvironmentProvider(ConfigurableEnvironment, String) - Constructor for class org.springframework.xd.sqoop.SqoopEnvironmentProvider
-
- SqoopOptionsMetadata - Class in org.springframework.xd.sqoop
-
Module options for Sqoop application module.
- SqoopOptionsMetadata() - Constructor for class org.springframework.xd.sqoop.SqoopOptionsMetadata
-
- SqoopRunner - Class in org.springframework.xd.sqoop
-
Class for running Sqoop tool.
- SqoopRunner() - Constructor for class org.springframework.xd.sqoop.SqoopRunner
-
- SqoopTasklet - Class in org.springframework.xd.sqoop
-
Tasklet used for running Sqoop tool.
- SqoopTasklet() - Constructor for class org.springframework.xd.sqoop.SqoopTasklet
-
- StacktraceFingerprintingCompletionRecoveryStrategy<E extends java.lang.Exception> - Class in org.springframework.xd.dirt.stream.completion
-
A recovery strategy that will trigger if the parser failure is similar to that of some sample unfinished stream
definition.
- StacktraceFingerprintingCompletionRecoveryStrategy(XDParser, Class<E>, String...) - Constructor for class org.springframework.xd.dirt.stream.completion.StacktraceFingerprintingCompletionRecoveryStrategy
-
Construct a new StacktraceFingerprintingCompletionRecoveryStrategy given the parser, and the expected exception
class to be thrown for sample fragments of a stream definition that is to be parsed.
- StalenessCheck - Interface in org.springframework.xd.dirt.module
-
A strategy interface for deciding whether a target definition is stale compared to a source definition.
- StandAloneUiApp - Class in org.springframework.xd.dirt.web
-
Starts the Web UI without needing the full Spring XD setup.
- StandAloneUiApp() - Constructor for class org.springframework.xd.dirt.web.StandAloneUiApp
-
- STANDARD_HEADERS - Static variable in class org.springframework.xd.dirt.integration.bus.XdHeaders
-
The headers that will be propagated, by default, by message bus implementations
that have no inherent header support (by embedding the headers in the payload).
- start() - Method in class org.springframework.xd.dirt.integration.bus.Binding
-
- start() - Method in class org.springframework.xd.dirt.plugins.job.ModuleJobLauncher
-
- start() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentQueue
-
Build and Start the ZK distributed queue.
- start() - Method in class org.springframework.xd.dirt.util.logging.CustomLoggerConverter
-
- start() - Method in class org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper
-
Start the ZooKeeper server in a background thread.
- start() - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
Starts the underlying CuratorFramework
instance.
- start() - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
Start the process.
- start() - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
- start() - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistServer
-
- start() - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- start() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
- start() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsWritingMessageHandler
-
- start() - Method in class org.springframework.xd.module.core.CompositeModule
-
- start() - Method in class org.springframework.xd.module.core.SimpleModule
-
- start() - Method in class org.springframework.xd.spark.streaming.SparkMessageSender
-
Start the message sender
- start() - Method in class org.springframework.xd.test.fixtures.TcpSink
-
Create a socket and copy received data into a buffer
- startAdmin(Properties) - Static method in class org.springframework.xd.distributed.util.ServerProcessUtils
-
Start an instance of the admin server.
- startContainer(Properties) - Method in class org.springframework.xd.distributed.util.DefaultDistributedTestSupport
-
Start a container in a new JVM, using the provided properties
as system properties for the container JVM process.
- startContainer() - Method in class org.springframework.xd.distributed.util.DefaultDistributedTestSupport
-
Start a container in a new JVM.
- startContainer(Properties) - Method in interface org.springframework.xd.distributed.util.DistributedTestSupport
-
Start a container in a new JVM, using the provided properties
as system properties for the container JVM process.
- startContainer() - Method in interface org.springframework.xd.distributed.util.DistributedTestSupport
-
Start a container in a new JVM.
- startContainer(Properties) - Static method in class org.springframework.xd.distributed.util.ServerProcessUtils
-
Start a container instance.
- startHsql(Properties) - Static method in class org.springframework.xd.distributed.util.ServerProcessUtils
-
Start an instance of HSQL.
- startpos - Variable in class org.springframework.xd.dirt.job.dsl.AstNode
-
- startpos - Variable in class org.springframework.xd.dirt.stream.dsl.AstNode
-
- startup() - Method in class org.springframework.xd.distributed.util.DefaultDistributedTestSupport
-
Start the minimum required servers for a distributed XD system:
ZooKeeper
HSQL
Admin server (for serving REST endpoints)
- startup() - Method in interface org.springframework.xd.distributed.util.DistributedTestSupport
-
Start the minimum required servers for a distributed XD system:
ZooKeeper
HSQL
Admin server (for serving REST endpoints)
- startZooKeeper(int) - Static method in class org.springframework.xd.distributed.util.ServerProcessUtils
-
Start an instance of ZooKeeper.
- stateCalculator - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.DefaultDeploymentStateRecalculator
-
Deployment unit state calculator
- stateCalculator() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- stateChanged(CuratorFramework, ConnectionState) - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentMessageConsumer
-
- STATUS - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of status node.
- STEP_EXECUTION_EVENTS_SUFFIX - Static variable in interface org.springframework.xd.dirt.plugins.job.support.listener.XDJobListenerConstants
-
- StepExecutionHistoryJacksonMixIn - Class in org.springframework.xd.rest.client.impl.support
-
Jackson MixIn for StepExecutionHistory
de-serialization.
- StepExecutionInfo - Class in org.springframework.xd.dirt.job
-
Represents Batch step execution info.
- StepExecutionInfo(String, Long, String, TimeZone) - Constructor for class org.springframework.xd.dirt.job.StepExecutionInfo
-
- StepExecutionInfo(StepExecution, TimeZone) - Constructor for class org.springframework.xd.dirt.job.StepExecutionInfo
-
- StepExecutionInfoResource - Class in org.springframework.xd.rest.domain
-
Represents the step execution info resource.
- StepExecutionInfoResource(Long, StepExecution, String) - Constructor for class org.springframework.xd.rest.domain.StepExecutionInfoResource
-
- StepExecutionInfoResource() - Constructor for class org.springframework.xd.rest.domain.StepExecutionInfoResource
-
- stepExecutionInfoResourceAssembler - Variable in class org.springframework.xd.dirt.rest.AbstractBatchJobsController
-
- StepExecutionInfoResourceAssembler - Class in org.springframework.xd.dirt.rest
-
- StepExecutionInfoResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.StepExecutionInfoResourceAssembler
-
- StepExecutionJacksonMixIn - Class in org.springframework.xd.dirt.plugins.job.support
-
Jackson MixIn for StepExecution
serialization.
- StepExecutionJacksonMixIn() - Constructor for class org.springframework.xd.dirt.plugins.job.support.StepExecutionJacksonMixIn
-
- StepExecutionJacksonMixIn - Class in org.springframework.xd.rest.client.impl.support
-
Jackson MixIn for StepExecution
de-serialization.
- stepExecutionProgress(long, long) - Method in class org.springframework.xd.rest.client.impl.JobTemplate
-
- stepExecutionProgress(long, long) - Method in interface org.springframework.xd.rest.client.JobOperations
-
Retrieve step execution progress with the given jobExecutionId
and stepExecutionId
.
- stepExecutionProgress(long, long) - Method in class org.springframework.xd.shell.command.JobCommands
-
- StepExecutionProgressInfo - Class in org.springframework.xd.dirt.job
-
Represents Batch job step execution progress info.
- StepExecutionProgressInfo(StepExecution, StepExecutionHistory) - Constructor for class org.springframework.xd.dirt.job.StepExecutionProgressInfo
-
- StepExecutionProgressInfoResource - Class in org.springframework.xd.rest.domain
-
Represents the step execution progress info resource.
- StepExecutionProgressInfoResource() - Constructor for class org.springframework.xd.rest.domain.StepExecutionProgressInfoResource
-
- StepExecutionProgressInfoResource(StepExecution, StepExecutionHistory, double, boolean, double) - Constructor for class org.springframework.xd.rest.domain.StepExecutionProgressInfoResource
-
- StepExecutionProgressInfoResourceAssembler - Class in org.springframework.xd.dirt.rest
-
- StepExecutionProgressInfoResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.StepExecutionProgressInfoResourceAssembler
-
- StepType - Enum in org.springframework.xd.dirt.job
-
The types of Spring Batch Step
implementations that are known to the system.
- stop() - Method in class org.springframework.xd.dirt.integration.bus.Binding
-
- stop() - Method in class org.springframework.xd.dirt.plugins.job.ModuleJobLauncher
-
- stop() - Method in class org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper
-
Shutdown the ZooKeeper server.
- stop(Runnable) - Method in class org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper
-
Stop the server if running and invoke the callback when complete.
- stop() - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
Closes the underlying CuratorFramework
instance.
- stop(Runnable) - Method in class org.springframework.xd.dirt.zookeeper.ZooKeeperConnection
-
Closes the underlying CuratorFramework
instance and then invokes the callback.
- stop() - Method in class org.springframework.xd.extension.process.ShellCommandProcessor
-
Stop the process and close streams.
- stop() - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
- stop(Runnable) - Method in class org.springframework.xd.greenplum.gpfdist.AbstractGPFDistMessageHandler
-
- stop() - Method in class org.springframework.xd.greenplum.gpfdist.GPFDistServer
-
- stop() - Method in class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- stop() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
- stop(Runnable) - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsStoreMessageHandler
-
- stop() - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsWritingMessageHandler
-
- stop(Runnable) - Method in class org.springframework.xd.integration.hadoop.outbound.HdfsWritingMessageHandler
-
- stop() - Method in class org.springframework.xd.module.core.CompositeModule
-
- stop() - Method in class org.springframework.xd.module.core.SimpleModule
-
- stop() - Method in class org.springframework.xd.spark.streaming.SparkMessageSender
-
Stop the message sender
- stopAll() - Method in class org.springframework.xd.dirt.rest.BatchJobExecutionsController
-
Stop all job executions.
- stopAllJobExecutions() - Method in class org.springframework.xd.rest.client.impl.JobTemplate
-
- stopAllJobExecutions() - Method in interface org.springframework.xd.rest.client.JobOperations
-
Stop all job executions.
- stopAllJobExecutions(boolean) - Method in class org.springframework.xd.shell.command.JobCommands
-
- stopBindings() - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- stopJobExecution(long) - Method in class org.springframework.xd.dirt.rest.BatchJobExecutionsController
-
Stop Job Execution by the given executionId.
- stopJobExecution(long) - Method in class org.springframework.xd.rest.client.impl.JobTemplate
-
- stopJobExecution(long) - Method in interface org.springframework.xd.rest.client.JobOperations
-
Stop job execution that is running.
- stopJobExecution(long) - Method in class org.springframework.xd.shell.command.JobCommands
-
- store(String, ModuleType, String) - Method in interface org.springframework.xd.dirt.module.ModuleDependencyRepository
-
Store one atomic dependency from a module (composed or not) to some target (stream, or composed module).
- store(String, ModuleType, String) - Method in class org.springframework.xd.dirt.module.store.ZooKeeperModuleDependencyRepository
-
- StoreWriterFactoryBean - Class in org.springframework.xd.integration.hadoop.config
-
A FactoryBean
creating a DataStoreWriter
.
- StoreWriterFactoryBean() - Constructor for class org.springframework.xd.integration.hadoop.config.StoreWriterFactoryBean
-
- StoreWriterParser - Class in org.springframework.xd.integration.hadoop.config
-
Parser for the 'storage' element.
- StoreWriterParser() - Constructor for class org.springframework.xd.integration.hadoop.config.StoreWriterParser
-
- Stream - Class in org.springframework.xd.dirt.core
-
Domain model for runtime Stream modules.
- Stream - Class in org.springframework.xd.dirt.stream
-
A runtime representation of a running stream.
- Stream(StreamDefinition) - Constructor for class org.springframework.xd.dirt.stream.Stream
-
- stream(String, String, URL) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Creates the stream definition and deploys it to the cluster being tested.
- Stream.Builder - Class in org.springframework.xd.dirt.core
-
Builder object for
Stream
that supports fluent style configuration.
- Stream.Builder() - Constructor for class org.springframework.xd.dirt.core.Stream.Builder
-
- STREAM_DEPLOYMENTS - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of stream deployments node.
- StreamCommands - Class in org.springframework.xd.shell.command
-
- StreamCommands() - Constructor for class org.springframework.xd.shell.command.StreamCommands
-
- StreamConfigParser - Class in org.springframework.xd.dirt.stream.dsl
-
- StreamConfigParser(CrudRepository<? extends BaseDefinition, String>) - Constructor for class org.springframework.xd.dirt.stream.dsl.StreamConfigParser
-
- StreamDefinition - Class in org.springframework.xd.dirt.stream
-
Represents a model for a data flow in the system.
- StreamDefinition(String, String) - Constructor for class org.springframework.xd.dirt.stream.StreamDefinition
-
Create a new StreamDefinition.
- StreamDefinitionException - Exception in org.springframework.xd.dirt.stream.dsl
-
Root exception for DSL parsing related exceptions.
- StreamDefinitionException(String, int, XDDSLMessages, Object...) - Constructor for exception org.springframework.xd.dirt.stream.dsl.StreamDefinitionException
-
- StreamDefinitionRepository - Interface in org.springframework.xd.dirt.stream
-
- streamDefinitionRepository() - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
- StreamDefinitionRepositoryUtils - Class in org.springframework.xd.dirt.stream
-
Encapsulate shared functionality between implementations of StreamDefinitionRepository that can't be done using
inheritance
- StreamDefinitionRepositoryUtils() - Constructor for class org.springframework.xd.dirt.stream.StreamDefinitionRepositoryUtils
-
- StreamDefinitionResource - Class in org.springframework.xd.rest.domain
-
Represents a stream definition, i.e. a flow of data in the system.
- StreamDefinitionResource() - Constructor for class org.springframework.xd.rest.domain.StreamDefinitionResource
-
Default constructor for serialization frameworks.
- StreamDefinitionResource(String, String) - Constructor for class org.springframework.xd.rest.domain.StreamDefinitionResource
-
- StreamDefinitionResource.Page - Class in org.springframework.xd.rest.domain
-
Dedicated subclass to workaround type erasure.
- StreamDefinitionResource.Page() - Constructor for class org.springframework.xd.rest.domain.StreamDefinitionResource.Page
-
- StreamDefinitionResourceAssembler - Class in org.springframework.xd.dirt.rest
-
- StreamDefinitionResourceAssembler() - Constructor for class org.springframework.xd.dirt.rest.StreamDefinitionResourceAssembler
-
- StreamDeployer - Class in org.springframework.xd.dirt.stream
-
- StreamDeployer(ZooKeeperConnection, StreamDefinitionRepository, StreamRepository, XDParser, DeploymentHandler) - Constructor for class org.springframework.xd.dirt.stream.StreamDeployer
-
Construct a StreamDeployer.
- streamDeployer() - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
- streamDeploymentHandler() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- StreamDeploymentsPath - Class in org.springframework.xd.dirt.core
-
- StreamDeploymentsPath() - Constructor for class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Construct a StreamDeploymentsPath
.
- StreamDeploymentsPath(String) - Constructor for class org.springframework.xd.dirt.core.StreamDeploymentsPath
-
Construct a StreamDeploymentsPath
.
- StreamException - Exception in org.springframework.xd.dirt.stream
-
Root of the hierarchy of exceptions for Module processing in DIRT.
- StreamException(String) - Constructor for exception org.springframework.xd.dirt.stream.StreamException
-
- StreamException(String, Throwable) - Constructor for exception org.springframework.xd.dirt.stream.StreamException
-
- streamFactory - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.DefaultDeploymentStateRecalculator
-
Factory to construct
Stream
instance
- streamFactory() - Method in class org.springframework.xd.dirt.server.admin.deployment.zk.DeploymentConfiguration
-
- streamFactory - Variable in class org.springframework.xd.dirt.server.admin.deployment.zk.ModuleRedeployer
-
Stream factory.
- StreamFactory - Class in org.springframework.xd.dirt.stream
-
Factory class that builds
Stream
instances.
- StreamFactory(StreamDefinitionRepository, ModuleRegistry, ModuleOptionsMetadataResolver) - Constructor for class org.springframework.xd.dirt.stream.StreamFactory
-
Construct a StreamFactory to create
Stream
domain model instances.
- StreamLookupEnvironment - Interface in org.springframework.xd.dirt.stream.dsl
-
A lookup environment is used to resolve a stream.
- StreamNode - Class in org.springframework.xd.dirt.stream.dsl
-
- StreamNode(String, String, List<ModuleNode>, SourceChannelNode, SinkChannelNode) - Constructor for class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- streamOperations() - Method in class org.springframework.xd.rest.client.impl.SpringXDTemplate
-
- streamOperations() - Method in interface org.springframework.xd.rest.client.SpringXDOperations
-
Returns the portion of the API for interacting with Streams.
- StreamOperations - Interface in org.springframework.xd.rest.client
-
Interface defining operations available against streams.
- StreamPlugin - Class in org.springframework.xd.dirt.plugins.stream
-
- StreamPlugin(MessageBus, ZooKeeperConnection) - Constructor for class org.springframework.xd.dirt.plugins.stream.StreamPlugin
-
- StreamRepository - Interface in org.springframework.xd.dirt.stream
-
A repository for persisting
Stream
s.
- streamRepository() - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
- StreamRuntimePropertiesProvider - Class in org.springframework.xd.dirt.server.admin.deployment
-
- StreamRuntimePropertiesProvider(Stream, ModuleDeploymentPropertiesProvider<ModuleDeploymentProperties>) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.StreamRuntimePropertiesProvider
-
Construct a
StreamPartitionPropertiesProvider
for
a
Stream
.
- STREAMS - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of streams node.
- StreamsController - Class in org.springframework.xd.dirt.rest
-
Handles all Stream related interaction.
- StreamsController(StreamDeployer) - Constructor for class org.springframework.xd.dirt.rest.StreamsController
-
- streamStateVerifier() - Method in class org.springframework.xd.dirt.test.SingleNodeIntegrationTestSupport
-
- StreamTemplate - Class in org.springframework.xd.rest.client.impl
-
Implementation of the Stream-related part of the API.
- StreamUtils - Class in org.springframework.xd.integration.util
-
Utilities for creating and monitoring streams and the JMX hooks for those strings.
- StreamUtils() - Constructor for class org.springframework.xd.integration.util.StreamUtils
-
- StrictContentTypeResolver - Class in org.springframework.xd.dirt.integration.bus
-
- StrictContentTypeResolver(MimeType) - Constructor for class org.springframework.xd.dirt.integration.bus.StrictContentTypeResolver
-
- strictlyMoreThanOne(boolean...) - Static method in class org.springframework.xd.module.options.validation.Exclusives
-
Return true when 2 or more booleans are true, false otherwise.
- StringConvertingContentTypeResolver - Class in org.springframework.xd.dirt.integration.bus
-
A DefaultContentTypeResolver
that can parse String values.
- StringConvertingContentTypeResolver() - Constructor for class org.springframework.xd.dirt.integration.bus.StringConvertingContentTypeResolver
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.job.dsl.ArgumentNode
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.job.dsl.AstNode
-
- stringify() - Method in class org.springframework.xd.dirt.job.dsl.AstNode
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.job.dsl.Flow
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.job.dsl.JobDefinition
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.job.dsl.JobReference
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.job.dsl.Split
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.job.dsl.Transition
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.stream.dsl.ArgumentNode
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.stream.dsl.AstNode
-
- stringify() - Method in class org.springframework.xd.dirt.stream.dsl.AstNode
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.stream.dsl.ChannelNode
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.stream.dsl.LabelNode
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.stream.dsl.ModuleNode
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.stream.dsl.SinkChannelNode
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.stream.dsl.SourceChannelNode
-
- stringify(boolean) - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- StringRedisRetryTemplate - Class in org.springframework.xd.analytics.metrics.redis
-
String-focused extension of RedisRetryTemplate.
- StringRedisRetryTemplate(RedisConnectionFactory, RetryOperations) - Constructor for class org.springframework.xd.analytics.metrics.redis.StringRedisRetryTemplate
-
Constructs a new StringRedisTemplate
instance with a set of retry operations.
- StringToByteArrayMessageConverter - Class in org.springframework.xd.dirt.integration.bus.converter
-
A MessageConverter
to convert a String to a byte[], applying the provided Charset in
the content-type header if any.
- StringToByteArrayMessageConverter() - Constructor for class org.springframework.xd.dirt.integration.bus.converter.StringToByteArrayMessageConverter
-
- StringToDateConverter - Class in org.springframework.xd.tuple
-
Converter for Strings to Date that can take into account date patterns
- StringToDateConverter() - Constructor for class org.springframework.xd.tuple.StringToDateConverter
-
- StringToDateConverter(String) - Constructor for class org.springframework.xd.tuple.StringToDateConverter
-
- StringToDateConverter(DateFormat) - Constructor for class org.springframework.xd.tuple.StringToDateConverter
-
- StringToEnumIgnoringCaseConverterFactory - Class in org.springframework.xd.module.options.support
-
Copied from org.springframework.boot.bind.RelaxedConversionService
.
- StringToEnumIgnoringCaseConverterFactory() - Constructor for class org.springframework.xd.module.options.support.StringToEnumIgnoringCaseConverterFactory
-
- stringValue() - Method in class org.springframework.xd.dirt.job.dsl.Token
-
- stringValue() - Method in class org.springframework.xd.dirt.stream.dsl.Token
-
- stripPath(String) - Static method in class org.springframework.xd.dirt.zookeeper.Paths
-
Strip path information from a string.
- stripPathConverter - Static variable in class org.springframework.xd.dirt.zookeeper.ZooKeeperUtils
-
Converter
from ChildData
to the leaf path name string.
- subject(String) - Method in class org.springframework.xd.test.fixtures.MailSink
-
- SubjectMessageHandler - Class in org.springframework.xd.rxjava
-
Adapts the item at a time delivery of a MessageHandler
by delegating processing to a Observable
.
- SubjectMessageHandler(Processor) - Constructor for class org.springframework.xd.rxjava.SubjectMessageHandler
-
- SUCCESS - Static variable in class org.springframework.xd.dirt.server.admin.deployment.zk.ZKDeploymentMessagePublisher
-
Name of ZooKeeper node that indicates the deployment message
was succesfully processed.
- success(List<ModuleDescriptor>, List<Exception>) - Method in class org.springframework.xd.dirt.stream.DocumentParseResult
-
- sum(long[]) - Static method in class org.springframework.xd.analytics.metrics.core.MetricUtils
-
- SupervisorElectedEvent - Class in org.springframework.xd.dirt.server.admin.deployment.zk
-
Event that is fired after a admin leader is elected.
- SupervisorElectedEvent(PathChildrenCache, PathChildrenCache, PathChildrenCache) - Constructor for class org.springframework.xd.dirt.server.admin.deployment.zk.SupervisorElectedEvent
-
Construct LeaderElected event.
- SupervisorElectionListener - Interface in org.springframework.xd.dirt.server.admin.deployment.zk
-
- supportedPayloadTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
Subclasses implement this to specify supported payload types
- supportedPayloadTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.ByteArrayToStringMessageConverter
-
- supportedPayloadTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.JavaToSerializedMessageConverter
-
- supportedPayloadTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.JsonToPojoMessageConverter
-
- supportedPayloadTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.JsonToTupleMessageConverter
-
- supportedPayloadTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.PojoToJsonMessageConverter
-
- supportedPayloadTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.PojoToStringMessageConverter
-
- supportedPayloadTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.SerializedToJavaMessageConverter
-
- supportedPayloadTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.StringToByteArrayMessageConverter
-
- supportedPayloadTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.TupleToJsonMessageConverter
-
- supportedTargetTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
Subclasses implement this to specify supported target types
- supportedTargetTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.ByteArrayToStringMessageConverter
-
- supportedTargetTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.JavaToSerializedMessageConverter
-
- supportedTargetTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.JsonToPojoMessageConverter
-
- supportedTargetTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.JsonToTupleMessageConverter
-
- supportedTargetTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.PojoToJsonMessageConverter
-
- supportedTargetTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.PojoToStringMessageConverter
-
- supportedTargetTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.SerializedToJavaMessageConverter
-
- supportedTargetTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.StringToByteArrayMessageConverter
-
- supportedTargetTypes() - Method in class org.springframework.xd.dirt.integration.bus.converter.TupleToJsonMessageConverter
-
- supports(Class<?>) - Method in class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
- supports(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractJobPlugin
-
- supports(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractPlugin
-
- supports(Module) - Method in class org.springframework.xd.dirt.plugins.AbstractStreamPlugin
-
- supports(Module) - Method in class org.springframework.xd.dirt.plugins.ContainerInfoPlugin
-
- supports(Module) - Method in class org.springframework.xd.dirt.plugins.MBeanExportingPlugin
-
- supports(Module) - Method in class org.springframework.xd.dirt.plugins.ModuleInfoPlugin
-
- supports(Module) - Method in class org.springframework.xd.dirt.plugins.spark.streaming.SparkStreamingPlugin
-
- supports(Module) - Method in class org.springframework.xd.dirt.plugins.stream.ModuleTypeConversionPlugin
-
- supports(Module) - Method in class org.springframework.xd.dirt.plugins.ZookeeperConnectionPlugin
-
- supports(Module) - Method in interface org.springframework.xd.module.core.Plugin
-
Check if the module is supported by the plugin.
- supports(Class<?>, String) - Method in class org.springframework.xd.shell.converter.CompletionConverter
-
- supports(Class<?>, String) - Method in class org.springframework.xd.shell.converter.ExistingXDEntityConverter
-
- supports(Class<?>, String) - Method in class org.springframework.xd.shell.converter.MediaTypeConverter
-
- supports(Class<?>, String) - Method in class org.springframework.xd.shell.converter.NumberFormatConverter
-
- supports(Class<?>, String) - Method in class org.springframework.xd.shell.converter.QualifiedModuleNameConverter
-
- supportsNamedChannels() - Method in enum org.springframework.xd.dirt.stream.ParsingContext
-
- supportsPayloadType(Class<?>) - Method in class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
- supportsTargetMimeType(MimeType) - Method in class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
- suspectTimeout - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- SynchronizingModuleRegistry - Class in org.springframework.xd.dirt.module
-
A ModuleRegistry that is configured with two delegates: a remote (source) and a local (target) registry.
- SynchronizingModuleRegistry(WritableModuleRegistry, WritableModuleRegistry) - Constructor for class org.springframework.xd.dirt.module.SynchronizingModuleRegistry
-
- SyslogInboundChannelAdapter - Class in org.springframework.xd.integration.reactor.syslog
-
InboundChannelAdapter
implementation that uses the Reactor TCP support to read in syslog messages and
transform them to a Map
for use in downstream modules.
- SyslogInboundChannelAdapter(ReactorPeer<Buffer, Buffer, ChannelStream<Buffer, Buffer>>) - Constructor for class org.springframework.xd.integration.reactor.syslog.SyslogInboundChannelAdapter
-
- SyslogInboundChannelAdapterConfiguration - Class in org.springframework.xd.integration.reactor.syslog
-
- SyslogInboundChannelAdapterConfiguration() - Constructor for class org.springframework.xd.integration.reactor.syslog.SyslogInboundChannelAdapterConfiguration
-
- SyslogInboundChannelAdapterParser - Class in org.springframework.xd.integration.reactor.config
-
- SyslogInboundChannelAdapterParser() - Constructor for class org.springframework.xd.integration.reactor.config.SyslogInboundChannelAdapterParser
-
- SyslogSourceOptionsMetadata - Class in org.springframework.xd.syslog
-
Captures options for the syslog-udp
source module.
- SyslogSourceOptionsMetadata() - Constructor for class org.springframework.xd.syslog.SyslogSourceOptionsMetadata
-
- syslogTcp(String) - Method in class org.springframework.xd.integration.fixtures.Sources
-
Constructs a SyslogTcpSource that receives syslog events via tcp.
- syslogTcp() - Method in class org.springframework.xd.integration.fixtures.Sources
-
Constructs a SyslogTcpSource that receives syslog events via tcp.
- syslogTcpSource() - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new SyslogTcpSource with the target host resolved at runtime from the default stream name.
- SyslogTcpSource - Class in org.springframework.xd.test.fixtures
-
A test fixture that allows testing of the syslog tcp source module.
- SyslogTcpSource(String, int) - Constructor for class org.springframework.xd.test.fixtures.SyslogTcpSource
-
Initializes a SyslogTcpSource fixture.
- SyslogTcpSourceOptionsMetadata - Class in org.springframework.xd.syslog
-
Captures options for the syslog-tcp
source module.
- SyslogTcpSourceOptionsMetadata() - Constructor for class org.springframework.xd.syslog.SyslogTcpSourceOptionsMetadata
-
- syslogUdp(String) - Method in class org.springframework.xd.integration.fixtures.Sources
-
Constructs a SyslogUdpSource that receives syslog events via udp.
- syslogUdp() - Method in class org.springframework.xd.integration.fixtures.Sources
-
Constructs a SyslogUdpSource that receives syslog events via udp using defaults.
- syslogUdpForContainerHost() - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new SyslogUdpSource with the target host resolved at runtime from the default stream name.
- SyslogUdpSource - Class in org.springframework.xd.test.fixtures
-
A test fixture that allows testing of the syslog udp source module.
- SyslogUdpSource(String, int) - Constructor for class org.springframework.xd.test.fixtures.SyslogUdpSource
-
Initializes a SyslogUdpSource fixture.
- Table - Class in org.springframework.xd.shell.util
-
Provide a basic concept of a table structure containing a map of column headers and a collection of rows.
- Table() - Constructor for class org.springframework.xd.shell.util.Table
-
- TableHeader - Class in org.springframework.xd.shell.util
-
Defines table column headers used by
Table
.
- TableHeader(String, int) - Constructor for class org.springframework.xd.shell.util.TableHeader
-
Constructor that initializes the table header with the provided header name and the with of the table header.
- TableHeader(String) - Constructor for class org.springframework.xd.shell.util.TableHeader
-
Constructor that initializes the table header with the provided header name.
- tableName - Variable in class org.springframework.xd.jdbc.AbstractImportToJdbcOptionsMetadata
-
- tableName(String) - Method in class org.springframework.xd.test.fixtures.HdfsJdbcJob
-
Sets the tableName where the data will be written.
- tableName(String) - Method in class org.springframework.xd.test.fixtures.JdbcSink
-
Sets the table that the sink will write to.
- TableRow - Class in org.springframework.xd.shell.util
-
Holds the table rows used by
Table
.
- TableRow() - Constructor for class org.springframework.xd.shell.util.TableRow
-
- tail(int, String) - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new SimpleTailSource with the the provided file name and delay
- tail(String, boolean) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- TailSource - Class in org.springframework.xd.test.fixtures
-
Support class that represents a tail source.
- TailSource() - Constructor for class org.springframework.xd.test.fixtures.TailSource
-
- TailSourceOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Describes options to the tail
source module.
- TailSourceOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.TailSourceOptionsMetadata
-
- tap(String) - Method in class org.springframework.xd.integration.fixtures.Sources
-
Constructs a Tap fixture.
- Tap - Class in org.springframework.xd.test.fixtures
-
Test fixture that creates a tap.
- Tap(String) - Constructor for class org.springframework.xd.test.fixtures.Tap
-
Create a tap stream with the provided name.
- TAP_CHANNEL_PREFIX - Static variable in class org.springframework.xd.dirt.integration.bus.BusUtils
-
The prefix for the consumer/producer when creating a tap.
- TAP_TYPE_PREFIX - Static variable in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
- TAPS - Static variable in class org.springframework.xd.dirt.zookeeper.Paths
-
Name of taps node.
- tapSource() - Method in enum org.springframework.xd.dirt.stream.dsl.ChannelType
-
- target(String, String, String) - Method in class org.springframework.xd.shell.command.ConfigCommands
-
- Target - Class in org.springframework.xd.shell
-
Encapsulates various data points related to the Admin Server Target, such as target URI, success/error state,
exception messages that may have occurred.
- Target(String, String, String) - Constructor for class org.springframework.xd.shell.Target
-
Construct a new Target.
- Target(String) - Constructor for class org.springframework.xd.shell.Target
-
Construct a new Target.
- Target.Credentials - Class in org.springframework.xd.shell
-
- Target.Credentials() - Constructor for class org.springframework.xd.shell.Target.Credentials
-
- Target.Credentials(String, String) - Constructor for class org.springframework.xd.shell.Target.Credentials
-
- Target.TargetStatus - Enum in org.springframework.xd.shell
-
- targetMimeTypes - Variable in class org.springframework.xd.dirt.integration.bus.converter.AbstractFromMessageConverter
-
- TaskletType - Enum in org.springframework.xd.dirt.job
-
Types of Tasklet
implementations known by Spring XD.
- tcp() - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Construct a new TcpSink with the default target host taken from the environment and default port (1234)
- tcp(String) - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Construct a new TcpSink with the target host and the default port.
- tcp(int) - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Construct a new TcpSink with the default target host taken from the environment and the provided port.
- tcp() - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new TcpSource with the default target host localhost and port (1234)
- tcp(String) - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new TcpSource with the default target host taken from the environment and default port (1234)
- tcp(String, int) - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new TcpSource with the default target host taken from the environment and the provided port.
- tcpClientSource() - Method in class org.springframework.xd.integration.fixtures.Sources
-
- TcpClientSource - Class in org.springframework.xd.test.fixtures
-
A test fixture that allows testing of the 'tcp-client' source module.
- TcpClientSource(String, int) - Constructor for class org.springframework.xd.test.fixtures.TcpClientSource
-
- TcpClientSourceOptionsMetadata - Class in org.springframework.xd.tcp
-
Captures options available to the tcp-client
source module.
- TcpClientSourceOptionsMetadata() - Constructor for class org.springframework.xd.tcp.TcpClientSourceOptionsMetadata
-
- tcpSink() - Method in class org.springframework.xd.integration.fixtures.Sinks
-
Construct a new TcpSink with the target host resolved at runtime from the default stream name.
- TcpSink - Class in org.springframework.xd.test.fixtures
-
Test fixture that creates a simple socket server, ready to accept connections from a 'tcp' sink module.
- TcpSink() - Constructor for class org.springframework.xd.test.fixtures.TcpSink
-
- TcpSink(String, int) - Constructor for class org.springframework.xd.test.fixtures.TcpSink
-
Create a TcpSink with the provided port
- TcpSink(int) - Constructor for class org.springframework.xd.test.fixtures.TcpSink
-
Create a TcpSink with the provided port
- TcpSinkOptionsMetadata - Class in org.springframework.xd.tcp
-
Captures the options to the tcp
sink module.
- TcpSinkOptionsMetadata() - Constructor for class org.springframework.xd.tcp.TcpSinkOptionsMetadata
-
- tcpSource() - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new TcpSource with the target host resolved at runtime from the default stream name.
- tcpSource(String) - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a new TcpSource with the target host resolved at runtime from the stream name.
- TcpSource - Class in org.springframework.xd.test.fixtures
-
A test fixture that allows testing of the 'tcp' source module.
- TcpSource() - Constructor for class org.springframework.xd.test.fixtures.TcpSource
-
- TcpSource(String) - Constructor for class org.springframework.xd.test.fixtures.TcpSource
-
- TcpSource(String, int) - Constructor for class org.springframework.xd.test.fixtures.TcpSource
-
Construct a new TcpSource with the provided host and port
- TcpSourceOptionsMetadata - Class in org.springframework.xd.tcp
-
Captures options for the tcp
source module.
- TcpSourceOptionsMetadata() - Constructor for class org.springframework.xd.tcp.TcpSourceOptionsMetadata
-
- template - Variable in class org.springframework.xd.cassandra.CassandraSinkConfiguration
-
- TestModuleDefinitions - Class in org.springframework.xd.module
-
Utility class for creating ModuleDefinitions in the context of tests.
- TestModuleDefinitions() - Constructor for class org.springframework.xd.module.TestModuleDefinitions
-
- testOnBorrow - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- testOnReturn - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- testWhileIdle - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- text(String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- ThreadContextClassLoaderSetterAdvice - Class in org.springframework.xd.dirt.module.support
-
An advice that will set the thread context ClassLoader
to the
enclosing ApplicationContext's class loader
before invocation and reset
it afterwards.
- ThreadContextClassLoaderSetterAdvice() - Constructor for class org.springframework.xd.dirt.module.support.ThreadContextClassLoaderSetterAdvice
-
- ThroughputSamplerMessageHandler - Class in org.springframework.xd.integration.throughput
-
Samples throughput by counting messages over an elapsed time between receiving a
Message
with the given startMessage
and a endMessage
and
reports the throughput in the given TimeUnit
.
- ThroughputSamplerMessageHandler() - Constructor for class org.springframework.xd.integration.throughput.ThroughputSamplerMessageHandler
-
Create a ThroughputSamplerMessageHandler using the String
START as the start
message and the String
END as the end message and measure throughput in seconds.
- ThroughputSamplerMessageHandler(Object, Object, TimeUnit) - Constructor for class org.springframework.xd.integration.throughput.ThroughputSamplerMessageHandler
-
- ThroughputSamplerMessageHandler(String, String, String) - Constructor for class org.springframework.xd.integration.throughput.ThroughputSamplerMessageHandler
-
- ThroughputSamplerOptionsMetadata - Class in org.springframework.xd.integration.throughput
-
- ThroughputSamplerOptionsMetadata() - Constructor for class org.springframework.xd.integration.throughput.ThroughputSamplerOptionsMetadata
-
- throwAlreadyDeployedException(String) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- throwDefinitionAlreadyExistsException(D) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- throwDefinitionNotDeployable(String) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- throwNoSuchDefinitionException(String) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- throwNoSuchDefinitionException(String, String) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- throwNotDeployedException(String) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- timeBetweenEvictionRunsMillis - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- TimeSourceOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Describes options to the time
source module.
- TimeSourceOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.TimeSourceOptionsMetadata
-
- TimestampFileJobOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Options for the timestampfile
job module.
- TimestampFileJobOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.TimestampFileJobOptionsMetadata
-
- TimestampFileTasklet - Class in org.springframework.batch.integration.x
-
A Tasklet
implementation
that writes the current timestamp to a file.
- TimestampFileTasklet(String, String, String, String) - Constructor for class org.springframework.batch.integration.x.TimestampFileTasklet
-
- TimeUtils - Class in org.springframework.xd.rest.domain.util
-
Provides a commons set of time-related helper methods and also defines common
date/time formats.
- timeZone - Variable in class org.springframework.xd.dirt.rest.AbstractBatchJobsController
-
- TMP_DIR - Static variable in class org.springframework.xd.integration.util.StreamUtils
-
- to - Variable in class org.springframework.xd.dirt.job.dsl.Link
-
- to(String) - Method in class org.springframework.xd.test.fixtures.MailSink
-
- toBytes(Integer) - Method in class org.springframework.xd.dirt.integration.kafka.IntegerEncoderDecoder
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.AbstractMetricSink
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.AbstractModuleFixture
-
Returns a representation of the module suitable for inclusion in a stream definition, e.g.
file --dir=xxxx --name=yyyy
- toDSL() - Method in class org.springframework.xd.test.fixtures.FileJdbcJob
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.FilePollHdfsJob
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.FileSink
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.FileSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.FtpHdfsJob
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.FtpSink
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.FtpSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.GemFireCQSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.GemFireServerSink
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.GemFireSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.HdfsJdbcJob
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.HdfsMongoDbJob
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.HdfsSink
-
Renders the DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.IncrementalJdbcHdfsJob
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.JdbcHdfsJob
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.JdbcSink
-
Renders the DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.JdbcSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.JmsSource
-
Renders the DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.KafkaSink
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.KafkaSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.LogSink
-
Renders the DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.MailSink
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.MqttSink
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.MqttSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.NonPollingImapSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.PartitionedJdbcHdfsJob
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.PollingMailSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.RabbitSink
-
Renders the DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.RabbitSource
-
Renders the DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.SimpleCounterSink
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.SimpleFileSink
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.SimpleFileSource
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.SimpleHttpSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.SimpleTailSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.SparkAppJob
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.SyslogTcpSource
-
Renders the DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.SyslogUdpSource
-
Renders the DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.TailSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.Tap
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.TcpClientSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.TcpSink
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.TcpSource
-
- toDSL() - Method in class org.springframework.xd.test.fixtures.Transform
-
Renders the default DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.TwitterSearchSource
-
Renders the DSL for this fixture.
- toDSL() - Method in class org.springframework.xd.test.fixtures.TwitterStreamSource
-
Renders the DSL for this fixture.
- toDSLText() - Method in class org.springframework.xd.dirt.job.dsl.Graph
-
Produce the DSL representation of the graph.
- toExceptionDescriptor() - Method in exception org.springframework.xd.dirt.job.dsl.JobSpecificationException
-
Produce a simple map of information about the exception that
can be sent to the client for display.
- toGraph() - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
- toJobLaunchRequest(Message<?>) - Method in class org.springframework.xd.dirt.plugins.job.JobLaunchRequestTransformer
-
- toJSON() - Method in class org.springframework.xd.dirt.job.dsl.Graph
-
- Token - Class in org.springframework.xd.dirt.job.dsl
-
Holder for a kind of token, the associated data and its position in the input data stream (start/end).
- Token - Class in org.springframework.xd.dirt.stream.dsl
-
Holder for a kind of token, the associated data and its position in the input data stream (start/end).
- TokenKind - Enum in org.springframework.xd.dirt.job.dsl
-
Enumeration of all the token types that may be found in a Job DSL specification.
- TokenKind - Enum in org.springframework.xd.dirt.stream.dsl
-
Enumeration of all the token types that may be found in a DSL definition stream.
- Tokens - Class in org.springframework.xd.dirt.job.dsl
-
Class that converts an expression into a list of
tokens
.
- Tokens(String) - Constructor for class org.springframework.xd.dirt.job.dsl.Tokens
-
Construct a Tokens
object based on the provided string expression.
- toMap() - Method in class org.springframework.xd.dirt.core.DeploymentUnitStatus
-
Return a map containing the deployment unit status information.
- toMap() - Method in class org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus
-
Return a map containing the state and error description
(if any) for this status.
- toMessage(Object, MessageHeaders) - Method in class org.springframework.integration.x.http.NettyInboundMessageConverter
-
- toMessage(MessageBuilderFactory) - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
Convert to a Message
using a MessageBuilderFactory
.
- toMessage() - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
Convert to a Message
using a the default MessageBuilder
.
- toObject(String) - Method in class org.springframework.integration.x.gemfire.JsonStringToObjectTransformer
-
- ToolsController - Class in org.springframework.xd.dirt.rest
-
A controller for integrating with frontend tools.
- ToolsController(XDStreamParser) - Constructor for class org.springframework.xd.dirt.rest.ToolsController
-
- topic(String) - Method in class org.springframework.xd.test.fixtures.KafkaSink
-
Set the topic that the sink will publish to
- topic(String) - Method in class org.springframework.xd.test.fixtures.KafkaSource
-
sets the topic for the kafka source
- TOPIC_CHANNEL_PREFIX - Static variable in class org.springframework.xd.dirt.integration.bus.BusUtils
-
The prefix for the consumer/producer when creating a topic.
- TOPIC_PREFIX - Static variable in class org.springframework.xd.dirt.test.AbstractSingleNodeNamedChannelModuleFactory
-
- toResource(DetailedJobInfo) - Method in class org.springframework.xd.dirt.rest.DetailedJobInfoResourceAssembler
-
- toResource(ModuleDefinition) - Method in class org.springframework.xd.dirt.rest.DetailedModuleDefinitionResourceAssembler
-
- toResource(DocumentParseResult) - Method in class org.springframework.xd.dirt.rest.DocumentParseResultResourceAssembler
-
- toResource(JobDefinition) - Method in class org.springframework.xd.dirt.rest.JobDefinitionResourceAssembler
-
- toResource(JobExecutionInfo) - Method in class org.springframework.xd.dirt.rest.JobExecutionInfoResourceAssembler
-
- toResource(JobInfo) - Method in class org.springframework.xd.dirt.rest.JobInfoResourceAssembler
-
- toResource(JobInstanceInfo) - Method in class org.springframework.xd.dirt.rest.JobInstanceInfoResourceAssembler
-
- toResource(AggregateCount) - Method in class org.springframework.xd.dirt.rest.metrics.DeepAggregateCountResourceAssembler
-
- toResource(Counter) - Method in class org.springframework.xd.dirt.rest.metrics.DeepCounterResourceAssembler
-
- toResource(FieldValueCounter) - Method in class org.springframework.xd.dirt.rest.metrics.DeepFieldValueCounterResourceAssembler
-
- toResource(M) - Method in class org.springframework.xd.dirt.rest.metrics.ShallowMetricResourceAssembler
-
- toResource(ModuleDefinition) - Method in class org.springframework.xd.dirt.rest.ModuleDefinitionResourceAssembler
-
- toResource(ModuleMetadata) - Method in class org.springframework.xd.dirt.rest.ModuleMetadataResourceAssembler
-
- toResource(DetailedContainer) - Method in class org.springframework.xd.dirt.rest.RuntimeContainerResourceAssembler
-
- toResource(StepExecutionInfo) - Method in class org.springframework.xd.dirt.rest.StepExecutionInfoResourceAssembler
-
- toResource(StepExecutionProgressInfo) - Method in class org.springframework.xd.dirt.rest.StepExecutionProgressInfoResourceAssembler
-
- toResource(StreamDefinition) - Method in class org.springframework.xd.dirt.rest.StreamDefinitionResourceAssembler
-
- toSink() - Method in class org.springframework.xd.cassandra.CassandraSinkConfiguration
-
- toSinkBridgeMessageHandler() - Method in class org.springframework.xd.cassandra.CassandraSinkConfiguration
-
- toString(Object) - Method in class org.springframework.integration.x.gemfire.JsonStringToObjectTransformer
-
- toString() - Method in class org.springframework.xd.analytics.metrics.core.AggregateCount
-
- toString() - Method in class org.springframework.xd.analytics.metrics.core.Counter
-
- toString() - Method in class org.springframework.xd.analytics.metrics.core.FieldValueCounter
-
- toString() - Method in class org.springframework.xd.analytics.metrics.core.Gauge
-
- toString() - Method in class org.springframework.xd.analytics.metrics.core.RichGauge
-
- toString() - Method in class org.springframework.xd.dirt.cluster.Admin
- toString() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- toString() - Method in class org.springframework.xd.dirt.cluster.Container
- toString() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- toString() - Method in class org.springframework.xd.dirt.core.BaseDefinition
-
- toString() - Method in class org.springframework.xd.dirt.core.DeploymentUnitStatus
- toString() - Method in class org.springframework.xd.dirt.core.Job
- toString() - Method in class org.springframework.xd.dirt.core.JobDeploymentsPath
- toString() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentRequestsPath
- toString() - Method in class org.springframework.xd.dirt.core.ModuleDeploymentsPath
- toString() - Method in class org.springframework.xd.dirt.core.Stream
- toString() - Method in class org.springframework.xd.dirt.core.StreamDeploymentsPath
- toString() - Method in class org.springframework.xd.dirt.event.AbstractEvent
-
- toString() - Method in class org.springframework.xd.dirt.event.AbstractModuleEvent
-
- toString() - Method in class org.springframework.xd.dirt.integration.bus.AbstractBusPropertiesAccessor
-
- toString() - Method in class org.springframework.xd.dirt.integration.bus.Binding
-
- toString() - Method in class org.springframework.xd.dirt.job.dsl.ArgumentNode
-
- toString() - Method in class org.springframework.xd.dirt.job.dsl.Flow
-
- toString() - Method in class org.springframework.xd.dirt.job.dsl.Graph
-
- toString() - Method in class org.springframework.xd.dirt.job.dsl.JobDescriptor
-
- toString() - Method in class org.springframework.xd.dirt.job.dsl.JobParser
-
Show the parsing progress in the output string.
- toString() - Method in class org.springframework.xd.dirt.job.dsl.JobReference
-
- toString() - Method in class org.springframework.xd.dirt.job.dsl.Link
-
- toString() - Method in class org.springframework.xd.dirt.job.dsl.Node
-
- toString() - Method in class org.springframework.xd.dirt.job.dsl.Split
-
- toString() - Method in class org.springframework.xd.dirt.job.dsl.Token
-
- toString() - Method in enum org.springframework.xd.dirt.job.dsl.TokenKind
-
- toString() - Method in class org.springframework.xd.dirt.job.dsl.Tokens
-
- toString() - Method in class org.springframework.xd.dirt.module.store.ModuleMetadata.Id
-
- toString() - Method in class org.springframework.xd.dirt.module.UploadedModuleDefinition
-
- toString() - Method in class org.springframework.xd.dirt.plugins.job.support.listener.ChunkContextInfo
-
- toString() - Method in class org.springframework.xd.dirt.server.admin.deployment.DeploymentMessage
-
- toString() - Method in class org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus
- toString() - Method in class org.springframework.xd.dirt.stream.BaseInstance
-
- toString() - Method in class org.springframework.xd.dirt.stream.dsl.ArgumentNode
-
- toString() - Method in class org.springframework.xd.dirt.stream.dsl.ChannelNode
-
- toString() - Method in class org.springframework.xd.dirt.stream.dsl.LabelNode
-
- toString() - Method in class org.springframework.xd.dirt.stream.dsl.ModuleNode
-
- toString() - Method in class org.springframework.xd.dirt.stream.dsl.SinkChannelNode
-
- toString() - Method in class org.springframework.xd.dirt.stream.dsl.SourceChannelNode
-
- toString() - Method in class org.springframework.xd.dirt.stream.dsl.StreamConfigParser
-
- toString() - Method in class org.springframework.xd.dirt.stream.dsl.StreamNode
-
- toString() - Method in class org.springframework.xd.dirt.stream.dsl.Token
-
- toString() - Method in enum org.springframework.xd.dirt.stream.dsl.TokenKind
-
- toString() - Method in class org.springframework.xd.dirt.web.controller.support.AuthenticationRequest
-
- toString() - Method in class org.springframework.xd.integration.util.jmxresult.Module
-
- toString() - Method in class org.springframework.xd.module.CompositeModuleDefinition
-
- toString() - Method in class org.springframework.xd.module.core.AbstractModule
-
- toString() - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- toString() - Method in class org.springframework.xd.module.ModuleDescriptor.Key
- toString() - Method in class org.springframework.xd.module.ModuleDescriptor
- toString() - Method in class org.springframework.xd.module.options.FlattenedCompositeModuleOptionsMetadata
-
- toString() - Method in class org.springframework.xd.module.options.ModuleOption
-
- toString() - Method in class org.springframework.xd.module.options.PojoModuleOptionsMetadata
-
- toString() - Method in class org.springframework.xd.module.options.types.Password
-
- toString() - Method in class org.springframework.xd.module.SimpleModuleDefinition
-
- toString() - Method in class org.springframework.xd.module.support.NestedArchiveResource
-
- toString() - Method in class org.springframework.xd.module.support.ParentLastURLClassLoader
-
- toString() - Method in class org.springframework.xd.rest.client.impl.JobTemplate
-
- toString() - Method in class org.springframework.xd.rest.client.impl.ModuleTemplate
-
- toString() - Method in class org.springframework.xd.rest.domain.DetailedContainerResource
-
- toString() - Method in class org.springframework.xd.rest.domain.DetailedModuleDefinitionResource.Option
-
- toString() - Method in class org.springframework.xd.rest.domain.ModuleMetadataResource
-
- toString() - Method in class org.springframework.xd.shell.Target
-
- toString() - Method in class org.springframework.xd.shell.util.Table
-
- toString() - Method in class org.springframework.xd.shell.util.TableRow
-
- toString() - Method in class org.springframework.xd.test.fixtures.AbstractModuleFixture
-
- toString() - Method in class org.springframework.xd.tuple.DefaultTuple
-
- ToStringCharsetMixin - Class in org.springframework.xd.module.options.mixins
-
A standard mixin for modules that do conversion from bytes to String.
- ToStringCharsetMixin() - Constructor for class org.springframework.xd.module.options.mixins.ToStringCharsetMixin
-
- toTuple(String) - Method in class org.springframework.xd.tuple.TupleStringMarshaller
-
- touchz(String) - Method in class org.springframework.xd.shell.hadoop.FsShellCommands
-
- toXML(String) - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
- toXML(String, boolean) - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
- TRACK_HISTORY_KEY - Static variable in class org.springframework.xd.module.ModuleDeploymentProperties
-
Key for the trackHistory
property.
- trackMembership(String) - Method in class org.springframework.xd.store.AbstractRedisRepository
-
Perform bookkeeping of entities managed by this repository.
- transferResultsToLocal(String, URL, String) - Static method in class org.springframework.xd.integration.util.StreamUtils
-
Copies the specified file from a remote machine to local machine.
- transform() - Method in class org.springframework.xd.integration.fixtures.Processors
-
Construct a new Transform fixture.
- Transform - Class in org.springframework.xd.test.fixtures
-
Test fixture that creates a Transform.
- Transform() - Constructor for class org.springframework.xd.test.fixtures.Transform
-
- transformPayload(Map<String, Map<Integer, List<Object>>>) - Method in class org.springframework.integration.x.kafka.KafkaMessageTransformer
-
Transform message payload to Map
where partitionIndex is the key and message payload is the value.
- transformPayload(String) - Method in class org.springframework.xd.jdbc.JdbcMessagePayloadTransformer
-
- transformPayload(String) - Method in class org.springframework.xd.tuple.integration.JsonToTupleTransformer
-
- transformPayload(Map<Object, Object>) - Method in class org.springframework.xd.tuple.integration.MapToTupleTransformer
-
- Transition - Class in org.springframework.xd.dirt.job.dsl
-
An AST node representing a transition found in the parsed Job specification.
- Transition(Token, JobReference) - Constructor for class org.springframework.xd.dirt.job.dsl.Transition
-
- TriggerSourceOptionsMetadata - Class in org.springframework.xd.dirt.modules.metadata
-
Describes options to the trigger
source module.
- TriggerSourceOptionsMetadata() - Constructor for class org.springframework.xd.dirt.modules.metadata.TriggerSourceOptionsMetadata
-
- TriggerSourceOptionsMetadata.DateHasBeenSet - Interface in org.springframework.xd.dirt.modules.metadata
-
- Tuple - Interface in org.springframework.xd.tuple
-
Data structure that stores a fixed number of ordered key-value pairs and adds convenience methods to access values in
a type-safe manner.
- tuple() - Static method in class org.springframework.xd.tuple.TupleBuilder
-
- TupleBuilder - Class in org.springframework.xd.tuple
-
Builder class to create Tuple instances.
- TupleBuilder() - Constructor for class org.springframework.xd.tuple.TupleBuilder
-
- TupleBuilder.ConversionServiceBuilder - Class in org.springframework.xd.tuple
-
Provides the ability to inject a
ConfigurableConversionService
as a way to
customize conversion behavior in the built
Tuple
.
- TupleFieldExtractor - Class in org.springframework.xd.tuple.batch
-
Implementation of the
FieldExtractor
that extracts fields from a
Tuple
.
- TupleFieldExtractor() - Constructor for class org.springframework.xd.tuple.batch.TupleFieldExtractor
-
- TupleFieldSetMapper - Class in org.springframework.xd.tuple.batch
-
A
FieldSetMapper
implementation intended to allow a user use a
Tuple
as the item.
- TupleFieldSetMapper() - Constructor for class org.springframework.xd.tuple.batch.TupleFieldSetMapper
-
- TupleJsonMarshaller - Class in org.springframework.xd.tuple
-
- TupleJsonMarshaller() - Constructor for class org.springframework.xd.tuple.TupleJsonMarshaller
-
- TupleKryoRegistrar - Class in org.springframework.xd.tuple.serializer.kryo
-
- TupleKryoRegistrar() - Constructor for class org.springframework.xd.tuple.serializer.kryo.TupleKryoRegistrar
-
- TupleProcessor - Interface in org.springframework.xd.tuple.processor
-
Simple type-safe process callback method that returns another Tuple
- TuplePropertyAccessor - Class in org.springframework.xd.tuple.spel
-
A
PropertyAccessor
implementation that enables reading of
Tuple
values using dot notation within SpEL
expressions.
- TuplePropertyAccessor() - Constructor for class org.springframework.xd.tuple.spel.TuplePropertyAccessor
-
- tupleRegistrar() - Method in class org.springframework.xd.dirt.server.MessageBusExtensionsConfiguration
-
- TupleRowMapper - Class in org.springframework.xd.tuple.batch
-
A
RowMapper
implementation to be used with the
Tuple
data structure.
- TupleRowMapper() - Constructor for class org.springframework.xd.tuple.batch.TupleRowMapper
-
- TupleSqlParameterSource - Class in org.springframework.xd.tuple.batch
-
Implementation of a
SqlParameterSource
that translates a
Tuple
into SQL parameters.
- TupleSqlParameterSource(Tuple) - Constructor for class org.springframework.xd.tuple.batch.TupleSqlParameterSource
-
- TupleSqlParameterSourceProvider - Class in org.springframework.xd.tuple.batch
-
- TupleSqlParameterSourceProvider() - Constructor for class org.springframework.xd.tuple.batch.TupleSqlParameterSourceProvider
-
- TupleStringMarshaller - Class in org.springframework.xd.tuple
-
- TupleStringMarshaller(Converter<Tuple, String>, Converter<String, Tuple>) - Constructor for class org.springframework.xd.tuple.TupleStringMarshaller
-
- TupleToJsonMessageConverter - Class in org.springframework.xd.dirt.integration.bus.converter
-
A
MessageConverter
to convert a
Tuple
to a JSON String
- TupleToJsonMessageConverter() - Constructor for class org.springframework.xd.dirt.integration.bus.converter.TupleToJsonMessageConverter
-
- TupleToJsonStringConverter - Class in org.springframework.xd.tuple
-
Converts a Tuple to JSON representation
- TupleToJsonStringConverter() - Constructor for class org.springframework.xd.tuple.TupleToJsonStringConverter
-
- TupleWriteConverter - Class in org.springframework.xd.mongodb
-
- TupleWriteConverter() - Constructor for class org.springframework.xd.mongodb.TupleWriteConverter
-
- TwitterMixin - Class in org.springframework.integration.x.twitter
-
Options common to twitter source modules
- TwitterMixin() - Constructor for class org.springframework.integration.x.twitter.TwitterMixin
-
- twitterSearch(String) - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a TwitterSearchSource using that will search for the query string provided..
- TwitterSearchChannelAdapter - Class in org.springframework.integration.x.twitter
-
Message producer which reads form Twitter's public search endpoints.
- TwitterSearchChannelAdapter(TwitterTemplate) - Constructor for class org.springframework.integration.x.twitter.TwitterSearchChannelAdapter
-
- TwitterSearchChannelAdapter.ResultType - Enum in org.springframework.integration.x.twitter
-
- TwitterSearchOptionsMetadata - Class in org.springframework.integration.x.twitter
-
- TwitterSearchOptionsMetadata() - Constructor for class org.springframework.integration.x.twitter.TwitterSearchOptionsMetadata
-
- TwitterSearchSource - Class in org.springframework.xd.test.fixtures
-
A test fixture that allows testing of the 'TwitterSearch' source module.
- TwitterSearchSource(String, String, String) - Constructor for class org.springframework.xd.test.fixtures.TwitterSearchSource
-
Initializes a TwitterSearchSource fixture.
- twitterStream() - Method in class org.springframework.xd.integration.fixtures.Sources
-
Construct a TwitterStreamSource fixture..
- TwitterStreamChannelAdapter - Class in org.springframework.integration.x.twitter
-
Message producer which reads form Twitter's public stream endpoints.
- TwitterStreamChannelAdapter(TwitterTemplate) - Constructor for class org.springframework.integration.x.twitter.TwitterStreamChannelAdapter
-
- TwitterStreamChannelAdapter.FilterLevel - Enum in org.springframework.integration.x.twitter
-
- TwitterStreamOptionsMetadata - Class in org.springframework.integration.x.twitter
-
- TwitterStreamOptionsMetadata() - Constructor for class org.springframework.integration.x.twitter.TwitterStreamOptionsMetadata
-
- TwitterStreamSource - Class in org.springframework.xd.test.fixtures
-
A test fixture that allows testing of the 'TwitterStream' source module.
- TwitterStreamSource(String, String, String, String) - Constructor for class org.springframework.xd.test.fixtures.TwitterStreamSource
-
Initializes a TwitterStreamSource fixture.
- type - Variable in class org.springframework.xd.shell.command.ModuleCommands.QualifiedModuleName
-
- validate(JobDefinitionRepository) - Method in class org.springframework.xd.dirt.job.dsl.JobSpecification
-
Performs validation of the AST.
- validate(String) - Method in class org.springframework.xd.dirt.rest.ToolsController
-
Accept a whole list of definitions and report whether they are valid as a whole or not.
- validate() - Method in class org.springframework.xd.module.options.ModuleOptions
-
- validateBeforeDelete(String) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- validateBeforeDelete(String) - Method in interface org.springframework.xd.dirt.stream.DeploymentValidator
-
Validate before deletion of the definition.
- validateBeforeDeploy(String, Map<String, String>) - Method in class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
- validateBeforeDeploy(String, Map<String, String>) - Method in interface org.springframework.xd.dirt.stream.DeploymentValidator
-
Validate before deploying.
- validateBeforeSave(String, String) - Method in class org.springframework.xd.dirt.stream.AbstractDeployer
-
- validateBeforeSave(String, String) - Method in interface org.springframework.xd.dirt.stream.DeploymentValidator
-
Validate before saving the definitions.
- validateBeforeUndeploy(String) - Method in class org.springframework.xd.dirt.stream.AbstractInstancePersistingDeployer
-
- validateBeforeUndeploy(String) - Method in interface org.springframework.xd.dirt.stream.DeploymentValidator
-
Validate before un-deployment.
- validateChannelName(String) - Method in class org.springframework.xd.dirt.test.AbstractSingleNodeNamedChannelModuleFactory
-
- validateConsumerProperties(String, Properties, Set<Object>) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Validate the provided deployment properties for the consumer against those supported by this bus implementation.
- validateCronExpression(CronValidation) - Method in class org.springframework.xd.dirt.rest.validation.ValidationController
-
- validateNotSingleJobInstance(String, Collection<String>) - Static method in class org.springframework.xd.dirt.job.dsl.ComposedJobUtil
-
Throws exception if user tries to create a single job instance with no transitions.
- validateProducerProperties(String, Properties, Set<Object>) - Method in class org.springframework.xd.dirt.integration.bus.MessageBusSupport
-
Validate the provided deployment properties for the producer against those supported by this bus implementation.
- VALIDATION_PATTERN - Static variable in class org.springframework.integration.x.kafka.InitialOffsetsFactoryBean
-
- ValidationController - Class in org.springframework.xd.dirt.rest.validation
-
Provides server-validation services.
- ValidationController() - Constructor for class org.springframework.xd.dirt.rest.validation.ValidationController
-
- ValidationGroupsProvider - Interface in org.springframework.xd.module.options.spi
-
To be implemented by classes change their validation behavior based on which properties have been set by the user.
- validationInterval - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- validationQuery - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- validatorClassName - Variable in class org.springframework.xd.jdbc.JdbcConnectionPoolMixin
-
- valueOf(String) - Static method in enum org.springframework.integration.x.kafka.AutoOffsetResetStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata.OffsetStorageStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.integration.x.twitter.TwitterSearchChannelAdapter.ResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.integration.x.twitter.TwitterStreamChannelAdapter.FilterLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.analytics.metrics.core.AggregateCountResolution
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.core.DeploymentUnitStatus.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.integration.bus.MessageBus.Capability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.integration.kafka.KafkaMessageBus.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.integration.kafka.KafkaMessageBus.OffsetManagement
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.job.dsl.JobDSLMessage.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.job.dsl.JobDSLMessage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.job.dsl.TokenKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.job.StepType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.job.TaskletType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata.StoreKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.modules.metadata.FileReadingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.plugins.job.support.listener.BatchListenerEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.server.admin.deployment.DeploymentAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.server.admin.deployment.DeploymentUnitType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.stream.dsl.ChannelType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.stream.dsl.TokenKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.stream.dsl.XDDSLMessages.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.stream.dsl.XDDSLMessages
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.stream.ParsingContext.Position
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.dirt.stream.ParsingContext
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.greenplum.support.ControlFile.OutputMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.greenplum.support.Format
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.greenplum.support.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.greenplum.support.SegmentRejectType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.http.HttpClientProcessorOptionsMetadata.HttpMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.integration.fixtures.ModuleType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.mail.MailProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.module.ModuleType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.module.options.mixins.IntoMongoDbOptionMixin.WriteConcern
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.rest.client.AggregateCounterOperations.Resolution
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.rest.domain.CompletionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.rest.domain.RESTDeploymentState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.rest.domain.RESTModuleType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.shell.Target.TargetStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.tcp.encdec.EncoderDecoderMixins.Encoding
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.test.fixtures.SimpleFileSource.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.xd.tuple.batch.FieldSetType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.springframework.integration.x.kafka.AutoOffsetResetStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.integration.x.kafka.KafkaSourceModuleOptionsMetadata.OffsetStorageStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.integration.x.twitter.TwitterSearchChannelAdapter.ResultType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.integration.x.twitter.TwitterStreamChannelAdapter.FilterLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.analytics.metrics.core.AggregateCountResolution
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.springframework.xd.dirt.cluster.AdminAttributes
- values() - Method in class org.springframework.xd.dirt.cluster.ContainerAttributes
- values() - Static method in enum org.springframework.xd.dirt.core.DeploymentUnitStatus.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.integration.bus.MessageBus.Capability
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.springframework.xd.dirt.integration.bus.MessageValues
-
- values() - Static method in enum org.springframework.xd.dirt.integration.kafka.KafkaMessageBus.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.integration.kafka.KafkaMessageBus.OffsetManagement
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.job.dsl.JobDSLMessage.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.job.dsl.JobDSLMessage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.job.dsl.TokenKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.job.StepType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.job.TaskletType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.modules.metadata.AggregatorProcessorModuleOptionsMetadata.StoreKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.modules.metadata.FileReadingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.modules.metadata.FileSinkOptionsMetadata.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.plugins.job.support.listener.BatchListenerEventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.server.admin.deployment.DeploymentAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.server.admin.deployment.DeploymentUnitType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.server.admin.deployment.ModuleDeploymentStatus.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.stream.dsl.ChannelType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.stream.dsl.TokenKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.stream.dsl.XDDSLMessages.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.stream.dsl.XDDSLMessages
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.stream.ParsingContext.Position
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.dirt.stream.ParsingContext
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.greenplum.support.ControlFile.OutputMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.greenplum.support.Format
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.greenplum.support.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.greenplum.support.SegmentRejectType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.http.HttpClientProcessorOptionsMetadata.HttpMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.integration.fixtures.ModuleType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.mail.MailProtocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.springframework.xd.module.ModuleDeploymentProperties
- values() - Static method in enum org.springframework.xd.module.ModuleType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.module.options.mixins.IntoMongoDbOptionMixin.WriteConcern
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.rest.client.AggregateCounterOperations.Resolution
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.rest.domain.CompletionKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.rest.domain.RESTDeploymentState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.rest.domain.RESTModuleType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.shell.Target.TargetStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.tcp.encdec.EncoderDecoderMixins.Encoding
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.test.fixtures.SimpleFileSource.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.springframework.xd.tuple.batch.FieldSetType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- verifyContentContains(URL, String, String) - Method in class org.springframework.xd.integration.util.XdEc2Validation
-
Verifies that the data user gave us is contained in the result.
- verifyContentContainsIgnoreCase(URL, String, String) - Method in class org.springframework.xd.integration.util.XdEc2Validation
-
Verifies that the data user gave us is contained in the result.
- verifyHdfsTestContent(String, String) - Method in class org.springframework.xd.integration.util.XdEc2Validation
-
Evaluates the content of the hdfs file against a result.
- verifyLogContains(URL, String) - Method in class org.springframework.xd.integration.util.XdEc2Validation
-
Verifies that the data is contained in the container log.
- verifyTestContent(URL, String, String) - Method in class org.springframework.xd.integration.util.XdEc2Validation
-
Verifies that the data user gave us is what was stored after the stream has processed the flow.
- verifyXDAdminReady(URL) - Method in class org.springframework.xd.integration.util.XdEc2Validation
-
Assert is the admin server is available.
- VersionController - Class in org.springframework.xd.dirt.rest.meta
-
Controller to retrieve version control information.
- VersionController() - Constructor for class org.springframework.xd.dirt.rest.meta.VersionController
-
- VersionPatternConverter - Class in org.springframework.xd.dirt.util.logging
-
Implementation of ClassicConverter
that returns the "Implementation-Version" string obtained from the
manifest of the jar that this class was loaded from.
- VersionPatternConverter() - Constructor for class org.springframework.xd.dirt.util.logging.VersionPatternConverter
-
- VersionPatternLayout - Class in org.springframework.xd.dirt.util.logging
-
Extension of Log4j's
EnhancedPatternLayout
which supports logging of the "Implementation-Version" string
obtained from the manifest of the jar that
VersionPatternParser
is loaded from.
- VersionPatternLayout() - Constructor for class org.springframework.xd.dirt.util.logging.VersionPatternLayout
-
- VersionPatternParser - Class in org.springframework.xd.dirt.util.logging
-
Extension of Log4j's
PatternParser
that recognizes the pattern
%v
which is used to log the
"Implementation-Version" string obtained from the manifest of the
jar that
VersionPatternParser
is loaded from.
- VersionPatternParser(String) - Constructor for class org.springframework.xd.dirt.util.logging.VersionPatternParser
-
- VersionResource - Class in org.springframework.xd.rest.domain.meta
-
Provides the version information for Spring XD.
- VersionResource() - Constructor for class org.springframework.xd.rest.domain.meta.VersionResource
-
Default constructor for serialization frameworks.
- VersionResource(String) - Constructor for class org.springframework.xd.rest.domain.meta.VersionResource
-
Default constructor for serialization frameworks.
- VndErrorResponseErrorHandler - Class in org.springframework.xd.rest.client.impl
-
Extension of DefaultResponseErrorHandler
that knows how to de-serialize a VndErrors.VndError
structure.
- VndErrorResponseErrorHandler(List<HttpMessageConverter<?>>) - Constructor for class org.springframework.xd.rest.client.impl.VndErrorResponseErrorHandler
-